You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@brooklyn.apache.org by he...@apache.org on 2016/02/01 18:34:41 UTC

[01/51] [abbrv] brooklyn-dist git commit: [SPLITPREP] rearranged to have structure of new repositories

Repository: brooklyn-dist
Updated Branches:
  refs/heads/master [created] 26c4604ca


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/src/main/license/files/NOTICE
----------------------------------------------------------------------
diff --git a/usage/dist/src/main/license/files/NOTICE b/usage/dist/src/main/license/files/NOTICE
deleted file mode 100644
index f790f13..0000000
--- a/usage/dist/src/main/license/files/NOTICE
+++ /dev/null
@@ -1,5 +0,0 @@
-Apache Brooklyn
-Copyright 2014-2015 The Apache Software Foundation
-
-This product includes software developed at
-The Apache Software Foundation (http://www.apache.org/).

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/src/test/java/org/apache/brooklyn/cli/BaseCliIntegrationTest.java
----------------------------------------------------------------------
diff --git a/usage/dist/src/test/java/org/apache/brooklyn/cli/BaseCliIntegrationTest.java b/usage/dist/src/test/java/org/apache/brooklyn/cli/BaseCliIntegrationTest.java
deleted file mode 100644
index 4cb2d2b..0000000
--- a/usage/dist/src/test/java/org/apache/brooklyn/cli/BaseCliIntegrationTest.java
+++ /dev/null
@@ -1,189 +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.brooklyn.cli;
-
-import static org.testng.Assert.assertEquals;
-import static org.testng.Assert.assertFalse;
-import static org.testng.Assert.assertTrue;
-import static org.testng.Assert.fail;
-
-import java.io.InputStream;
-import java.io.OutputStream;
-import java.util.NoSuchElementException;
-import java.util.Scanner;
-import java.util.concurrent.Callable;
-import java.util.concurrent.ExecutionException;
-import java.util.concurrent.ExecutorService;
-import java.util.concurrent.Executors;
-import java.util.concurrent.Future;
-import java.util.concurrent.TimeUnit;
-import java.util.concurrent.TimeoutException;
-
-import org.apache.brooklyn.core.entity.factory.ApplicationBuilder;
-import org.testng.annotations.AfterMethod;
-import org.testng.annotations.BeforeMethod;
-
-import com.google.common.collect.Lists;
-
-/**
- * Command line interface test support.
- */
-public class BaseCliIntegrationTest {
-
-    // TODO does this need to be hard-coded?
-    private static final String BROOKLYN_BIN_PATH = "./target/brooklyn-dist/bin/brooklyn";
-    private static final String BROOKLYN_CLASSPATH = "./target/test-classes/:./target/classes/";
-
-    // Times in seconds to allow Brooklyn to run and produce output
-    private static final long DELAY = 10l;
-    private static final long TIMEOUT = DELAY + 30l;
-
-    private ExecutorService executor;
-
-    @BeforeMethod(alwaysRun = true)
-    public void setup() {
-        executor = Executors.newCachedThreadPool();
-    }
-
-    @AfterMethod(alwaysRun = true)
-    public void teardown() {
-        executor.shutdownNow();
-    }
-
-    /** Invoke the brooklyn script with arguments. */
-    public Process startBrooklyn(String...argv) throws Throwable {
-        ProcessBuilder pb = new ProcessBuilder();
-        pb.environment().remove("BROOKLYN_HOME");
-        pb.environment().put("BROOKLYN_CLASSPATH", BROOKLYN_CLASSPATH);
-        pb.command(Lists.asList(BROOKLYN_BIN_PATH, argv));
-        return pb.start();
-    }
-
-    public void testBrooklyn(Process brooklyn, BrooklynCliTest test, int expectedExit) throws Throwable {
-        testBrooklyn(brooklyn, test, expectedExit, false);
-    }
-
-    /** Tests the operation of the Brooklyn CLI. */
-    public void testBrooklyn(Process brooklyn, BrooklynCliTest test, int expectedExit, boolean stop) throws Throwable {
-        try {
-            Future<Integer> future = executor.submit(test);
-
-            // Send CR to stop if required
-            if (stop) {
-                OutputStream out = brooklyn.getOutputStream();
-                out.write('\n');
-                out.flush();
-            }
-
-            int exitStatus = future.get(TIMEOUT, TimeUnit.SECONDS);
-
-            // Check error code from process
-            assertEquals(exitStatus, expectedExit, "Command returned wrong status");
-        } catch (TimeoutException te) {
-            fail("Timed out waiting for process to complete", te);
-        } catch (ExecutionException ee) {
-            if (ee.getCause() instanceof AssertionError) {
-                throw ee.getCause();
-            } else throw ee;
-        } finally {
-            brooklyn.destroy();
-        }
-    }
-
-    /** A {@link Callable} that encapsulates Brooklyn CLI test logic. */
-    public static abstract class BrooklynCliTest implements Callable<Integer> {
-
-        private final Process brooklyn;
-
-        private String consoleOutput;
-        private String consoleError;
-
-        public BrooklynCliTest(Process brooklyn) {
-            this.brooklyn = brooklyn;
-        }
-
-        @Override
-        public Integer call() throws Exception {
-            // Wait for initial output
-            Thread.sleep(TimeUnit.SECONDS.toMillis(DELAY));
-
-            // Get the console output of running that command
-            consoleOutput = convertStreamToString(brooklyn.getInputStream());
-            consoleError = convertStreamToString(brooklyn.getErrorStream());
-
-            // Check if the output looks as expected
-            checkConsole();
-
-            // Return exit status on completion
-            return brooklyn.waitFor();
-        }
-
-        /** Perform test assertions on console output and error streams. */
-        public abstract void checkConsole();
-
-        private String convertStreamToString(InputStream is) {
-            try {
-                return new Scanner(is).useDelimiter("\\A").next();
-            } catch (NoSuchElementException e) {
-                return "";
-            }
-        }
-
-        protected void assertConsoleOutput(String...expected) {
-            for (String e : expected) {
-                assertTrue(consoleOutput.contains(e), "Execution output not logged; output=" + consoleOutput);
-            }
-        }
-
-        protected void assertNoConsoleOutput(String...expected) {
-            for (String e : expected) {
-                assertFalse(consoleOutput.contains(e), "Execution output logged; output=" + consoleOutput);
-            }
-        }
-
-        protected void assertConsoleError(String...expected) {
-            for (String e : expected) {
-                assertTrue(consoleError.contains(e), "Execution error not logged; error=" + consoleError);
-            }
-        }
-
-        protected void assertNoConsoleError(String...expected) {
-            for (String e : expected) {
-                assertFalse(consoleError.contains(e), "Execution error logged; error=" + consoleError);
-            }
-        }
-
-        protected void assertConsoleOutputEmpty() {
-            assertTrue(consoleOutput.isEmpty(), "Output present; output=" + consoleOutput);
-        }
-
-        protected void assertConsoleErrorEmpty() {
-            assertTrue(consoleError.isEmpty(), "Error present; error=" + consoleError);
-        }
-    };
-
-    /** An empty application for testing. */
-    public static class TestApplication extends ApplicationBuilder {
-        @Override
-        protected void doBuild() {
-            // Empty, for testing
-        }
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/src/test/java/org/apache/brooklyn/cli/CliIntegrationTest.java
----------------------------------------------------------------------
diff --git a/usage/dist/src/test/java/org/apache/brooklyn/cli/CliIntegrationTest.java b/usage/dist/src/test/java/org/apache/brooklyn/cli/CliIntegrationTest.java
deleted file mode 100644
index adf9559..0000000
--- a/usage/dist/src/test/java/org/apache/brooklyn/cli/CliIntegrationTest.java
+++ /dev/null
@@ -1,219 +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.brooklyn.cli;
-
-import org.testng.annotations.Test;
-
-/**
- * Test the command line interface operation.
- */
-public class CliIntegrationTest extends BaseCliIntegrationTest {
-
-    /**
-     * Checks if running {@code brooklyn help} produces the expected output.
-     */
-    @Test(groups = {"Integration","Broken"})
-    public void testLaunchCliHelp() throws Throwable {
-        final Process brooklyn = startBrooklyn("help");
-
-        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
-            @Override
-            public void checkConsole() {
-                assertConsoleOutput("usage: brooklyn"); // Usage info not present
-                assertConsoleOutput("The most commonly used brooklyn commands are:");
-                assertConsoleOutput("help     Display help for available commands",
-                                    "info     Display information about brooklyn",
-                                    "launch   Starts a brooklyn application"); // List of common commands not present
-                assertConsoleOutput("See 'brooklyn help <command>' for more information on a specific command.");
-                assertConsoleErrorEmpty();
-            }
-        };
-
-        testBrooklyn(brooklyn, test, 0);
-    }
-
-    /*
-        Exception java.io.IOException
-        
-        Message: Cannot run program "./target/brooklyn-dist/bin/brooklyn": error=2, No such file or directory
-        Stacktrace:
-        
-        
-        at java.lang.ProcessBuilder.start(ProcessBuilder.java:1047)
-        at org.apache.brooklyn.cli.BaseCliIntegrationTest.startBrooklyn(BaseCliIntegrationTest.java:75)
-        at org.apache.brooklyn.cli.CliIntegrationTest.testLaunchCliApp(CliIntegrationTest.java:56)
-        at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
-        at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:57)
-        at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
-        at java.lang.reflect.Method.invoke(Method.java:606)
-        at org.testng.internal.MethodInvocationHelper.invokeMethod(MethodInvocationHelper.java:84)
-        at org.testng.internal.Invoker.invokeMethod(Invoker.java:714)
-        at org.testng.internal.Invoker.invokeTestMethod(Invoker.java:901)
-        at org.testng.internal.Invoker.invokeTestMethods(Invoker.java:1231)
-        at org.testng.internal.TestMethodWorker.invokeTestMethods(TestMethodWorker.java:127)
-        at org.testng.internal.TestMethodWorker.run(TestMethodWorker.java:111)
-        at org.testng.TestRunner.privateRun(TestRunner.java:767)
-        at org.testng.TestRunner.run(TestRunner.java:617)
-        at org.testng.SuiteRunner.runTest(SuiteRunner.java:348)
-        at org.testng.SuiteRunner.runSequentially(SuiteRunner.java:343)
-        at org.testng.SuiteRunner.privateRun(SuiteRunner.java:305)
-        at org.testng.SuiteRunner.run(SuiteRunner.java:254)
-        at org.testng.SuiteRunnerWorker.runSuite(SuiteRunnerWorker.java:52)
-        at org.testng.SuiteRunnerWorker.run(SuiteRunnerWorker.java:86)
-        at org.testng.TestNG.runSuitesSequentially(TestNG.java:1224)
-        at org.testng.TestNG.runSuitesLocally(TestNG.java:1149)
-        at org.testng.TestNG.run(TestNG.java:1057)
-        at org.apache.maven.surefire.testng.TestNGExecutor.run(TestNGExecutor.java:115)
-        at org.apache.maven.surefire.testng.TestNGDirectoryTestSuite.executeMulti(TestNGDirectoryTestSuite.java:205)
-        at org.apache.maven.surefire.testng.TestNGDirectoryTestSuite.execute(TestNGDirectoryTestSuite.java:108)
-        at org.apache.maven.surefire.testng.TestNGProvider.invoke(TestNGProvider.java:111)
-        at org.apache.maven.surefire.booter.ForkedBooter.invokeProviderInSameClassLoader(ForkedBooter.java:203)
-        at org.apache.maven.surefire.booter.ForkedBooter.runSuitesInProcess(ForkedBooter.java:155)
-        at org.apache.maven.surefire.booter.ForkedBooter.main(ForkedBooter.java:103)
-        Caused by: java.io.IOException: error=2, No such file or directory
-        at java.lang.UNIXProcess.forkAndExec(Native Method)
-        at java.lang.UNIXProcess.<init>(UNIXProcess.java:186)
-        at java.lang.ProcessImpl.start(ProcessImpl.java:130)
-        at java.lang.ProcessBuilder.start(ProcessBuilder.java:1028)
-        ... 30 more
-     */
-    /**
-     * Checks if launching an application using {@code brooklyn launch} produces the expected output.
-     */
-    @Test(groups = {"Integration","Broken"})
-    public void testLaunchCliApp() throws Throwable {
-        final Process brooklyn = startBrooklyn("--verbose", "launch", "--stopOnKeyPress", "--app", "org.apache.brooklyn.cli.BaseCliIntegrationTest$TestApplication", "--location", "localhost", "--noConsole");
-
-        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
-            @Override
-            public void checkConsole() {
-                assertConsoleOutput("Launching brooklyn app:"); // Launch message not output
-                assertNoConsoleOutput("Initiating Jersey application"); // Web console started
-                assertConsoleOutput("Started application BasicApplicationImpl"); // Application not started
-                assertConsoleOutput("Server started. Press return to stop."); // Server started message not output
-                assertConsoleErrorEmpty();
-            }
-        };
-
-        testBrooklyn(brooklyn, test, 0, true);
-    }
-
-    /**
-     * Checks if a correct error and help message is given if using incorrect param.
-     */
-    @Test(groups = {"Integration","Broken"})
-    public void testLaunchCliAppParamError() throws Throwable {
-        final Process brooklyn = startBrooklyn("launch", "nothing", "--app");
-
-        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
-            @Override
-            public void checkConsole() {
-                assertConsoleError("Parse error: Required values for option 'application class or file' not provided");
-                assertConsoleError("NAME", "SYNOPSIS", "OPTIONS", "COMMANDS");
-                assertConsoleOutputEmpty();
-            }
-        };
-
-        testBrooklyn(brooklyn, test, 1);
-    }
-
-    /*
-        Exception java.io.IOException
-        
-        Message: Cannot run program "./target/brooklyn-dist/bin/brooklyn": error=2, No such file or directory
-        Stacktrace:
-        
-        
-        at java.lang.ProcessBuilder.start(ProcessBuilder.java:1047)
-        at org.apache.brooklyn.cli.BaseCliIntegrationTest.startBrooklyn(BaseCliIntegrationTest.java:75)
-        at org.apache.brooklyn.cli.CliIntegrationTest.testLaunchCliAppCommandError(CliIntegrationTest.java:96)
-        at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
-        at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:57)
-        at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
-        at java.lang.reflect.Method.invoke(Method.java:606)
-        at org.testng.internal.MethodInvocationHelper.invokeMethod(MethodInvocationHelper.java:84)
-        at org.testng.internal.Invoker.invokeMethod(Invoker.java:714)
-        at org.testng.internal.Invoker.invokeTestMethod(Invoker.java:901)
-        at org.testng.internal.Invoker.invokeTestMethods(Invoker.java:1231)
-        at org.testng.internal.TestMethodWorker.invokeTestMethods(TestMethodWorker.java:127)
-        at org.testng.internal.TestMethodWorker.run(TestMethodWorker.java:111)
-        at org.testng.TestRunner.privateRun(TestRunner.java:767)
-        at org.testng.TestRunner.run(TestRunner.java:617)
-        at org.testng.SuiteRunner.runTest(SuiteRunner.java:348)
-        at org.testng.SuiteRunner.runSequentially(SuiteRunner.java:343)
-        at org.testng.SuiteRunner.privateRun(SuiteRunner.java:305)
-        at org.testng.SuiteRunner.run(SuiteRunner.java:254)
-        at org.testng.SuiteRunnerWorker.runSuite(SuiteRunnerWorker.java:52)
-        at org.testng.SuiteRunnerWorker.run(SuiteRunnerWorker.java:86)
-        at org.testng.TestNG.runSuitesSequentially(TestNG.java:1224)
-        at org.testng.TestNG.runSuitesLocally(TestNG.java:1149)
-        at org.testng.TestNG.run(TestNG.java:1057)
-        at org.apache.maven.surefire.testng.TestNGExecutor.run(TestNGExecutor.java:115)
-        at org.apache.maven.surefire.testng.TestNGDirectoryTestSuite.executeMulti(TestNGDirectoryTestSuite.java:205)
-        at org.apache.maven.surefire.testng.TestNGDirectoryTestSuite.execute(TestNGDirectoryTestSuite.java:108)
-        at org.apache.maven.surefire.testng.TestNGProvider.invoke(TestNGProvider.java:111)
-        at org.apache.maven.surefire.booter.ForkedBooter.invokeProviderInSameClassLoader(ForkedBooter.java:203)
-        at org.apache.maven.surefire.booter.ForkedBooter.runSuitesInProcess(ForkedBooter.java:155)
-        at org.apache.maven.surefire.booter.ForkedBooter.main(ForkedBooter.java:103)
-        Caused by: java.io.IOException: error=2, No such file or directory
-        at java.lang.UNIXProcess.forkAndExec(Native Method)
-        at java.lang.UNIXProcess.<init>(UNIXProcess.java:186)
-        at java.lang.ProcessImpl.start(ProcessImpl.java:130)
-        at java.lang.ProcessBuilder.start(ProcessBuilder.java:1028)
-        ... 30 more
-     */
-    /**
-     * Checks if a correct error and help message is given if using incorrect command.
-     */
-    @Test(groups = "Integration")
-    public void testLaunchCliAppCommandError() throws Throwable {
-        final Process brooklyn = startBrooklyn("biscuit");
-
-        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
-            @Override
-            public void checkConsole() {
-                assertConsoleError("Parse error: No command specified");
-                assertConsoleError("NAME", "SYNOPSIS", "OPTIONS", "COMMANDS");
-                assertConsoleOutputEmpty();
-            }
-        };
-
-        testBrooklyn(brooklyn, test, 1);
-    }
-
-    /**
-     * Checks if a correct error and help message is given if using incorrect application.
-     */
-    @Test(groups = {"Integration","Broken"})
-    public void testLaunchCliAppLaunchError() throws Throwable {
-        final String app = "org.eample.DoesNotExist";
-        final Process brooklyn = startBrooklyn("launch", "--app", app, "--location", "nowhere");
-
-        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
-            @Override
-            public void checkConsole() {
-                assertConsoleOutput(app, "not found");
-                assertConsoleError("ERROR", "Fatal", "getting resource", app);
-            }
-        };
-
-        testBrooklyn(brooklyn, test, 2);
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/downstream-parent/pom.xml
----------------------------------------------------------------------
diff --git a/usage/downstream-parent/pom.xml b/usage/downstream-parent/pom.xml
deleted file mode 100644
index 6580281..0000000
--- a/usage/downstream-parent/pom.xml
+++ /dev/null
@@ -1,506 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-  <modelVersion>4.0.0</modelVersion>
-
-  <parent>
-    <groupId>org.apache.brooklyn</groupId>
-    <artifactId>brooklyn</artifactId>
-    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-    <relativePath>../../pom.xml</relativePath>
-  </parent>
-
-  <artifactId>brooklyn-downstream-parent</artifactId>
-  <packaging>pom</packaging>
-  <name>Brooklyn Downstream Project Parent</name>
-  <description>
-      Parent pom that can be used by downstream projects that use Brooklyn,
-      or that contribute additional functionality to Brooklyn.
-  </description>
-
-  <properties>
-    <!-- Compilation -->
-    <java.version>1.7</java.version>
-    <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>
-    <project.reporting.outputEncoding>UTF-8</project.reporting.outputEncoding>
-
-    <!-- Testing -->
-    <testng.version>6.8.8</testng.version>
-    <surefire.version>2.18.1</surefire.version>
-    <includedTestGroups />
-    <excludedTestGroups>Integration,Acceptance,Live,Live-sanity,WIP</excludedTestGroups>
-
-    <!-- Dependencies -->
-    <brooklyn.version>0.9.0-SNAPSHOT</brooklyn.version>  <!-- BROOKLYN_VERSION -->
-    <jclouds.groupId>org.apache.jclouds</jclouds.groupId> <!-- JCLOUDS_GROUPID_VERSION -->
-
-    <!-- versions should match those used by Brooklyn, to avoid conflicts -->
-    <jclouds.version>1.9.1</jclouds.version> <!-- JCLOUDS_VERSION -->
-    <logback.version>1.0.7</logback.version>
-    <slf4j.version>1.6.6</slf4j.version>  <!-- used for java.util.logging jul-to-slf4j interception -->
-    <guava.version>17.0</guava.version>
-    <xstream.version>1.4.7</xstream.version>
-    <jackson.version>1.9.13</jackson.version>  <!-- codehaus jackson, used by brooklyn rest server -->
-    <fasterxml.jackson.version>2.4.5</fasterxml.jackson.version>  <!-- more recent jackson, but not compatible with old annotations! -->
-    <jersey.version>1.19</jersey.version>
-    <httpclient.version>4.4.1</httpclient.version>
-    <commons-lang3.version>3.1</commons-lang3.version>
-    <groovy.version>2.3.7</groovy.version> <!-- Version supported by https://github.com/groovy/groovy-eclipse/wiki/Groovy-Eclipse-2.9.1-Release-Notes -->
-    <jsr305.version>2.0.1</jsr305.version>
-    <snakeyaml.version>1.11</snakeyaml.version>
-  </properties>
-
-  <dependencyManagement>
-    <dependencies>
-      <dependency>
-        <!-- this would pull in all brooklyn entities and clouds;
-             you can cherry pick selected ones instead (for a smaller build) -->
-        <groupId>org.apache.brooklyn</groupId>
-        <artifactId>brooklyn-all</artifactId>
-        <version>${brooklyn.version}</version>
-      </dependency>
-    </dependencies>
-  </dependencyManagement>
-
-  <dependencies>
-    <dependency>
-      <!-- this gives us flexible and easy-to-use logging; just edit logback-custom.xml! -->
-      <groupId>org.apache.brooklyn</groupId>
-      <artifactId>brooklyn-logback-xml</artifactId>
-      <version>${brooklyn.version}</version>
-      <!-- optional so that this project has logging; dependencies may redeclare or supply their own;
-           provided so that it isn't put into the assembly (as it supplies its own explicit logback.xml);
-           see Logging in the Brooklyn website/userguide for more info -->
-      <optional>true</optional>
-      <scope>provided</scope>
-    </dependency>
-    <dependency>
-      <!-- includes testng and useful logging for tests -->
-      <groupId>org.apache.brooklyn</groupId>
-      <artifactId>brooklyn-test-support</artifactId>
-      <version>${brooklyn.version}</version>
-      <scope>test</scope>
-    </dependency>
-    <dependency>
-      <!-- includes org.apache.brooklyn.test.support.LoggingVerboseReporter -->
-      <groupId>org.apache.brooklyn</groupId>
-      <artifactId>brooklyn-utils-test-support</artifactId>
-      <version>${brooklyn.version}</version>
-      <scope>test</scope>
-    </dependency>
-  </dependencies>
-
-  <build>
-    <testSourceDirectory>src/test/java</testSourceDirectory>
-    <testResources>
-      <testResource>
-        <directory>src/test/resources</directory>
-      </testResource>
-    </testResources>
-
-    <pluginManagement>
-      <plugins>
-        <plugin>
-          <artifactId>maven-assembly-plugin</artifactId>
-          <version>2.5.4</version>
-          <configuration>
-            <tarLongFileMode>gnu</tarLongFileMode>
-          </configuration>
-        </plugin>
-        <plugin>
-          <artifactId>maven-clean-plugin</artifactId>
-          <version>2.6.1</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-compiler-plugin</artifactId>
-          <version>3.3</version>
-          <configuration>
-            <source>${java.version}</source>
-            <target>${java.version}</target>
-          </configuration>
-        </plugin>
-        <plugin>
-          <artifactId>maven-deploy-plugin</artifactId>
-          <version>2.8.2</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-eclipse-plugin</artifactId>
-          <version>2.10</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-enforcer-plugin</artifactId>
-          <version>1.4</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-failsafe-plugin</artifactId>
-          <version>2.18.1</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-gpg-plugin</artifactId>
-          <version>1.6</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-jar-plugin</artifactId>
-          <version>2.6</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-javadoc-plugin</artifactId>
-          <version>2.10.3</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-resources-plugin</artifactId>
-          <version>2.7</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-source-plugin</artifactId>
-          <version>2.4</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-surefire-plugin</artifactId>
-          <version>2.18.1</version>
-        </plugin>
-        <plugin>
-          <groupId>org.apache.felix</groupId>
-          <artifactId>maven-bundle-plugin</artifactId>
-          <version>2.3.4</version>
-        </plugin>
-        <!--This plugin's configuration is used to store Eclipse m2e settings only. It has no influence on the Maven build itself.-->
-        <plugin>
-          <groupId>org.eclipse.m2e</groupId>
-          <artifactId>lifecycle-mapping</artifactId>
-          <version>1.0.0</version>
-          <configuration>
-            <lifecycleMappingMetadata>
-              <pluginExecutions>
-                <pluginExecution>
-                  <pluginExecutionFilter>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-assembly-plugin</artifactId>
-                    <versionRange>[2.4.1,)</versionRange>
-                    <goals>
-                      <goal>single</goal>
-                    </goals>
-                  </pluginExecutionFilter>
-                  <action>
-                    <ignore />
-                  </action>
-                </pluginExecution>
-                <pluginExecution>
-                  <pluginExecutionFilter>
-                    <groupId>org.codehaus.mojo</groupId>
-                    <artifactId>build-helper-maven-plugin</artifactId>
-                    <versionRange>[1.7,)</versionRange>
-                    <goals>
-                      <goal>attach-artifact</goal>
-                    </goals>
-                  </pluginExecutionFilter>
-                  <action>
-                    <ignore />
-                  </action>
-                </pluginExecution>
-                <pluginExecution>
-                  <pluginExecutionFilter>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-enforcer-plugin</artifactId>
-                    <versionRange>[1.3.1,)</versionRange>
-                    <goals>
-                      <goal>enforce</goal>
-                    </goals>
-                  </pluginExecutionFilter>
-                  <action>
-                    <ignore />
-                  </action>
-                </pluginExecution>
-                <pluginExecution>
-                  <pluginExecutionFilter>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-remote-resources-plugin</artifactId>
-                    <versionRange>[1.5,)</versionRange>
-                    <goals>
-                      <goal>process</goal>
-                    </goals>
-                  </pluginExecutionFilter>
-                  <action>
-                    <ignore />
-                  </action>
-                </pluginExecution>
-                <pluginExecution>
-                  <pluginExecutionFilter>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-dependency-plugin</artifactId>
-                    <versionRange>[2.8,)</versionRange>
-                    <goals>
-                      <goal>unpack</goal>
-                      <goal>copy</goal>
-                    </goals>
-                  </pluginExecutionFilter>
-                  <action>
-                    <ignore />
-                  </action>
-                </pluginExecution>
-                <pluginExecution>
-                  <pluginExecutionFilter>
-                    <groupId>com.github.skwakman.nodejs-maven-plugin</groupId>
-                    <artifactId>nodejs-maven-plugin</artifactId>
-                    <versionRange>[1.0.3,)</versionRange>
-                    <goals>
-                      <goal>extract</goal>
-                    </goals>
-                  </pluginExecutionFilter>
-                  <action>
-                    <ignore />
-                  </action>
-                </pluginExecution>
-                <pluginExecution>
-                  <pluginExecutionFilter>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-war-plugin</artifactId>
-                    <versionRange>[2.4,)</versionRange>
-                    <goals>
-                      <goal>exploded</goal>
-                    </goals>
-                  </pluginExecutionFilter>
-                  <action>
-                    <ignore />
-                  </action>
-                </pluginExecution>
-              </pluginExecutions>
-             </lifecycleMappingMetadata>
-           </configuration>
-        </plugin>
-      </plugins>
-    </pluginManagement>
-
-    <plugins>
-      <plugin>
-        <artifactId>maven-clean-plugin</artifactId>
-        <configuration>
-          <filesets>
-            <fileset>
-              <directory>.</directory>
-              <includes>
-                <include>brooklyn*.log</include>
-                <include>brooklyn*.log.*</include>
-                <include>stacktrace.log</include>
-                <include>test-output</include>
-                <include>prodDb.*</include>
-              </includes>
-            </fileset>
-          </filesets>
-        </configuration>
-      </plugin>
-
-      <plugin>
-        <artifactId>maven-resources-plugin</artifactId>
-      </plugin>
-
-      <plugin>
-        <artifactId>maven-eclipse-plugin</artifactId>
-        <configuration>
-          <additionalProjectnatures>
-            <projectnature>org.maven.ide.eclipse.maven2Nature</projectnature>
-          </additionalProjectnatures>
-        </configuration>
-      </plugin>
-
-      <plugin>
-        <artifactId>maven-surefire-plugin</artifactId>
-        <configuration>
-          <argLine>-Xms256m -Xmx512m -XX:MaxPermSize=512m</argLine>
-          <properties>
-            <property>
-              <name>listener</name>
-              <value>org.apache.brooklyn.test.support.LoggingVerboseReporter</value>
-            </property>
-          </properties>
-          <enableAssertions>true</enableAssertions>
-          <groups>${includedTestGroups}</groups>
-          <excludedGroups>${excludedTestGroups}</excludedGroups>
-          <testFailureIgnore>false</testFailureIgnore>
-          <systemPropertyVariables>
-            <verbose>-1</verbose>
-            <net.sourceforge.cobertura.datafile>${project.build.directory}/cobertura/cobertura.ser</net.sourceforge.cobertura.datafile>
-            <cobertura.user.java.nio>false</cobertura.user.java.nio>
-          </systemPropertyVariables>
-          <printSummary>true</printSummary>
-        </configuration>
-      </plugin>
-    </plugins>
-  </build>
-
-  <profiles>
-
-    <profile>
-      <id>Tests</id>
-      <activation>
-        <file> <exists>${basedir}/src/test</exists> </file>
-      </activation>
-      <build>
-        <plugins>
-          <plugin>
-            <artifactId>maven-jar-plugin</artifactId>
-            <inherited>true</inherited>
-            <executions>
-              <execution>
-                <id>test-jar-creation</id>
-                <goals>
-                  <goal>test-jar</goal>
-                </goals>
-                <configuration>
-                  <forceCreation>true</forceCreation>
-                  <archive combine.self="override" />
-                </configuration>
-              </execution>
-            </executions>
-          </plugin>
-        </plugins>
-      </build>
-    </profile>
-
-    <!-- run Integration tests with -PIntegration -->
-    <profile>
-      <id>Integration</id>
-      <properties>
-        <includedTestGroups>Integration</includedTestGroups>
-        <excludedTestGroups>Acceptance,Live,Live-sanity,WIP</excludedTestGroups>
-      </properties>
-    </profile>
-
-    <!-- run Live tests with -PLive -->
-    <profile>
-      <id>Live</id>
-      <properties>
-        <includedTestGroups>Live,Live-sanity</includedTestGroups>
-        <excludedTestGroups>Acceptance,WIP</excludedTestGroups>
-      </properties>
-    </profile>
-
-    <!-- run Live-sanity tests with -PLive-sanity -->
-    <profile>
-      <id>Live-sanity</id>
-      <properties>
-        <includedTestGroups>Live-sanity</includedTestGroups>
-        <excludedTestGroups>Acceptance,WIP</excludedTestGroups>
-      </properties>
-      <build>
-        <plugins>
-          <plugin>
-            <artifactId>maven-jar-plugin</artifactId>
-            <executions>
-              <execution>
-                <id>test-jar-creation</id>
-                <configuration>
-                  <skip>true</skip>
-                </configuration>
-              </execution>
-            </executions>
-          </plugin>
-        </plugins>
-      </build>
-    </profile>
-
-    <profile>
-      <id>Bundle</id>
-      <activation>
-        <file>
-          <!-- NB - this is all the leaf projects, including logback-* (with no src);
-               the archetype project neatly ignores this however -->
-          <exists>${basedir}/src</exists>
-        </file>
-      </activation>
-      <build>
-        <plugins>
-          <plugin>
-            <groupId>org.apache.felix</groupId>
-            <artifactId>maven-bundle-plugin</artifactId>
-            <extensions>true</extensions>
-            <!-- configure plugin to generate MANIFEST.MF
-                 adapted from http://blog.knowhowlab.org/2010/06/osgi-tutorial-from-project-structure-to.html -->
-            <executions>
-              <execution>
-                <id>bundle-manifest</id>
-                <phase>process-classes</phase>
-                <goals>
-                  <goal>manifest</goal>
-                </goals>
-              </execution>
-            </executions>
-            <configuration>
-              <supportedProjectTypes>
-                <supportedProjectType>jar</supportedProjectType>
-              </supportedProjectTypes>
-              <instructions>
-                <!-- OSGi specific instruction -->
-                <!--
-                    By default packages containing impl and internal
-                    are not included in the export list. Setting an
-                    explicit wildcard will include all packages
-                    regardless of name.
-                    In time we should minimize our export lists to
-                    what is really needed.
-                -->
-                <Export-Package>brooklyn.*,org.apache.brooklyn.*</Export-Package>
-                <!-- Brooklyn-Feature prefix triggers inclusion of the project's metadata in the server's features list. -->
-                <Brooklyn-Feature-Name>${project.name}</Brooklyn-Feature-Name>
-              </instructions>
-            </configuration>
-          </plugin>
-          <plugin>
-            <groupId>org.apache.maven.plugins</groupId>
-            <artifactId>maven-jar-plugin</artifactId>
-            <configuration>
-              <archive>
-                <manifestFile>${project.build.outputDirectory}/META-INF/MANIFEST.MF</manifestFile>
-              </archive>
-            </configuration>
-          </plugin>
-        </plugins>
-      </build>
-    </profile>
-
-    <!-- different properties used to deploy to different locations depending on profiles;
-         default is cloudsoft filesystem repo, but some sources still use cloudsoft artifactory as source
-         and soon we will support artifactory. use this profile for the ASF repositories and
-         sonatype-oss-release profile for the Sonatype OSS repositories.
-    -->
-    <!-- profile>
-      <id>apache-release</id>
-      <activation>
-        <property>
-          <name>brooklyn.deployTo</name>
-          <value>apache</value>
-        </property>
-      </activation>
-      <distributionManagement>
-        <repository>
-          <id>apache.releases.https</id>
-          <name>Apache Release Distribution Repository</name>
-          <url>https://repository.apache.org/service/local/staging/deploy/maven2</url>
-        </repository>
-        <snapshotRepository>
-          <id>apache.snapshots.https</id>
-          <name>Apache Development Snapshot Repository</name>
-          <url>https://repository.apache.org/content/repositories/snapshots</url>
-        </snapshotRepository>
-      </distributionManagement>
-    </profile -->
-  </profiles>
-
-</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/jsgui/src/main/license/files/LICENSE
----------------------------------------------------------------------
diff --git a/usage/jsgui/src/main/license/files/LICENSE b/usage/jsgui/src/main/license/files/LICENSE
deleted file mode 100644
index 4a1f38b..0000000
--- a/usage/jsgui/src/main/license/files/LICENSE
+++ /dev/null
@@ -1,482 +0,0 @@
-
-This software is distributed under the Apache License, version 2.0. See (1) below.
-This software is copyright (c) The Apache Software Foundation and contributors.
-
-Contents:
-
-  (1) This software license: Apache License, version 2.0
-  (2) Notices for bundled software
-  (3) Licenses for bundled software
-
-
----------------------------------------------------
-
-(1) This software license: Apache License, version 2.0
-
-
-                                 Apache License
-                           Version 2.0, January 2004
-                        http://www.apache.org/licenses/
-
-   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
-
-   1. Definitions.
-
-      "License" shall mean the terms and conditions for use, reproduction,
-      and distribution as defined by Sections 1 through 9 of this document.
-
-      "Licensor" shall mean the copyright owner or entity authorized by
-      the copyright owner that is granting the License.
-
-      "Legal Entity" shall mean the union of the acting entity and all
-      other entities that control, are controlled by, or are under common
-      control with that entity. For the purposes of this definition,
-      "control" means (i) the power, direct or indirect, to cause the
-      direction or management of such entity, whether by contract or
-      otherwise, or (ii) ownership of fifty percent (50%) or more of the
-      outstanding shares, or (iii) beneficial ownership of such entity.
-
-      "You" (or "Your") shall mean an individual or Legal Entity
-      exercising permissions granted by this License.
-
-      "Source" form shall mean the preferred form for making modifications,
-      including but not limited to software source code, documentation
-      source, and configuration files.
-
-      "Object" form shall mean any form resulting from mechanical
-      transformation or translation of a Source form, including but
-      not limited to compiled object code, generated documentation,
-      and conversions to other media types.
-
-      "Work" shall mean the work of authorship, whether in Source or
-      Object form, made available under the License, as indicated by a
-      copyright notice that is included in or attached to the work
-      (an example is provided in the Appendix below).
-
-      "Derivative Works" shall mean any work, whether in Source or Object
-      form, that is based on (or derived from) the Work and for which the
-      editorial revisions, annotations, elaborations, or other modifications
-      represent, as a whole, an original work of authorship. For the purposes
-      of this License, Derivative Works shall not include works that remain
-      separable from, or merely link (or bind by name) to the interfaces of,
-      the Work and Derivative Works thereof.
-
-      "Contribution" shall mean any work of authorship, including
-      the original version of the Work and any modifications or additions
-      to that Work or Derivative Works thereof, that is intentionally
-      submitted to Licensor for inclusion in the Work by the copyright owner
-      or by an individual or Legal Entity authorized to submit on behalf of
-      the copyright owner. For the purposes of this definition, "submitted"
-      means any form of electronic, verbal, or written communication sent
-      to the Licensor or its representatives, including but not limited to
-      communication on electronic mailing lists, source code control systems,
-      and issue tracking systems that are managed by, or on behalf of, the
-      Licensor for the purpose of discussing and improving the Work, but
-      excluding communication that is conspicuously marked or otherwise
-      designated in writing by the copyright owner as "Not a Contribution."
-
-      "Contributor" shall mean Licensor and any individual or Legal Entity
-      on behalf of whom a Contribution has been received by Licensor and
-      subsequently incorporated within the Work.
-
-   2. Grant of Copyright License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      copyright license to reproduce, prepare Derivative Works of,
-      publicly display, publicly perform, sublicense, and distribute the
-      Work and such Derivative Works in Source or Object form.
-
-   3. Grant of Patent License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      (except as stated in this section) patent license to make, have made,
-      use, offer to sell, sell, import, and otherwise transfer the Work,
-      where such license applies only to those patent claims licensable
-      by such Contributor that are necessarily infringed by their
-      Contribution(s) alone or by combination of their Contribution(s)
-      with the Work to which such Contribution(s) was submitted. If You
-      institute patent litigation against any entity (including a
-      cross-claim or counterclaim in a lawsuit) alleging that the Work
-      or a Contribution incorporated within the Work constitutes direct
-      or contributory patent infringement, then any patent licenses
-      granted to You under this License for that Work shall terminate
-      as of the date such litigation is filed.
-
-   4. Redistribution. You may reproduce and distribute copies of the
-      Work or Derivative Works thereof in any medium, with or without
-      modifications, and in Source or Object form, provided that You
-      meet the following conditions:
-
-      (a) You must give any other recipients of the Work or
-          Derivative Works a copy of this License; and
-
-      (b) You must cause any modified files to carry prominent notices
-          stating that You changed the files; and
-
-      (c) You must retain, in the Source form of any Derivative Works
-          that You distribute, all copyright, patent, trademark, and
-          attribution notices from the Source form of the Work,
-          excluding those notices that do not pertain to any part of
-          the Derivative Works; and
-
-      (d) If the Work includes a "NOTICE" text file as part of its
-          distribution, then any Derivative Works that You distribute must
-          include a readable copy of the attribution notices contained
-          within such NOTICE file, excluding those notices that do not
-          pertain to any part of the Derivative Works, in at least one
-          of the following places: within a NOTICE text file distributed
-          as part of the Derivative Works; within the Source form or
-          documentation, if provided along with the Derivative Works; or,
-          within a display generated by the Derivative Works, if and
-          wherever such third-party notices normally appear. The contents
-          of the NOTICE file are for informational purposes only and
-          do not modify the License. You may add Your own attribution
-          notices within Derivative Works that You distribute, alongside
-          or as an addendum to the NOTICE text from the Work, provided
-          that such additional attribution notices cannot be construed
-          as modifying the License.
-
-      You may add Your own copyright statement to Your modifications and
-      may provide additional or different license terms and conditions
-      for use, reproduction, or distribution of Your modifications, or
-      for any such Derivative Works as a whole, provided Your use,
-      reproduction, and distribution of the Work otherwise complies with
-      the conditions stated in this License.
-
-   5. Submission of Contributions. Unless You explicitly state otherwise,
-      any Contribution intentionally submitted for inclusion in the Work
-      by You to the Licensor shall be under the terms and conditions of
-      this License, without any additional terms or conditions.
-      Notwithstanding the above, nothing herein shall supersede or modify
-      the terms of any separate license agreement you may have executed
-      with Licensor regarding such Contributions.
-
-   6. Trademarks. This License does not grant permission to use the trade
-      names, trademarks, service marks, or product names of the Licensor,
-      except as required for reasonable and customary use in describing the
-      origin of the Work and reproducing the content of the NOTICE file.
-
-   7. Disclaimer of Warranty. Unless required by applicable law or
-      agreed to in writing, Licensor provides the Work (and each
-      Contributor provides its Contributions) on an "AS IS" BASIS,
-      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-      implied, including, without limitation, any warranties or conditions
-      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-      PARTICULAR PURPOSE. You are solely responsible for determining the
-      appropriateness of using or redistributing the Work and assume any
-      risks associated with Your exercise of permissions under this License.
-
-   8. Limitation of Liability. In no event and under no legal theory,
-      whether in tort (including negligence), contract, or otherwise,
-      unless required by applicable law (such as deliberate and grossly
-      negligent acts) or agreed to in writing, shall any Contributor be
-      liable to You for damages, including any direct, indirect, special,
-      incidental, or consequential damages of any character arising as a
-      result of this License or out of the use or inability to use the
-      Work (including but not limited to damages for loss of goodwill,
-      work stoppage, computer failure or malfunction, or any and all
-      other commercial damages or losses), even if such Contributor
-      has been advised of the possibility of such damages.
-
-   9. Accepting Warranty or Additional Liability. While redistributing
-      the Work or Derivative Works thereof, You may choose to offer,
-      and charge a fee for, acceptance of support, warranty, indemnity,
-      or other liability obligations and/or rights consistent with this
-      License. However, in accepting such obligations, You may act only
-      on Your own behalf and on Your sole responsibility, not on behalf
-      of any other Contributor, and only if You agree to indemnify,
-      defend, and hold each Contributor harmless for any liability
-      incurred by, or claims asserted against, such Contributor by reason
-      of your accepting any such warranty or additional liability.
-
-
----------------------------------------------------
-
-(2) Notices for bundled software
-
-This project includes the software: async.js
-  Available at: https://github.com/p15martin/google-maps-hello-world/blob/master/js/libs/async.js
-  Developed by: Miller Medeiros (https://github.com/millermedeiros/)
-  Version used: 0.1.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Miller Medeiros (2011)
-
-This project includes the software: backbone.js
-  Available at: http://backbonejs.org
-  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
-  Version used: 1.0.0
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2010-2013)
-
-This project includes the software: backbone.js
-  Available at: http://backbonejs.org
-  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
-  Version used: 1.1.2
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Jeremy Ashkenas, DocumentCloud (2010-2014)
-
-This project includes the software: bootstrap.js
-  Available at: http://twitter.github.com/bootstrap/javascript.html#transitions
-  Version used: 2.0.4
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-  Copyright (c) Twitter, Inc. (2012)
-
-This project includes the software: handlebars.js
-  Available at: https://github.com/wycats/handlebars.js
-  Developed by: Yehuda Katz (https://github.com/wycats/)
-  Inclusive of: handlebars*.js
-  Version used: 1.0-rc1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Yehuda Katz (2012)
-
-This project includes the software: handlebars.js
-  Available at: https://github.com/wycats/handlebars.js
-  Developed by: Yehuda Katz (https://github.com/wycats/)
-  Inclusive of: handlebars*.js
-  Version used: 2.0.0
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (C) by Yehuda Katz (2011-2014)
-
-This project includes the software: jQuery JavaScript Library
-  Available at: http://jquery.com/
-  Developed by: The jQuery Foundation (http://jquery.org/)
-  Inclusive of: jquery.js
-  Version used: 1.7.2
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) John Resig (2005-2011)
-  Includes code fragments from sizzle.js:
-    Copyright (c) The Dojo Foundation
-    Available at http://sizzlejs.com
-    Used under the MIT license
-
-This project includes the software: jQuery JavaScript Library
-  Available at: http://jquery.com/
-  Developed by: The jQuery Foundation (http://jquery.org/)
-  Inclusive of: jquery.js
-  Version used: 1.8.0
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) jQuery Foundation and other contributors (2012)
-  Includes code fragments from sizzle.js:
-    Copyright (c) The Dojo Foundation
-    Available at http://sizzlejs.com
-    Used under the MIT license
-
-This project includes the software: jQuery BBQ: Back Button & Query Library
-  Available at: http://benalman.com/projects/jquery-bbq-plugin/
-  Developed by: "Cowboy" Ben Alman (http://benalman.com/)
-  Inclusive of: jquery.ba-bbq*.js
-  Version used: 1.2.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) "Cowboy" Ben Alman (2010)"
-
-This project includes the software: DataTables Table plug-in for jQuery
-  Available at: http://www.datatables.net/
-  Developed by: SpryMedia Ltd (http://sprymedia.co.uk/)
-  Inclusive of: jquery.dataTables.{js,css}
-  Version used: 1.9.4
-  Used under the following license: The BSD 3-Clause (New BSD) License (http://opensource.org/licenses/BSD-3-Clause)
-  Copyright (c) Allan Jardine (2008-2012)
-
-This project includes the software: jQuery Form Plugin
-  Available at: https://github.com/malsup/form
-  Developed by: Mike Alsup (http://malsup.com/)
-  Inclusive of: jquery.form.js
-  Version used: 3.09
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) M. Alsup (2006-2013)
-
-This project includes the software: jQuery Wiggle
-  Available at: https://github.com/jordanthomas/jquery-wiggle
-  Inclusive of: jquery.wiggle.min.js
-  Version used: swagger-ui:1.0.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) WonderGroup and Jordan Thomas (2010)
-  Previously online at http://labs.wondergroup.com/demos/mini-ui/index.html.
-  The version included here is from the Swagger UI distribution.
-
-This project includes the software: js-uri
-  Available at: http://code.google.com/p/js-uri/
-  Developed by: js-uri contributors (https://code.google.com/js-uri)
-  Inclusive of: URI.js
-  Version used: 0.1
-  Used under the following license: The BSD 3-Clause (New BSD) License (http://opensource.org/licenses/BSD-3-Clause)
-  Copyright (c) js-uri contributors (2013)
-
-This project includes the software: js-yaml.js
-  Available at: https://github.com/nodeca/
-  Developed by: Vitaly Puzrin (https://github.com/nodeca/)
-  Version used: 3.2.7
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Vitaly Puzrin (2011-2015)
-
-This project includes the software: moment.js
-  Available at: http://momentjs.com
-  Developed by: Tim Wood (http://momentjs.com)
-  Version used: 2.1.0
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Tim Wood, Iskren Chernev, Moment.js contributors (2011-2014)
-
-This project includes the software: RequireJS
-  Available at: http://requirejs.org/
-  Developed by: The Dojo Foundation (http://dojofoundation.org/)
-  Inclusive of: require.js, text.js
-  Version used: 2.0.6
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) The Dojo Foundation (2010-2012)
-
-This project includes the software: RequireJS (r.js maven plugin)
-  Available at: http://github.com/jrburke/requirejs
-  Developed by: The Dojo Foundation (http://dojofoundation.org/)
-  Inclusive of: r.js
-  Version used: 2.1.6
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) The Dojo Foundation (2009-2013)
-  Includes code fragments for source-map and other functionality:
-    Copyright (c) The Mozilla Foundation and contributors (2011)
-    Used under the BSD 2-Clause license.
-  Includes code fragments for parse-js and other functionality:
-    Copyright (c) Mihai Bazon (2010, 2012)
-    Used under the BSD 2-Clause license.
-  Includes code fragments for uglifyjs/consolidator:
-    Copyright (c) Robert Gust-Bardon (2012)
-    Used under the BSD 2-Clause license.
-  Includes code fragments for the esprima parser:
-    Copyright (c):
-      Ariya Hidayat (2011, 2012)
-      Mathias Bynens (2012)
-      Joost-Wim Boekesteijn (2012)
-      Kris Kowal (2012)
-      Yusuke Suzuki (2012)
-      Arpad Borsos (2012)
-    Used under the BSD 2-Clause license.
-
-This project includes the software: Swagger JS
-  Available at: https://github.com/swagger-api/swagger-js
-  Inclusive of: swagger.js
-  Version used: 2.1.6
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-  Copyright (c) SmartBear Software (2015)
-
-This project includes the software: Swagger UI
-  Available at: https://github.com/swagger-api/swagger-ui
-  Inclusive of: swagger-ui.js
-  Version used: 2.1.3
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-  Copyright (c) SmartBear Software (2015)
-
-This project includes the software: underscore.js
-  Available at: http://underscorejs.org
-  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
-  Inclusive of: underscore*.{js,map}
-  Version used: 1.4.4
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2009-2013)
-
-This project includes the software: underscore.js
-  Available at: http://underscorejs.org
-  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
-  Inclusive of: underscore*.{js,map}
-  Version used: 1.7.0
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Jeremy Ashkenas, DocumentCloud and Investigative Reporters & Editors (2009-2014)
-
-This project includes the software: ZeroClipboard
-  Available at: http://zeroclipboard.org/
-  Developed by: ZeroClipboard contributors (https://github.com/zeroclipboard)
-  Inclusive of: ZeroClipboard.*
-  Version used: 1.3.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Jon Rohan, James M. Greene (2014)
-
-This project includes the software: marked.js
-  Available at: https://github.com/chjj/marked
-  Developed by: Christopher Jeffrey (https://github.com/chjj)
-  Inclusive of: marked.js
-  Version used: 0.3.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Christopher Jeffrey (2011-2014)
-
----------------------------------------------------
-
-(3) Licenses for bundled software
-
-Contents:
-
-  The BSD 2-Clause License
-  The BSD 3-Clause License ("New BSD")
-  The MIT License ("MIT")
-
-
-The BSD 2-Clause License
-
-  Redistribution and use in source and binary forms, with or without
-  modification, are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, this
-  list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice,
-  this list of conditions and the following disclaimer in the documentation
-  and/or other materials provided with the distribution.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
-  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
-  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
-  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
-  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
-  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
-  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
-  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
-  
-
-The BSD 3-Clause License ("New BSD")
-
-  Redistribution and use in source and binary forms, with or without modification,
-  are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, 
-  this list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice, 
-  this list of conditions and the following disclaimer in the documentation 
-  and/or other materials provided with the distribution.
-  
-  3. Neither the name of the copyright holder nor the names of its contributors 
-  may be used to endorse or promote products derived from this software without 
-  specific prior written permission.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
-  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
-  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
-  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
-  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
-  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
-  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
-  POSSIBILITY OF SUCH DAMAGE.
-  
-
-The MIT License ("MIT")
-
-  Permission is hereby granted, free of charge, to any person obtaining a copy
-  of this software and associated documentation files (the "Software"), to deal
-  in the Software without restriction, including without limitation the rights
-  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
-  copies of the Software, and to permit persons to whom the Software is
-  furnished to do so, subject to the following conditions:
-  
-  The above copyright notice and this permission notice shall be included in
-  all copies or substantial portions of the Software.
-  
-  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
-  THE SOFTWARE.
-  
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/jsgui/src/main/license/files/NOTICE
----------------------------------------------------------------------
diff --git a/usage/jsgui/src/main/license/files/NOTICE b/usage/jsgui/src/main/license/files/NOTICE
deleted file mode 100644
index f790f13..0000000
--- a/usage/jsgui/src/main/license/files/NOTICE
+++ /dev/null
@@ -1,5 +0,0 @@
-Apache Brooklyn
-Copyright 2014-2015 The Apache Software Foundation
-
-This product includes software developed at
-The Apache Software Foundation (http://www.apache.org/).

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/jsgui/src/test/license/DISCLAIMER
----------------------------------------------------------------------
diff --git a/usage/jsgui/src/test/license/DISCLAIMER b/usage/jsgui/src/test/license/DISCLAIMER
deleted file mode 100644
index 9e6119b..0000000
--- a/usage/jsgui/src/test/license/DISCLAIMER
+++ /dev/null
@@ -1,8 +0,0 @@
-
-Apache Brooklyn is an effort undergoing incubation at The Apache Software Foundation (ASF), 
-sponsored by the Apache Incubator. Incubation is required of all newly accepted projects until 
-a further review indicates that the infrastructure, communications, and decision making process 
-have stabilized in a manner consistent with other successful ASF projects. While incubation 
-status is not necessarily a reflection of the completeness or stability of the code, it does 
-indicate that the project has yet to be fully endorsed by the ASF.
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/jsgui/src/test/license/NOTICE
----------------------------------------------------------------------
diff --git a/usage/jsgui/src/test/license/NOTICE b/usage/jsgui/src/test/license/NOTICE
deleted file mode 100644
index f790f13..0000000
--- a/usage/jsgui/src/test/license/NOTICE
+++ /dev/null
@@ -1,5 +0,0 @@
-Apache Brooklyn
-Copyright 2014-2015 The Apache Software Foundation
-
-This product includes software developed at
-The Apache Software Foundation (http://www.apache.org/).

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/scripts/buildAndTest
----------------------------------------------------------------------
diff --git a/usage/scripts/buildAndTest b/usage/scripts/buildAndTest
deleted file mode 100755
index 45c1a26..0000000
--- a/usage/scripts/buildAndTest
+++ /dev/null
@@ -1,102 +0,0 @@
-#!/bin/bash
-#
-# 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.
-#
-# Convenience script to clean, build, install and run unit and/or integration tests.
-# Recommend you run this prior to pushing to Github to reduce the chances of breaking
-# the continuous integration (unit tests) or overnight builds (integration tests.)
-#
-# Also very useful when using "git bisect" to find out which commit was responsible
-# for breaking the overnight build - invoke as "git bisect run ./buildAndRun"
-#
-# Run "./buildAndRun --help" to see the usage.
-#
-
-# Has an integration test left a Java process running? See if there is any running
-# Java processes and offer to kill them/
-cleanup(){
-    PROCS=$(ps ax | grep '[j]ava' | grep -v set_tab_title)
-    if [ ! -z "${PROCS}" ]; then
-	echo "These Java processes are running:"
-	echo ${PROCS}
-	echo -n "Kill them? y=yes, n=no, x=abort: "
-	read $RESPONSE
-	[ "${RESPONSE}" = "y" ] && killall java && sleep 1s
-	[ "${RESPONSE}" = "x" ] && exit 50
-    fi
-}
-
-# Check a return value, and bail if its non-zero - invoke as "assert $? 'Unit tests'"
-assert(){
-    [ $1 -eq 0 ] && return
-    echo '*** Command returned '$1' on '$2
-    exit $1
-}
-
-# The defaults
-unit=1
-integration=1
-
-if [ ! -z "$1" ]; then
-    case "$1" in
-	u)
-	    unit=1
-	    integration=0
-	    ;;
-	i)
-	    unit=0
-	    integration=1
-	    ;;
-	ui)
-	    unit=1
-	    integration=1
-	    ;;
-	b)
-	    unit=0
-	    integration=0
-	    ;;
-	*)
-	    echo >&2 Usage: buildAndTest [action]
-	    echo >&2 where action is:
-	    echo >&2 u - build from clean and run unit tests
-	    echo >&2 i - build from clean and run integration tests
-	    echo >&2 ui - build from clean and run unit and integration tests \(default\)
-	    echo >&2 b - build from clean and do not run any tests
-	    exit 1
-	    ;;
-    esac
-fi
-
-echo '*** BUILD'
-mvn clean install -DskipTests -PConsole
-assert $? 'BUILD'
-cleanup
-if [ $unit -eq 1 ]; then
-    echo '*** UNIT TEST'
-    mvn integration-test -PConsole
-    assert $? 'UNIT TEST'
-    cleanup
-fi
-if [ $integration -eq 1 ]; then
-    echo '*** INTEGRATION TEST'
-    mvn integration-test -PConsole,Integration
-    assert $? 'INTEGRATION TEST'
-    cleanup
-fi
-
-exit 0

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/scripts/grep-in-poms.sh
----------------------------------------------------------------------
diff --git a/usage/scripts/grep-in-poms.sh b/usage/scripts/grep-in-poms.sh
deleted file mode 100755
index aca9258..0000000
--- a/usage/scripts/grep-in-poms.sh
+++ /dev/null
@@ -1,25 +0,0 @@
-#!/usr/bin/env bash
-#
-# 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.
-#
-
-# usage: run in the root dir of a project, it will grep in poms up to 3 levels deep
-# e.g. where are shaded jars defined?
-# brooklyn% grep-in-poms -i slf4j
-
-grep $* {.,*,*/*,*/*/*}/pom.xml

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/scripts/release-branch-from-master
----------------------------------------------------------------------
diff --git a/usage/scripts/release-branch-from-master b/usage/scripts/release-branch-from-master
deleted file mode 100755
index 8d7befa..0000000
--- a/usage/scripts/release-branch-from-master
+++ /dev/null
@@ -1,114 +0,0 @@
-#!/bin/bash -e
-#
-# 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.
-#
-
-usage(){
-	echo >&2 'Usage: release-branch-from-master --release <version> [ --release-suffix <suffix> ]'
-	echo >&2 '                                  --master <version>  [ --master-suffix <suffix> ]'
-	echo >&2 'Creates a release branch, and updates the version number in both the branch and master.'
-	echo >&2 '<version> should be a two-part version number, such as 3.6 or 4.0.'
-	echo >&2 '<suffix> will normally be of the form ".patchlevel", plus "-RC1" or similar if required,'
-	echo >&2 'plus "-SNAPSHOT". Example: ".0.RC1-SNAPSHOT". The defaults for the suffix are normally sensible.'
-	echo >&2 'This command will preview what it is going to do and require confirmation before it makes changes.'
-}
-
-release_ver=
-release_ver_suffix=.0-RC1-SNAPSHOT
-master_ver=
-master_ver_suffix=.0-SNAPSHOT
-
-[ $# -eq 0 ] && echo >&2 "No arguments given, so I'm going to try and figure it out myself. Invoke with the --help option if you want to find how to invoke this script."
-
-while [ $# -gt 0 ]; do
-	case $1 in
-		--release)			shift; release_ver=$1;;
-		--release-suffix)	shift; release_ver_suffix=$1;;
-		--master)			shift; master_ver=$1;;
-		--master-suffix)	shift; master_ver_suffix=$1;;
-		*)					usage; exit 1;;
-	esac
-	shift
-done
-
-# Use xpath to query the current version number in the pom
-xpath='xpath'
-type -P $xpath &>/dev/null && {
-	set +e
-	current_version=$( xpath pom.xml '/project/version/text()' 2>/dev/null )
-	( echo ${current_version} | grep -qE '^([0-9]+).([0-9]+).0-SNAPSHOT$' )
-	current_version_valid=$?
-	set -e 
-} || { 
-	echo "Cannot guess version number as $xpath command not found."
-	current_version_valid=1
-}
-
-if [ "${current_version_valid}" -ne 0 -a -z "${release_ver}" -a -z "${master_ver}" ]; then
-	echo >&2 "Detected current version as '${current_version}', but I can't parse this. Please supply --release and --master parameters."
-	exit 1
-fi
-
-[ -z "${release_ver}" ] && {
-	release_ver=${current_version%-SNAPSHOT}
-	release_ver=${release_ver%.0}
-	[ -z "${release_ver}" ] && { echo >&2 Could not determine the version of the release branch. Please use the --release parameter. ; exit 1 ; }
-}
-
-[ -z "${master_ver}" ] && {
-	master_ver=$( echo ${current_version} | perl -n -e 'if (/^(\d+).(\d+)(.*)$/) { printf "%s.%s\n", $1, $2+1 }' )
-	[ -z "${master_ver}" ] && { echo >&2 Could not determine the version of the master branch. Please use the --master parameter. ; exit 1 ; }
-}
-
-version_on_branch=${release_ver}${release_ver_suffix}
-version_on_master=${master_ver}${master_ver_suffix}
-branch_name=${version_on_branch}
-
-# Show the details and get confirmation
-echo "The current version is:                                  ${current_version}"
-echo "The release branch will be named:                        ${branch_name}"
-echo "The version number on the release branch will be set to: ${version_on_branch}"
-echo "The version number on 'master' will be set to:           ${version_on_master}"
-echo "If you proceed, the new branch and version number changes will be pushed to GitHub."
-echo -n 'Enter "y" if this is correct, anything else to abort: '
-read input
-[ "$input" == "y" ] || { echo >&2 Aborted. ; exit 1 ; }
-
-# Fail if not in a Git repository
-[ -d .git ] || {
-	echo >&2 Error: this directory is not a git repository root. Nothing happened.
-	exit 1
-}
-
-# Warn if the current branch isn't master
-current_branch=$( git name-rev --name-only HEAD )
-[ ${current_branch} == "master" ] || {
-	echo Current branch is ${current_branch}. Usually, release branches are made from master.
-	echo -n 'Enter "y" if this is correct, anything else to abort: '
-	read input
-	[ "$input" == "y" ] || { echo >&2 Aborted. ; exit 1 ; }
-}
-
-# Get Maven to make the branch
-set -x
-mvn release:clean release:branch -P Brooklyn,Console,Example,Launcher,Acceptance,Documentation --batch-mode -DautoVersionSubmodules=true -DbranchName=${branch_name} -DupdateBranchVersions=true -DreleaseVersion=${version_on_branch} -DdevelopmentVersion=${version_on_master}
-set +x
-
-# Done!
-echo Completed. Your repository is still looking at ${current_branch}. To switch to the release branch, enter:
-echo git checkout ${branch_name}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/scripts/release-make
----------------------------------------------------------------------
diff --git a/usage/scripts/release-make b/usage/scripts/release-make
deleted file mode 100755
index df46ea1..0000000
--- a/usage/scripts/release-make
+++ /dev/null
@@ -1,83 +0,0 @@
-#!/bin/bash -e -u
-#
-# 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.
-#
-
-usage(){
-	echo >&2 'Usage: release-make [ --release <version> ] [ --next <version> ]'
-	echo >&2 'Creates and tags a release based on the current branch.'
-	echo >&2 'Arguments are optional - if omitted, the script tries to work out the correct versions.'
-	echo >&2 'release <version> should be a full version number, such as 3.6.0-RC1'
-	echo >&2 'next <version> should be a snapshot version number, such as 3.6.0-RC2-SNAPSHOT'
-	echo >&2 'This command will preview what it is going to do and require confirmation before it makes changes.'
-}
-
-[ $# -eq 0 ] && echo >&2 "No arguments given, so I'm going to try and figure it out myself. Invoke with the --help option if you want to find how to invoke this script."
-
-release_tag_ver=
-release_branch_ver=
-
-while [ $# -gt 0 ]; do
-	case $1 in
-		--release)	shift; release_tag_ver=$1;;
-		--next)		shift; release_branch_ver=$1;;
-		*)					usage; exit 1;;
-	esac
-	shift
-done
-
-# Some magic to derive the anticipated version of the release.
-# Use xpath to query the version number in the pom
-xpath='xpath'
-type -P $xpath &>/dev/null && {
-	set +e
-	current_version=$( xpath pom.xml '/project/version/text()' 2>/dev/null )
-	set -e
-} || {
-        echo "Cannot guess version number as $xpath command not found."
-}
-# If the user didn't supply the release version, strip -SNAPSHOT off the current version and use that
-[ -z "$release_tag_ver" ] && release_tag_ver=${current_version%-SNAPSHOT}
-
-# More magic, this time to guess the next version.
-# If the user didn't supply the next version, modify the digits off the end of the release to increment by one and append -SNAPSHOT
-[ -z "$release_branch_ver" ] && release_branch_ver=$( echo ${release_tag_ver} | perl -n -e 'if (/^(.*)(\d+)$/) { print $1.($2+1)."-SNAPSHOT\n" }' )
-
-current_branch=$( git name-rev --name-only HEAD )
-
-echo "The release is on the branch:                             ${current_branch}"
-echo "The current version (detected) is:                        ${current_version}"
-echo "The release version is:                                   ${release_tag_ver}"
-echo "Development on the release branch continues with version: ${release_branch_ver}"
-echo -n 'Enter "y" if this is correct, anything else to abort: '
-read input
-[ "$input" == "y" ] || { echo >&2 Aborted. ; exit 1 ; }
-
-# Warn if the current branch is master
-[ ${current_branch} == "master" ] && {
-	echo Current branch is ${current_branch}. Usually, releases are made from a release branch.
-	echo -n 'Enter "y" if this is correct, anything else to abort: '
-	read input
-	[ "$input" == "y" ] || { echo >&2 Aborted. ; exit 1 ; }
-}
-
-# Release prepare
-mvn release:clean release:prepare -PExample,Launcher,Four,Three --batch-mode -DautoVersionSubmodules=true -DreleaseVersion=${release_tag_ver} -DdevelopmentVersion=${release_branch_ver}
-
-# Release perform
-mvn release:perform -PExample,Launcher,Four,Three --batch-mode


[47/51] [abbrv] brooklyn-dist git commit: move subdir from incubator up a level as it is promoted to its own repo (first non-incubator commit!)

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/src/main/license/files/LICENSE
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/license/files/LICENSE b/brooklyn-dist/dist/src/main/license/files/LICENSE
deleted file mode 100644
index dd42819..0000000
--- a/brooklyn-dist/dist/src/main/license/files/LICENSE
+++ /dev/null
@@ -1,2169 +0,0 @@
-
-This software is distributed under the Apache License, version 2.0. See (1) below.
-This software is copyright (c) The Apache Software Foundation and contributors.
-
-Contents:
-
-  (1) This software license: Apache License, version 2.0
-  (2) Notices for bundled software
-  (3) Licenses for bundled software
-
-
----------------------------------------------------
-
-(1) This software license: Apache License, version 2.0
-
-
-                                 Apache License
-                           Version 2.0, January 2004
-                        http://www.apache.org/licenses/
-
-   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
-
-   1. Definitions.
-
-      "License" shall mean the terms and conditions for use, reproduction,
-      and distribution as defined by Sections 1 through 9 of this document.
-
-      "Licensor" shall mean the copyright owner or entity authorized by
-      the copyright owner that is granting the License.
-
-      "Legal Entity" shall mean the union of the acting entity and all
-      other entities that control, are controlled by, or are under common
-      control with that entity. For the purposes of this definition,
-      "control" means (i) the power, direct or indirect, to cause the
-      direction or management of such entity, whether by contract or
-      otherwise, or (ii) ownership of fifty percent (50%) or more of the
-      outstanding shares, or (iii) beneficial ownership of such entity.
-
-      "You" (or "Your") shall mean an individual or Legal Entity
-      exercising permissions granted by this License.
-
-      "Source" form shall mean the preferred form for making modifications,
-      including but not limited to software source code, documentation
-      source, and configuration files.
-
-      "Object" form shall mean any form resulting from mechanical
-      transformation or translation of a Source form, including but
-      not limited to compiled object code, generated documentation,
-      and conversions to other media types.
-
-      "Work" shall mean the work of authorship, whether in Source or
-      Object form, made available under the License, as indicated by a
-      copyright notice that is included in or attached to the work
-      (an example is provided in the Appendix below).
-
-      "Derivative Works" shall mean any work, whether in Source or Object
-      form, that is based on (or derived from) the Work and for which the
-      editorial revisions, annotations, elaborations, or other modifications
-      represent, as a whole, an original work of authorship. For the purposes
-      of this License, Derivative Works shall not include works that remain
-      separable from, or merely link (or bind by name) to the interfaces of,
-      the Work and Derivative Works thereof.
-
-      "Contribution" shall mean any work of authorship, including
-      the original version of the Work and any modifications or additions
-      to that Work or Derivative Works thereof, that is intentionally
-      submitted to Licensor for inclusion in the Work by the copyright owner
-      or by an individual or Legal Entity authorized to submit on behalf of
-      the copyright owner. For the purposes of this definition, "submitted"
-      means any form of electronic, verbal, or written communication sent
-      to the Licensor or its representatives, including but not limited to
-      communication on electronic mailing lists, source code control systems,
-      and issue tracking systems that are managed by, or on behalf of, the
-      Licensor for the purpose of discussing and improving the Work, but
-      excluding communication that is conspicuously marked or otherwise
-      designated in writing by the copyright owner as "Not a Contribution."
-
-      "Contributor" shall mean Licensor and any individual or Legal Entity
-      on behalf of whom a Contribution has been received by Licensor and
-      subsequently incorporated within the Work.
-
-   2. Grant of Copyright License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      copyright license to reproduce, prepare Derivative Works of,
-      publicly display, publicly perform, sublicense, and distribute the
-      Work and such Derivative Works in Source or Object form.
-
-   3. Grant of Patent License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      (except as stated in this section) patent license to make, have made,
-      use, offer to sell, sell, import, and otherwise transfer the Work,
-      where such license applies only to those patent claims licensable
-      by such Contributor that are necessarily infringed by their
-      Contribution(s) alone or by combination of their Contribution(s)
-      with the Work to which such Contribution(s) was submitted. If You
-      institute patent litigation against any entity (including a
-      cross-claim or counterclaim in a lawsuit) alleging that the Work
-      or a Contribution incorporated within the Work constitutes direct
-      or contributory patent infringement, then any patent licenses
-      granted to You under this License for that Work shall terminate
-      as of the date such litigation is filed.
-
-   4. Redistribution. You may reproduce and distribute copies of the
-      Work or Derivative Works thereof in any medium, with or without
-      modifications, and in Source or Object form, provided that You
-      meet the following conditions:
-
-      (a) You must give any other recipients of the Work or
-          Derivative Works a copy of this License; and
-
-      (b) You must cause any modified files to carry prominent notices
-          stating that You changed the files; and
-
-      (c) You must retain, in the Source form of any Derivative Works
-          that You distribute, all copyright, patent, trademark, and
-          attribution notices from the Source form of the Work,
-          excluding those notices that do not pertain to any part of
-          the Derivative Works; and
-
-      (d) If the Work includes a "NOTICE" text file as part of its
-          distribution, then any Derivative Works that You distribute must
-          include a readable copy of the attribution notices contained
-          within such NOTICE file, excluding those notices that do not
-          pertain to any part of the Derivative Works, in at least one
-          of the following places: within a NOTICE text file distributed
-          as part of the Derivative Works; within the Source form or
-          documentation, if provided along with the Derivative Works; or,
-          within a display generated by the Derivative Works, if and
-          wherever such third-party notices normally appear. The contents
-          of the NOTICE file are for informational purposes only and
-          do not modify the License. You may add Your own attribution
-          notices within Derivative Works that You distribute, alongside
-          or as an addendum to the NOTICE text from the Work, provided
-          that such additional attribution notices cannot be construed
-          as modifying the License.
-
-      You may add Your own copyright statement to Your modifications and
-      may provide additional or different license terms and conditions
-      for use, reproduction, or distribution of Your modifications, or
-      for any such Derivative Works as a whole, provided Your use,
-      reproduction, and distribution of the Work otherwise complies with
-      the conditions stated in this License.
-
-   5. Submission of Contributions. Unless You explicitly state otherwise,
-      any Contribution intentionally submitted for inclusion in the Work
-      by You to the Licensor shall be under the terms and conditions of
-      this License, without any additional terms or conditions.
-      Notwithstanding the above, nothing herein shall supersede or modify
-      the terms of any separate license agreement you may have executed
-      with Licensor regarding such Contributions.
-
-   6. Trademarks. This License does not grant permission to use the trade
-      names, trademarks, service marks, or product names of the Licensor,
-      except as required for reasonable and customary use in describing the
-      origin of the Work and reproducing the content of the NOTICE file.
-
-   7. Disclaimer of Warranty. Unless required by applicable law or
-      agreed to in writing, Licensor provides the Work (and each
-      Contributor provides its Contributions) on an "AS IS" BASIS,
-      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-      implied, including, without limitation, any warranties or conditions
-      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-      PARTICULAR PURPOSE. You are solely responsible for determining the
-      appropriateness of using or redistributing the Work and assume any
-      risks associated with Your exercise of permissions under this License.
-
-   8. Limitation of Liability. In no event and under no legal theory,
-      whether in tort (including negligence), contract, or otherwise,
-      unless required by applicable law (such as deliberate and grossly
-      negligent acts) or agreed to in writing, shall any Contributor be
-      liable to You for damages, including any direct, indirect, special,
-      incidental, or consequential damages of any character arising as a
-      result of this License or out of the use or inability to use the
-      Work (including but not limited to damages for loss of goodwill,
-      work stoppage, computer failure or malfunction, or any and all
-      other commercial damages or losses), even if such Contributor
-      has been advised of the possibility of such damages.
-
-   9. Accepting Warranty or Additional Liability. While redistributing
-      the Work or Derivative Works thereof, You may choose to offer,
-      and charge a fee for, acceptance of support, warranty, indemnity,
-      or other liability obligations and/or rights consistent with this
-      License. However, in accepting such obligations, You may act only
-      on Your own behalf and on Your sole responsibility, not on behalf
-      of any other Contributor, and only if You agree to indemnify,
-      defend, and hold each Contributor harmless for any liability
-      incurred by, or claims asserted against, such Contributor by reason
-      of your accepting any such warranty or additional liability.
-
-
----------------------------------------------------
-
-(2) Notices for bundled software
-
-This project includes the software: aopalliance
-  Available at: http://aopalliance.sourceforge.net
-  Version used: 1.0
-  Used under the following license: Public Domain
-
-This project includes the software: asm
-  Available at: http://asm.objectweb.org/
-  Developed by: ObjectWeb (http://www.objectweb.org/)
-  Version used: 3.3.1
-  Used under the following license: BSD License (http://asm.objectweb.org/license.html)
-
-This project includes the software: async.js
-  Available at: https://github.com/p15martin/google-maps-hello-world/blob/master/js/libs/async.js
-  Developed by: Miller Medeiros (https://github.com/millermedeiros/)
-  Version used: 0.1.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Miller Medeiros (2011)
-
-This project includes the software: backbone.js
-  Available at: http://backbonejs.org
-  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
-  Version used: 1.0.0
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2010-2013)
-
-This project includes the software: bootstrap.js
-  Available at: http://twitter.github.com/bootstrap/javascript.html#transitions
-  Version used: 2.0.4
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-  Copyright (c) Twitter, Inc. (2012)
-
-This project includes the software: ch.qos.logback
-  Available at: http://logback.qos.ch
-  Developed by: QOS.ch (http://www.qos.ch)
-  Version used: 1.0.7
-  Used under the following license: Eclipse Public License, version 1.0 (http://www.eclipse.org/legal/epl-v10.html)
-
-This project includes the software: com.fasterxml.jackson.core
-  Available at: http://github.com/FasterXML/jackson https://github.com/FasterXML/jackson
-  Developed by: FasterXML (http://fasterxml.com/)
-  Version used: 2.4.5
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.fasterxml.jackson.dataformat
-  Available at: https://github.com/FasterXML/jackson http://wiki.fasterxml.com/JacksonExtensionXmlDataBinding
-  Developed by: FasterXML (http://fasterxml.com/)
-  Version used: 2.4.5
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.fasterxml.jackson.datatype
-  Available at: http://wiki.fasterxml.com/JacksonModuleJoda
-  Developed by: FasterXML (http://fasterxml.com/)
-  Version used: 2.4.5
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.fasterxml.jackson.jaxrs
-  Available at: http://wiki.fasterxml.com/JacksonHome
-  Developed by: FasterXML (http://fasterxml.com/)
-  Version used: 2.4.5
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.fasterxml.jackson.module
-  Available at: http://wiki.fasterxml.com/JacksonJAXBAnnotations
-  Developed by: FasterXML (http://fasterxml.com/)
-  Version used: 2.4.5
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.google.code.findbugs
-  Available at: http://findbugs.sourceforge.net/
-  Version used: 2.0.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.google.code.gson
-  Available at: http://code.google.com/p/google-gson/
-  Developed by: Google, Inc. (http://www.google.com)
-  Version used: 2.3
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.google.guava
-  Available at: http://code.google.com/p/guava-libraries
-  Version used: 17.0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.google.http-client
-  Available at: http://code.google.com/p/google-http-java-client/
-  Developed by: Google (http://www.google.com/)
-  Version used: 1.18.0-rc
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.google.inject
-  Available at: http://code.google.com/p/google-guice/
-  Developed by: Google, Inc. (http://www.google.com)
-  Version used: 3.0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.google.inject.extensions
-  Available at: http://code.google.com/p/google-guice/
-  Developed by: Google, Inc. (http://www.google.com)
-  Version used: 3.0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.googlecode.concurrentlinkedhashmap
-  Available at: http://code.google.com/p/concurrentlinkedhashmap
-  Version used: 1.0_jdk5
-  Used under the following license: Apache License (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.jamesmurty.utils
-  Available at: https://github.com/jmurty/java-xmlbuilder
-  Version used: 1.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-
-This project includes the software: com.jayway.jsonpath
-  Available at: https://github.com/jayway/JsonPath
-  Version used: 2.0.0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.jcraft
-  Available at: http://www.jcraft.com/jsch-agent-proxy/
-  Developed by: JCraft,Inc. (http://www.jcraft.com/)
-  Version used: 0.0.8
-  Used under the following license: The BSD 3-Clause (New BSD) License (http://www.jcraft.com/jsch-agent-proxy/LICENSE.txt)
-
-This project includes the software: com.maxmind.db
-  Available at: http://dev.maxmind.com/
-  Developed by: MaxMind, Inc. (http://www.maxmind.com/)
-  Version used: 0.3.4
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.html)
-
-This project includes the software: com.maxmind.geoip2
-  Available at: http://dev.maxmind.com/geoip/geoip2/web-services
-  Developed by: MaxMind, Inc. (http://www.maxmind.com/)
-  Version used: 0.8.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.html)
-
-This project includes the software: com.squareup.okhttp
-  Available at: https://github.com/square/okhttp
-  Version used: 2.2.0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.squareup.okio
-  Available at: https://github.com/square/okio
-  Version used: 1.2.0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.sun.jersey
-  Available at: https://jersey.java.net/
-  Developed by: Oracle Corporation (http://www.oracle.com/)
-  Version used: 1.19
-  Used under the following license: Common Development and Distribution License, version 1.1 (http://glassfish.java.net/public/CDDL+GPL_1_1.html)
-
-This project includes the software: com.sun.jersey.contribs
-  Available at: https://jersey.java.net/
-  Developed by: Oracle Corporation (http://www.oracle.com/)
-  Version used: 1.19
-  Used under the following license: Common Development and Distribution License, version 1.1 (http://glassfish.java.net/public/CDDL+GPL_1_1.html)
-
-This project includes the software: com.thoughtworks.xstream
-  Available at: http://x-stream.github.io/
-  Developed by: XStream (http://xstream.codehaus.org)
-  Version used: 1.4.7
-  Used under the following license: BSD License (http://xstream.codehaus.org/license.html)
-
-This project includes the software: commons-beanutils
-  Available at: http://commons.apache.org/proper/commons-beanutils/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: commons-codec
-  Available at: http://commons.apache.org/proper/commons-codec/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: commons-collections
-  Available at: http://commons.apache.org/collections/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 3.2.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: commons-io
-  Available at: http://commons.apache.org/io/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 2.4
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: commons-lang
-  Available at: http://commons.apache.org/lang/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 2.4
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: commons-logging
-  Available at: http://commons.apache.org/proper/commons-logging/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.2
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: dom4j
-  Available at: http://dom4j.sourceforge.net/
-  Developed by: MetaStuff Ltd. (http://sourceforge.net/projects/dom4j)
-  Version used: 1.6.1
-  Used under the following license: MetaStuff BSD style license (3-clause) (http://dom4j.sourceforge.net/dom4j-1.6.1/license.html)
-
-This project includes the software: handlebars.js
-  Available at: https://github.com/wycats/handlebars.js
-  Developed by: Yehuda Katz (https://github.com/wycats/)
-  Inclusive of: handlebars*.js
-  Version used: 1.0-rc1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Yehuda Katz (2012)
-
-This project includes the software: io.airlift
-  Available at: https://github.com/airlift/airline
-  Version used: 0.6
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: io.cloudsoft.windows
-  Available at: http://github.com/cloudsoft/winrm4j
-  Version used: 0.2.0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: io.swagger
-  Available at: https://github.com/swagger-api/swagger-core
-  Version used: 1.5.3
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.html)
-
-This project includes the software: javax.annotation
-  Available at: https://jcp.org/en/jsr/detail?id=250
-  Version used: 1.0
-  Used under the following license: Common Development and Distribution License, version 1.0 (https://glassfish.dev.java.net/public/CDDLv1.0.html)
-
-This project includes the software: javax.inject
-  Available at: http://code.google.com/p/atinject/
-  Version used: 1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: javax.servlet
-  Available at: http://servlet-spec.java.net
-  Developed by: GlassFish Community (https://glassfish.dev.java.net)
-  Version used: 3.1.0
-  Used under the following license: CDDL + GPLv2 with classpath exception (https://glassfish.dev.java.net/nonav/public/CDDL+GPL.html)
-
-This project includes the software: javax.validation
-  Available at: http://beanvalidation.org
-  Version used: 1.1.0.Final
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: javax.ws.rs
-  Available at: https://jsr311.java.net/
-  Developed by: Sun Microsystems, Inc (http://www.sun.com/)
-  Version used: 1.1.1
-  Used under the following license: CDDL License (http://www.opensource.org/licenses/cddl1.php)
-
-This project includes the software: joda-time
-  Available at: http://joda-time.sourceforge.net
-  Developed by: Joda.org (http://www.joda.org)
-  Version used: 2.2
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: jQuery JavaScript Library
-  Available at: http://jquery.com/
-  Developed by: The jQuery Foundation (http://jquery.org/)
-  Inclusive of: jquery.js
-  Version used: 1.7.2
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) John Resig (2005-2011)
-  Includes code fragments from sizzle.js:
-    Copyright (c) The Dojo Foundation
-    Available at http://sizzlejs.com
-    Used under the MIT license
-
-This project includes the software: jQuery BBQ: Back Button & Query Library
-  Available at: http://benalman.com/projects/jquery-bbq-plugin/
-  Developed by: "Cowboy" Ben Alman (http://benalman.com/)
-  Inclusive of: jquery.ba-bbq*.js
-  Version used: 1.2.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) "Cowboy" Ben Alman (2010)"
-
-This project includes the software: DataTables Table plug-in for jQuery
-  Available at: http://www.datatables.net/
-  Developed by: SpryMedia Ltd (http://sprymedia.co.uk/)
-  Inclusive of: jquery.dataTables.{js,css}
-  Version used: 1.9.4
-  Used under the following license: The BSD 3-Clause (New BSD) License (http://opensource.org/licenses/BSD-3-Clause)
-  Copyright (c) Allan Jardine (2008-2012)
-
-This project includes the software: jQuery Form Plugin
-  Available at: https://github.com/malsup/form
-  Developed by: Mike Alsup (http://malsup.com/)
-  Inclusive of: jquery.form.js
-  Version used: 3.09
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) M. Alsup (2006-2013)
-
-This project includes the software: jQuery Wiggle
-  Available at: https://github.com/jordanthomas/jquery-wiggle
-  Inclusive of: jquery.wiggle.min.js
-  Version used: swagger-ui:1.0.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) WonderGroup and Jordan Thomas (2010)
-  Previously online at http://labs.wondergroup.com/demos/mini-ui/index.html.
-  The version included here is from the Swagger UI distribution.
-
-This project includes the software: js-uri
-  Available at: http://code.google.com/p/js-uri/
-  Developed by: js-uri contributors (https://code.google.com/js-uri)
-  Inclusive of: URI.js
-  Version used: 0.1
-  Used under the following license: The BSD 3-Clause (New BSD) License (http://opensource.org/licenses/BSD-3-Clause)
-  Copyright (c) js-uri contributors (2013)
-
-This project includes the software: js-yaml.js
-  Available at: https://github.com/nodeca/
-  Developed by: Vitaly Puzrin (https://github.com/nodeca/)
-  Version used: 3.2.7
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Vitaly Puzrin (2011-2015)
-
-This project includes the software: marked.js
-  Available at: https://github.com/chjj/marked
-  Developed by: Christopher Jeffrey (https://github.com/chjj)
-  Version used: 0.3.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Christopher Jeffrey (2011-2014)
-
-This project includes the software: moment.js
-  Available at: http://momentjs.com
-  Developed by: Tim Wood (http://momentjs.com)
-  Version used: 2.1.0
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Tim Wood, Iskren Chernev, Moment.js contributors (2011-2014)
-
-This project includes the software: net.iharder
-  Available at: http://iharder.net/base64/
-  Version used: 2.3.8
-  Used under the following license: Public domain
-
-This project includes the software: net.java.dev.jna
-  Available at: https://github.com/twall/jna
-  Version used: 4.0.0
-  Used under the following license: Apache License, version 2.0 (http://www.gnu.org/licenses/licenses.html)
-
-This project includes the software: net.minidev
-  Available at: http://www.minidev.net/
-  Developed by: Chemouni Uriel (http://www.minidev.net/)
-  Version used: 2.1.1; 1.0.2
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: net.schmizz
-  Available at: http://github.com/shikhar/sshj
-  Version used: 0.8.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.99soft.guice
-  Available at: http://99soft.github.com/rocoto/
-  Developed by: 99 Software Foundation (http://www.99soft.org/)
-  Version used: 6.2
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.commons
-  Available at: http://commons.apache.org/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 3.3.2; 1.4
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.felix
-  Available at: http://felix.apache.org/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 4.4.0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.httpcomponents
-  Available at: http://hc.apache.org/httpcomponents-client-ga http://hc.apache.org/httpcomponents-core-ga
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 4.4.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.jclouds
-  Available at: http://jclouds.apache.org/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.2
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.jclouds.api
-  Available at: http://jclouds.apache.org/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.2
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.jclouds.common
-  Available at: http://jclouds.apache.org/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.2
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.jclouds.driver
-  Available at: http://jclouds.apache.org/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.2
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.jclouds.labs
-  Available at: http://jclouds.apache.org/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.2
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.jclouds.provider
-  Available at: http://jclouds.apache.org/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.2
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.bouncycastle
-  Available at: http://www.bouncycastle.org/java.html
-  Version used: 1.49
-  Used under the following license: Bouncy Castle Licence (http://www.bouncycastle.org/licence.html)
-
-This project includes the software: org.codehaus.groovy
-  Available at: http://groovy.codehaus.org/
-  Developed by: The Codehaus (http://codehaus.org)
-  Version used: 2.3.7
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.codehaus.jackson
-  Available at: http://jackson.codehaus.org
-  Developed by: FasterXML (http://fasterxml.com)
-  Version used: 1.9.13
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.codehaus.jettison
-  Version used: 1.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-
-This project includes the software: org.codehaus.woodstox
-  Available at: http://wiki.fasterxml.com/WoodstoxStax2
-  Developed by: fasterxml.com (http://fasterxml.com)
-  Version used: 3.1.4
-  Used under the following license: BSD License (http://www.opensource.org/licenses/bsd-license.php)
-
-This project includes the software: org.eclipse.jetty
-  Available at: http://www.eclipse.org/jetty
-  Developed by: Webtide (http://webtide.com)
-  Version used: 9.2.13.v20150730
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-
-This project includes the software: org.eclipse.jetty.toolchain
-  Available at: http://www.eclipse.org/jetty
-  Developed by: Mort Bay Consulting (http://www.mortbay.com)
-  Version used: 3.1.M0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-
-This project includes the software: org.freemarker
-  Available at: http://freemarker.org/
-  Version used: 2.3.22
-  Used under the following license: Apache License, version 2.0 (http://freemarker.org/LICENSE.txt)
-
-This project includes the software: org.glassfish.external
-  Version used: 1.0-b01-ea
-  Used under the following license: Common Development and Distribution License (http://opensource.org/licenses/CDDL-1.0)
-
-This project includes the software: org.hibernate
-  Available at: http://jtidy.sourceforge.net
-  Version used: r8-20060801
-  Used under the following license: Java HTML Tidy License (http://sourceforge.net/p/jtidy/code/HEAD/tree/trunk/jtidy/LICENSE.txt?revision=95)
-
-This project includes the software: org.javassist
-  Available at: http://www.javassist.org/
-  Version used: 3.16.1-GA
-  Used under the following license: Apache License, version 2.0 (http://www.mozilla.org/MPL/MPL-1.1.html)
-
-This project includes the software: org.jvnet.mimepull
-  Available at: http://mimepull.java.net
-  Developed by: Oracle Corporation (http://www.oracle.com/)
-  Version used: 1.9.3
-  Used under the following license: Common Development and Distribution License, version 1.1 (https://glassfish.java.net/public/CDDL+GPL_1_1.html)
-
-This project includes the software: org.mongodb
-  Available at: http://www.mongodb.org
-  Version used: 3.0.3
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.reflections
-  Available at: http://code.google.com/p/reflections/
-  Version used: 0.9.9-RC1
-  Used under the following license: WTFPL (http://www.wtfpl.net/)
-
-This project includes the software: org.slf4j
-  Available at: http://www.slf4j.org
-  Developed by: QOS.ch (http://www.qos.ch)
-  Version used: 1.6.6
-  Used under the following license: The MIT License (http://www.opensource.org/licenses/mit-license.php)
-
-This project includes the software: org.tukaani
-  Available at: http://tukaani.org/xz/java.html
-  Version used: 1.0
-  Used under the following license: Public Domain
-
-This project includes the software: org.yaml
-  Available at: http://www.snakeyaml.org
-  Version used: 1.11
-  Used under the following license: Apache License, version 2.0 (in-project reference: LICENSE.txt)
-
-This project includes the software: RequireJS
-  Available at: http://requirejs.org/
-  Developed by: The Dojo Foundation (http://dojofoundation.org/)
-  Inclusive of: require.js, text.js
-  Version used: 2.0.6
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) The Dojo Foundation (2010-2012)
-
-This project includes the software: RequireJS (r.js maven plugin)
-  Available at: http://github.com/jrburke/requirejs
-  Developed by: The Dojo Foundation (http://dojofoundation.org/)
-  Inclusive of: r.js
-  Version used: 2.1.6
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) The Dojo Foundation (2009-2013)
-  Includes code fragments for source-map and other functionality:
-    Copyright (c) The Mozilla Foundation and contributors (2011)
-    Used under the BSD 2-Clause license.
-  Includes code fragments for parse-js and other functionality:
-    Copyright (c) Mihai Bazon (2010, 2012)
-    Used under the BSD 2-Clause license.
-  Includes code fragments for uglifyjs/consolidator:
-    Copyright (c) Robert Gust-Bardon (2012)
-    Used under the BSD 2-Clause license.
-  Includes code fragments for the esprima parser:
-    Copyright (c):
-      Ariya Hidayat (2011, 2012)
-      Mathias Bynens (2012)
-      Joost-Wim Boekesteijn (2012)
-      Kris Kowal (2012)
-      Yusuke Suzuki (2012)
-      Arpad Borsos (2012)
-    Used under the BSD 2-Clause license.
-
-This project includes the software: Swagger UI
-  Available at: https://github.com/swagger-api/swagger-ui
-  Inclusive of: swagger*.{js,css,html}
-  Version used: 2.1.4
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-  Copyright (c) SmartBear Software (2011-2015)
-
-This project includes the software: typeahead.js
-  Available at: https://github.com/twitter/typeahead.js
-  Developed by: Twitter, Inc (http://twitter.com)
-  Version used: 0.10.5
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Twitter, Inc. and other contributors (2013-2014)
-
-This project includes the software: underscore.js
-  Available at: http://underscorejs.org
-  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
-  Inclusive of: underscore*.{js,map}
-  Version used: 1.4.4
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2009-2013)
-
-This project includes the software: underscore.js:1.7.0
-  Available at: http://underscorejs.org
-  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
-  Inclusive of: underscore*.{js,map}
-  Version used: 1.7.0
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Jeremy Ashkenas, DocumentCloud and Investigative Reporters & Editors (2009-2014)
-
-This project includes the software: xmlpull
-  Available at: http://www.xmlpull.org
-  Version used: 1.1.3.1
-  Used under the following license: Public Domain (http://www.xmlpull.org/v1/download/unpacked/LICENSE.txt)
-
-This project includes the software: xpp3
-  Available at: http://www.extreme.indiana.edu/xgws/xsoap/xpp/mxp1/
-  Developed by: Extreme! Lab, Indiana University (http://www.extreme.indiana.edu/)
-  Version used: 1.1.4c
-  Used under the following license: Indiana University Extreme! Lab Software License, vesion 1.1.1 (https://github.com/apache/openmeetings/blob/a95714ce3f7e587d13d3d0bb3b4f570be15c67a5/LICENSE#L1361)
-
-This project includes the software: ZeroClipboard
-  Available at: http://zeroclipboard.org/
-  Developed by: ZeroClipboard contributors (https://github.com/zeroclipboard)
-  Inclusive of: ZeroClipboard.*
-  Version used: 1.3.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Jon Rohan, James M. Greene (2014)
-
-
----------------------------------------------------
-
-(3) Licenses for bundled software
-
-Contents:
-
-  Apache License, Version 2.0
-  The BSD 2-Clause License
-  The BSD 3-Clause License ("New BSD")
-  COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.0
-  COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.1
-  Eclipse Public License, version 1.0
-  The MIT License ("MIT")
-  WTF Public License
-  Bouncy Castle License
-  JTidy License
-  Jython License
-  MetaStuff BSD Style License
-  Indiana University Extreme! Lab Software License, Version 1.1.1
-
-
-Apache License, Version 2.0
-
-  Apache License
-  Version 2.0, January 2004
-  http://www.apache.org/licenses/
-  
-  TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
-  
-  1. Definitions.
-  
-  "License" shall mean the terms and conditions for use, reproduction,
-  and distribution as defined by Sections 1 through 9 of this document.
-  
-  "Licensor" shall mean the copyright owner or entity authorized by
-  the copyright owner that is granting the License.
-  
-  "Legal Entity" shall mean the union of the acting entity and all
-  other entities that control, are controlled by, or are under common
-  control with that entity. For the purposes of this definition,
-  "control" means (i) the power, direct or indirect, to cause the
-  direction or management of such entity, whether by contract or
-  otherwise, or (ii) ownership of fifty percent (50%) or more of the
-  outstanding shares, or (iii) beneficial ownership of such entity.
-  
-  "You" (or "Your") shall mean an individual or Legal Entity
-  exercising permissions granted by this License.
-  
-  "Source" form shall mean the preferred form for making modifications,
-  including but not limited to software source code, documentation
-  source, and configuration files.
-  
-  "Object" form shall mean any form resulting from mechanical
-  transformation or translation of a Source form, including but
-  not limited to compiled object code, generated documentation,
-  and conversions to other media types.
-  
-  "Work" shall mean the work of authorship, whether in Source or
-  Object form, made available under the License, as indicated by a
-  copyright notice that is included in or attached to the work
-  (an example is provided in the Appendix below).
-  
-  "Derivative Works" shall mean any work, whether in Source or Object
-  form, that is based on (or derived from) the Work and for which the
-  editorial revisions, annotations, elaborations, or other modifications
-  represent, as a whole, an original work of authorship. For the purposes
-  of this License, Derivative Works shall not include works that remain
-  separable from, or merely link (or bind by name) to the interfaces of,
-  the Work and Derivative Works thereof.
-  
-  "Contribution" shall mean any work of authorship, including
-  the original version of the Work and any modifications or additions
-  to that Work or Derivative Works thereof, that is intentionally
-  submitted to Licensor for inclusion in the Work by the copyright owner
-  or by an individual or Legal Entity authorized to submit on behalf of
-  the copyright owner. For the purposes of this definition, "submitted"
-  means any form of electronic, verbal, or written communication sent
-  to the Licensor or its representatives, including but not limited to
-  communication on electronic mailing lists, source code control systems,
-  and issue tracking systems that are managed by, or on behalf of, the
-  Licensor for the purpose of discussing and improving the Work, but
-  excluding communication that is conspicuously marked or otherwise
-  designated in writing by the copyright owner as "Not a Contribution."
-  
-  "Contributor" shall mean Licensor and any individual or Legal Entity
-  on behalf of whom a Contribution has been received by Licensor and
-  subsequently incorporated within the Work.
-  
-  2. Grant of Copyright License. Subject to the terms and conditions of
-  this License, each Contributor hereby grants to You a perpetual,
-  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-  copyright license to reproduce, prepare Derivative Works of,
-  publicly display, publicly perform, sublicense, and distribute the
-  Work and such Derivative Works in Source or Object form.
-  
-  3. Grant of Patent License. Subject to the terms and conditions of
-  this License, each Contributor hereby grants to You a perpetual,
-  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-  (except as stated in this section) patent license to make, have made,
-  use, offer to sell, sell, import, and otherwise transfer the Work,
-  where such license applies only to those patent claims licensable
-  by such Contributor that are necessarily infringed by their
-  Contribution(s) alone or by combination of their Contribution(s)
-  with the Work to which such Contribution(s) was submitted. If You
-  institute patent litigation against any entity (including a
-  cross-claim or counterclaim in a lawsuit) alleging that the Work
-  or a Contribution incorporated within the Work constitutes direct
-  or contributory patent infringement, then any patent licenses
-  granted to You under this License for that Work shall terminate
-  as of the date such litigation is filed.
-  
-  4. Redistribution. You may reproduce and distribute copies of the
-  Work or Derivative Works thereof in any medium, with or without
-  modifications, and in Source or Object form, provided that You
-  meet the following conditions:
-  
-  (a) You must give any other recipients of the Work or
-  Derivative Works a copy of this License; and
-  
-  (b) You must cause any modified files to carry prominent notices
-  stating that You changed the files; and
-  
-  (c) You must retain, in the Source form of any Derivative Works
-  that You distribute, all copyright, patent, trademark, and
-  attribution notices from the Source form of the Work,
-  excluding those notices that do not pertain to any part of
-  the Derivative Works; and
-  
-  (d) If the Work includes a "NOTICE" text file as part of its
-  distribution, then any Derivative Works that You distribute must
-  include a readable copy of the attribution notices contained
-  within such NOTICE file, excluding those notices that do not
-  pertain to any part of the Derivative Works, in at least one
-  of the following places: within a NOTICE text file distributed
-  as part of the Derivative Works; within the Source form or
-  documentation, if provided along with the Derivative Works; or,
-  within a display generated by the Derivative Works, if and
-  wherever such third-party notices normally appear. The contents
-  of the NOTICE file are for informational purposes only and
-  do not modify the License. You may add Your own attribution
-  notices within Derivative Works that You distribute, alongside
-  or as an addendum to the NOTICE text from the Work, provided
-  that such additional attribution notices cannot be construed
-  as modifying the License.
-  
-  You may add Your own copyright statement to Your modifications and
-  may provide additional or different license terms and conditions
-  for use, reproduction, or distribution of Your modifications, or
-  for any such Derivative Works as a whole, provided Your use,
-  reproduction, and distribution of the Work otherwise complies with
-  the conditions stated in this License.
-  
-  5. Submission of Contributions. Unless You explicitly state otherwise,
-  any Contribution intentionally submitted for inclusion in the Work
-  by You to the Licensor shall be under the terms and conditions of
-  this License, without any additional terms or conditions.
-  Notwithstanding the above, nothing herein shall supersede or modify
-  the terms of any separate license agreement you may have executed
-  with Licensor regarding such Contributions.
-  
-  6. Trademarks. This License does not grant permission to use the trade
-  names, trademarks, service marks, or product names of the Licensor,
-  except as required for reasonable and customary use in describing the
-  origin of the Work and reproducing the content of the NOTICE file.
-  
-  7. Disclaimer of Warranty. Unless required by applicable law or
-  agreed to in writing, Licensor provides the Work (and each
-  Contributor provides its Contributions) on an "AS IS" BASIS,
-  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-  implied, including, without limitation, any warranties or conditions
-  of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-  PARTICULAR PURPOSE. You are solely responsible for determining the
-  appropriateness of using or redistributing the Work and assume any
-  risks associated with Your exercise of permissions under this License.
-  
-  8. Limitation of Liability. In no event and under no legal theory,
-  whether in tort (including negligence), contract, or otherwise,
-  unless required by applicable law (such as deliberate and grossly
-  negligent acts) or agreed to in writing, shall any Contributor be
-  liable to You for damages, including any direct, indirect, special,
-  incidental, or consequential damages of any character arising as a
-  result of this License or out of the use or inability to use the
-  Work (including but not limited to damages for loss of goodwill,
-  work stoppage, computer failure or malfunction, or any and all
-  other commercial damages or losses), even if such Contributor
-  has been advised of the possibility of such damages.
-  
-  9. Accepting Warranty or Additional Liability. While redistributing
-  the Work or Derivative Works thereof, You may choose to offer,
-  and charge a fee for, acceptance of support, warranty, indemnity,
-  or other liability obligations and/or rights consistent with this
-  License. However, in accepting such obligations, You may act only
-  on Your own behalf and on Your sole responsibility, not on behalf
-  of any other Contributor, and only if You agree to indemnify,
-  defend, and hold each Contributor harmless for any liability
-  incurred by, or claims asserted against, such Contributor by reason
-  of your accepting any such warranty or additional liability.
-  
-
-The BSD 2-Clause License
-
-  Redistribution and use in source and binary forms, with or without
-  modification, are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, this
-  list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice,
-  this list of conditions and the following disclaimer in the documentation
-  and/or other materials provided with the distribution.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
-  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
-  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
-  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
-  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
-  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
-  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
-  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
-  
-
-The BSD 3-Clause License ("New BSD")
-
-  Redistribution and use in source and binary forms, with or without modification,
-  are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, 
-  this list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice, 
-  this list of conditions and the following disclaimer in the documentation 
-  and/or other materials provided with the distribution.
-  
-  3. Neither the name of the copyright holder nor the names of its contributors 
-  may be used to endorse or promote products derived from this software without 
-  specific prior written permission.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
-  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
-  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
-  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
-  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
-  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
-  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
-  POSSIBILITY OF SUCH DAMAGE.
-  
-
-COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.0
-
-  1. Definitions.
-  
-  1.1. "Contributor" means each individual or entity that
-  creates or contributes to the creation of Modifications.
-  
-  1.2. "Contributor Version" means the combination of the
-  Original Software, prior Modifications used by a
-  Contributor (if any), and the Modifications made by that
-  particular Contributor.
-  
-  1.3. "Covered Software" means (a) the Original Software, or
-  (b) Modifications, or (c) the combination of files
-  containing Original Software with files containing
-  Modifications, in each case including portions thereof.
-  
-  1.4. "Executable" means the Covered Software in any form
-  other than Source Code. 
-  
-  1.5. "Initial Developer" means the individual or entity
-  that first makes Original Software available under this
-  License. 
-  
-  1.6. "Larger Work" means a work which combines Covered
-  Software or portions thereof with code not governed by the
-  terms of this License.
-  
-  1.7. "License" means this document.
-  
-  1.8. "Licensable" means having the right to grant, to the
-  maximum extent possible, whether at the time of the initial
-  grant or subsequently acquired, any and all of the rights
-  conveyed herein.
-  
-  1.9. "Modifications" means the Source Code and Executable
-  form of any of the following: 
-  
-  A. Any file that results from an addition to,
-  deletion from or modification of the contents of a
-  file containing Original Software or previous
-  Modifications; 
-  
-  B. Any new file that contains any part of the
-  Original Software or previous Modification; or 
-  
-  C. Any new file that is contributed or otherwise made
-  available under the terms of this License.
-  
-  1.10. "Original Software" means the Source Code and
-  Executable form of computer software code that is
-  originally released under this License. 
-  
-  1.11. "Patent Claims" means any patent claim(s), now owned
-  or hereafter acquired, including without limitation,
-  method, process, and apparatus claims, in any patent
-  Licensable by grantor. 
-  
-  1.12. "Source Code" means (a) the common form of computer
-  software code in which modifications are made and (b)
-  associated documentation included in or with such code.
-  
-  1.13. "You" (or "Your") means an individual or a legal
-  entity exercising rights under, and complying with all of
-  the terms of, this License. For legal entities, "You"
-  includes any entity which controls, is controlled by, or is
-  under common control with You. For purposes of this
-  definition, "control" means (a) the power, direct or
-  indirect, to cause the direction or management of such
-  entity, whether by contract or otherwise, or (b) ownership
-  of more than fifty percent (50%) of the outstanding shares
-  or beneficial ownership of such entity.
-  
-  2. License Grants. 
-  
-  2.1. The Initial Developer Grant.
-  
-  Conditioned upon Your compliance with Section 3.1 below and
-  subject to third party intellectual property claims, the
-  Initial Developer hereby grants You a world-wide,
-  royalty-free, non-exclusive license: 
-  
-  (a) under intellectual property rights (other than
-  patent or trademark) Licensable by Initial Developer,
-  to use, reproduce, modify, display, perform,
-  sublicense and distribute the Original Software (or
-  portions thereof), with or without Modifications,
-  and/or as part of a Larger Work; and 
-  
-  (b) under Patent Claims infringed by the making,
-  using or selling of Original Software, to make, have
-  made, use, practice, sell, and offer for sale, and/or
-  otherwise dispose of the Original Software (or
-  portions thereof). 
-  
-  (c) The licenses granted in Sections 2.1(a) and (b)
-  are effective on the date Initial Developer first
-  distributes or otherwise makes the Original Software
-  available to a third party under the terms of this
-  License. 
-  
-  (d) Notwithstanding Section 2.1(b) above, no patent
-  license is granted: (1) for code that You delete from
-  the Original Software, or (2) for infringements
-  caused by: (i) the modification of the Original
-  Software, or (ii) the combination of the Original
-  Software with other software or devices. 
-  
-  2.2. Contributor Grant.
-  
-  Conditioned upon Your compliance with Section 3.1 below and
-  subject to third party intellectual property claims, each
-  Contributor hereby grants You a world-wide, royalty-free,
-  non-exclusive license:
-  
-  (a) under intellectual property rights (other than
-  patent or trademark) Licensable by Contributor to
-  use, reproduce, modify, display, perform, sublicense
-  and distribute the Modifications created by such
-  Contributor (or portions thereof), either on an
-  unmodified basis, with other Modifications, as
-  Covered Software and/or as part of a Larger Work; and
-  
-  (b) under Patent Claims infringed by the making,
-  using, or selling of Modifications made by that
-  Contributor either alone and/or in combination with
-  its Contributor Version (or portions of such
-  combination), to make, use, sell, offer for sale,
-  have made, and/or otherwise dispose of: (1)
-  Modifications made by that Contributor (or portions
-  thereof); and (2) the combination of Modifications
-  made by that Contributor with its Contributor Version
-  (or portions of such combination). 
-  
-  (c) The licenses granted in Sections 2.2(a) and
-  2.2(b) are effective on the date Contributor first
-  distributes or otherwise makes the Modifications
-  available to a third party. 
-  
-  (d) Notwithstanding Section 2.2(b) above, no patent
-  license is granted: (1) for any code that Contributor
-  has deleted from the Contributor Version; (2) for
-  infringements caused by: (i) third party
-  modifications of Contributor Version, or (ii) the
-  combination of Modifications made by that Contributor
-  with other software (except as part of the
-  Contributor Version) or other devices; or (3) under
-  Patent Claims infringed by Covered Software in the
-  absence of Modifications made by that Contributor. 
-  
-  3. Distribution Obligations.
-  
-  3.1. Availability of Source Code.
-  
-  Any Covered Software that You distribute or otherwise make
-  available in Executable form must also be made available in
-  Source Code form and that Source Code form must be
-  distributed only under the terms of this License. You must
-  include a copy of this License with every copy of the
-  Source Code form of the Covered Software You distribute or
-  otherwise make available. You must inform recipients of any
-  such Covered Software in Executable form as to how they can
-  obtain such Covered Software in Source Code form in a
-  reasonable manner on or through a medium customarily used
-  for software exchange.
-  
-  3.2. Modifications.
-  
-  The Modifications that You create or to which You
-  contribute are governed by the terms of this License. You
-  represent that You believe Your Modifications are Your
-  original creation(s) and/or You have sufficient rights to
-  grant the rights conveyed by this License.
-  
-  3.3. Required Notices.
-  
-  You must include a notice in each of Your Modifications
-  that identifies You as the Contributor of the Modification.
-  You may not remove or alter any copyright, patent or
-  trademark notices contained within the Covered Software, or
-  any notices of licensing or any descriptive text giving
-  attribution to any Contributor or the Initial Developer.
-  
-  3.4. Application of Additional Terms.
-  
-  You may not offer or impose any terms on any Covered
-  Software in Source Code form that alters or restricts the
-  applicable version of this License or the recipients"
-  rights hereunder. You may choose to offer, and to charge a
-  fee for, warranty, support, indemnity or liability
-  obligations to one or more recipients of Covered Software.
-  However, you may do so only on Your own behalf, and not on
-  behalf of the Initial Developer or any Contributor. You
-  must make it absolutely clear that any such warranty,
-  support, indemnity or liability obligation is offered by
-  You alone, and You hereby agree to indemnify the Initial
-  Developer and every Contributor for any liability incurred
-  by the Initial Developer or such Contributor as a result of
-  warranty, support, indemnity or liability terms You offer.
-      
-  3.5. Distribution of Executable Versions.
-  
-  You may distribute the Executable form of the Covered
-  Software under the terms of this License or under the terms
-  of a license of Your choice, which may contain terms
-  different from this License, provided that You are in
-  compliance with the terms of this License and that the
-  license for the Executable form does not attempt to limit
-  or alter the recipient"s rights in the Source Code form
-  from the rights set forth in this License. If You
-  distribute the Covered Software in Executable form under a
-  different license, You must make it absolutely clear that
-  any terms which differ from this License are offered by You
-  alone, not by the Initial Developer or Contributor. You
-  hereby agree to indemnify the Initial Developer and every
-  Contributor for any liability incurred by the Initial
-  Developer or such Contributor as a result of any such terms
-  You offer.
-  
-  3.6. Larger Works.
-  
-  You may create a Larger Work by combining Covered Software
-  with other code not governed by the terms of this License
-  and distribute the Larger Work as a single product. In such
-  a case, You must make sure the requirements of this License
-  are fulfilled for the Covered Software. 
-  
-  4. Versions of the License. 
-  
-  4.1. New Versions.
-  
-  Sun Microsystems, Inc. is the initial license steward and
-  may publish revised and/or new versions of this License
-  from time to time. Each version will be given a
-  distinguishing version number. Except as provided in
-  Section 4.3, no one other than the license steward has the
-  right to modify this License. 
-  
-  4.2. Effect of New Versions.
-  
-  You may always continue to use, distribute or otherwise
-  make the Covered Software available under the terms of the
-  version of the License under which You originally received
-  the Covered Software. If the Initial Developer includes a
-  notice in the Original Software prohibiting it from being
-  distributed or otherwise made available under any
-  subsequent version of the License, You must distribute and
-  make the Covered Software available under the terms of the
-  version of the License under which You originally received
-  the Covered Software. Otherwise, You may also choose to
-  use, distribute or otherwise make the Covered Software
-  available under the terms of any subsequent version of the
-  License published by the license steward. 
-  
-  4.3. Modified Versions.
-  
-  When You are an Initial Developer and You want to create a
-  new license for Your Original Software, You may create and
-  use a modified version of this License if You: (a) rename
-  the license and remove any references to the name of the
-  license steward (except to note that the license differs
-  from this License); and (b) otherwise make it clear that
-  the license contains terms which differ from this License.
-  
-  5. DISCLAIMER OF WARRANTY.
-  
-  COVERED SOFTWARE IS PROVIDED UNDER THIS LICENSE ON AN "AS IS"
-  BASIS, WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED,
-  INCLUDING, WITHOUT LIMITATION, WARRANTIES THAT THE COVERED
-  SOFTWARE IS FREE OF DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR
-  PURPOSE OR NON-INFRINGING. THE ENTIRE RISK AS TO THE QUALITY AND
-  PERFORMANCE OF THE COVERED SOFTWARE IS WITH YOU. SHOULD ANY
-  COVERED SOFTWARE PROVE DEFECTIVE IN ANY RESPECT, YOU (NOT THE
-  INITIAL DEVELOPER OR ANY OTHER CONTRIBUTOR) ASSUME THE COST OF
-  ANY NECESSARY SERVICING, REPAIR OR CORRECTION. THIS DISCLAIMER OF
-  WARRANTY CONSTITUTES AN ESSENTIAL PART OF THIS LICENSE. NO USE OF
-  ANY COVERED SOFTWARE IS AUTHORIZED HEREUNDER EXCEPT UNDER THIS
-  DISCLAIMER. 
-  
-  6. TERMINATION. 
-  
-  6.1. This License and the rights granted hereunder will
-  terminate automatically if You fail to comply with terms
-  herein and fail to cure such breach within 30 days of
-  becoming aware of the breach. Provisions which, by their
-  nature, must remain in effect beyond the termination of
-  this License shall survive.
-  
-  6.2. If You assert a patent infringement claim (excluding
-  declaratory judgment actions) against Initial Developer or
-  a Contributor (the Initial Developer or Contributor against
-  whom You assert such claim is referred to as "Participant")
-  alleging that the Participant Software (meaning the
-  Contributor Version where the Participant is a Contributor
-  or the Original Software where the Participant is the
-  Initial Developer) directly or indirectly infringes any
-  patent, then any and all rights granted directly or
-  indirectly to You by such Participant, the Initial
-  Developer (if the Initial Developer is not the Participant)
-  and all Contributors under Sections 2.1 and/or 2.2 of this
-  License shall, upon 60 days notice from Participant
-  terminate prospectively and automatically at the expiration
-  of such 60 day notice period, unless if within such 60 day
-  period You withdraw Your claim with respect to the
-  Participant Software against such Participant either
-  unilaterally or pursuant to a written agreement with
-  Participant.
-  
-  6.3. In the event of termination under Sections 6.1 or 6.2
-  above, all end user licenses that have been validly granted
-  by You or any distributor hereunder prior to termination
-  (excluding licenses granted to You by any distributor)
-  shall survive termination.
-  
-  7. LIMITATION OF LIABILITY.
-  
-  UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT
-  (INCLUDING NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE
-  INITIAL DEVELOPER, ANY OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF
-  COVERED SOFTWARE, OR ANY SUPPLIER OF ANY OF SUCH PARTIES, BE
-  LIABLE TO ANY PERSON FOR ANY INDIRECT, SPECIAL, INCIDENTAL, OR
-  CONSEQUENTIAL DAMAGES OF ANY CHARACTER INCLUDING, WITHOUT
-  LIMITATION, DAMAGES FOR LOST PROFITS, LOSS OF GOODWILL, WORK
-  STOPPAGE, COMPUTER FAILURE OR MALFUNCTION, OR ANY AND ALL OTHER
-  COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH PARTY SHALL HAVE BEEN
-  INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS LIMITATION OF
-  LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL
-  INJURY RESULTING FROM SUCH PARTY"S NEGLIGENCE TO THE EXTENT
-  APPLICABLE LAW PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO
-  NOT ALLOW THE EXCLUSION OR LIMITATION OF INCIDENTAL OR
-  CONSEQUENTIAL DAMAGES, SO THIS EXCLUSION AND LIMITATION MAY NOT
-  APPLY TO YOU.
-  
-  8. U.S. GOVERNMENT END USERS.
-  
-  The Covered Software is a "commercial item," as that term is
-  defined in 48 C.F.R. 2.101 (Oct. 1995), consisting of "commercial
-  computer software" (as that term is defined at 48 C.F.R. "
-  252.227-7014(a)(1)) and "commercial computer software
-  documentation" as such terms are used in 48 C.F.R. 12.212 (Sept.
-  1995). Consistent with 48 C.F.R. 12.212 and 48 C.F.R. 227.7202-1
-  through 227.7202-4 (June 1995), all U.S. Government End Users
-  acquire Covered Software with only those rights set forth herein.
-  This U.S. Government Rights clause is in lieu of, and supersedes,
-  any other FAR, DFAR, or other clause or provision that addresses
-  Government rights in computer software under this License.
-  
-  9. MISCELLANEOUS.
-  
-  This License represents the complete agreement concerning subject
-  matter hereof. If any provision of this License is held to be
-  unenforceable, such provision shall be reformed only to the
-  extent necessary to make it enforceable. This License shall be
-  governed by the law of the jurisdiction specified in a notice
-  contained within the Original Software (except to the extent
-  applicable law, if any, provides otherwise), excluding such
-  jurisdiction"s conflict-of-law provisions. Any litigation
-  relating to this License shall be subject to the jurisdiction of
-  the courts located in the jurisdiction and venue specified in a
-  notice contained within the Original Software, with the losing
-  party responsible for costs, including, without limitation, court
-  costs and reasonable attorneys" fees and expenses. The
-  application of the United Nations Convention on Contracts for the
-  International Sale of Goods is expressly excluded. Any law or
-  regulation which provides that the language of a contract shall
-  be construed against the drafter shall not apply to this License.
-  You agree that You alone are responsible for compliance with the
-  United States export administration regulations (and the export
-  control laws and regulation of any other countries) when You use,
-  distribute or otherwise make available any Covered Software.
-  
-  10. RESPONSIBILITY FOR CLAIMS.
-  
-  As between Initial Developer and the Contributors, each party is
-  responsible for claims and damages arising, directly or
-  indirectly, out of its utilization of rights under this License
-  and You agree to work with Initial Developer and Contributors to
-  distribute such responsibility on an equitable basis. Nothing
-  herein is intended or shall be deemed to constitute any admission
-  of liability.
-  
-
-COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.1
-
-  1. Definitions.
-  
-  1.1. “Contributor” means each individual or entity that creates or contributes
-  to the creation of Modifications.
-  
-  1.2. “Contributor Version” means the combination of the Original Software,
-  prior Modifications used by a Contributor (if any), and the Modifications made
-  by that particular Contributor.
-  
-  1.3. “Covered Software” means (a) the Original Software, or (b) Modifications,
-  or (c) the combination of files containing Original Software with files
-  containing Modifications, in each case including portions thereof.
-  
-  1.4. “Executable” means the Covered Software in any form other than Source
-  Code.
-  
-  1.5. “Initial Developer” means the individual or entity that first makes
-  Original Software available under this License.
-  
-  1.6. “Larger Work” means a work which combines Covered Software or portions
-  thereof with code not governed by the terms of this License.
-  
-  1.7. “License” means this document.
-  
-  1.8. “Licensable” means having the right to grant, to the maximum extent
-  possible, whether at the time of the initial grant or subsequently acquired,
-  any and all of the rights conveyed herein.
-  
-  1.9. “Modifications” means the Source Code and Executable form of any of the
-  following:
-  
-  A. Any file that results from an addition to, deletion from or modification of
-  the contents of a file containing Original Software or previous Modifications;
-  
-  B. Any new file that contains any part of the Original Software or previous
-  Modification; or
-  
-  C. Any new file that is contributed or otherwise made available under the terms
-  of this License.
-  
-  1.10. “Original Software” means the Source Code and Executable form of computer
-  software code that is originally released under this License.
-  
-  1.11. “Patent Claims” means any patent claim(s), now owned or hereafter
-  acquired, including without limitation, method, process, and apparatus claims,
-  in any patent Licensable by grantor.
-  
-  1.12. “Source Code” means (a) the common form of computer software code in
-  which modifications are made and (b) associated documentation included in or
-  with such code.
-  
-  1.13. “You” (or “Your”) means an individual or a legal entity exercising rights
-  under, and complying with all of the terms of, this License. For legal
-  entities, “You” includes any entity which controls, is controlled by, or is
-  under common control with You. For purposes of this definition, “control” means
-  (a) the power, direct or indirect, to cause the direction or management of such
-  entity, whether by contract or otherwise, or (b) ownership of more than fifty
-  percent (50%) of the outstanding shares or beneficial ownership of such entity.
-  
-  2. License Grants.
-  
-  2.1. The Initial Developer Grant.  Conditioned upon Your compliance with
-  Section 3.1 below and subject to third party intellectual property claims, the
-  Initial Developer hereby grants You a world-wide, royalty-free, non-exclusive
-  license:
-  
-  (a) under intellectual property rights (other than patent or trademark)
-  Licensable by Initial Developer, to use, reproduce, modify, display, perform,
-  sublicense and distribute the Original Software (or portions thereof), with or
-  without Modifications, and/or as part of a Larger Work; and
-  
-  (b) under Patent Claims infringed by the making, using or selling of Original
-  Software, to make, have made, use, practice, sell, and offer for sale, and/or
-  otherwise dispose of the Original Software (or portions thereof).
-  
-  (c) The licenses granted in Sections 2.1(a) and (b) are effective on the date
-  Initial Developer first distributes or otherwise makes the Original Software
-  available to a third party under the terms of this License.
-  
-  (d) Notwithstanding Section 2.1(b) above, no patent license is granted: (1) for
-  code that You delete from the Original Software, or (2) for infringements
-  caused by: (i) the modification of the Original Software, or (ii) the
-  combination of the Original Software with other software or devices.
-  
-  2.2. Contributor Grant.  Conditioned upon Your compliance with Section 3.1
-  below and subject to third party intellectual property claims, each Contributor
-  hereby grants You a world-wide, royalty-free, non-exclusive license:
-  
-  (a) under intellectual property rights (other than patent or trademark)
-  Licensable by Contributor to use, reproduce, modify, display, perform,
-  sublicense and distribute the Modifications created by such Contributor (or
-  portions thereof), either on an unmodified basis, with other Modifications, as
-  Covered Software and/or as part of a Larger Work; and
-  
-  (b) under Patent Claims infringed by the making, using, or selling of
-  Modifications made by that Contributor either alone and/or in combination with
-  its Contributor Version (or portions of such combination), to make, use, sell,
-  offer for sale, have made, and/or otherwise dispose of: (1) Modifications made
-  by that Contributor (or portions thereof); and (2) the combination of
-  Modifications made by that Contributor with its Contributor Version (or
-  portions of such combination).
-  
-  (c) The licenses granted in Sections 2.2(a) and 2.2(b) are effective on the
-  date Contributor first distributes or otherwise makes the Modifications
-  available to a third party.
-  
-  (d) Notwithstanding Section 2.2(b) above, no patent license is granted: (1) for
-  any code that Contributor has deleted from the Contributor Version; (2) for
-  infringements caused by: (i) third party modifications of Contributor Version,
-  or (ii) the combination of Modifications made by that Contributor with other
-  software (except as part of the Contributor Version) or other devices; or (3)
-  under Patent Claims infringed by Covered Software in the absence of
-  Modifications made by that Contributor.
-  
-  3. Distribution Obligations.
-  
-  3.1. Availability of Source Code.  Any Covered Software that You distribute or
-  otherwise make available in Executable form must also be made available in
-  Source Code form and that Source Code form must be distributed only under the
-  terms of this License. You must include a copy of this License with every copy
-  of the Source Code form of the Covered Software You distribute or otherwise
-  make available. You must inform recipients of any such Covered Software in
-  Executable form as to how they can obtain such Covered Software in Source Code
-  form in a reasonable manner on or through a medium customarily used for
-  software exchange.
-  
-  3.2. Modifications.  The Modifications that You create or to which You
-  contribute are governed by the terms of this License. You represent that You
-  believe Your Modifications are Your original creation(s) and/or You have
-  sufficient rights to grant the rights conveyed by this License.
-  
-  3.3. Required Notices.  You must include a notice in each of Your Modifications
-  that identifies You as the Contributor of the Modification. You may not remove
-  or alter any copyright, patent or trademark notices contained within the
-  Covered Software, or any notices of licensing or any descriptive text giving
-  attribution to any Contributor or the Initial Developer.
-  
-  3.4. Application of Additional Terms.  You may not offer or impose any terms on
-  any Covered Software in Source Code form that alters or restricts the
-  applicable version of this License or the recipients' rights hereunder. You may
-  choose to offer, and to charge a fee for, warranty, support, indemnity or
-  liability obligations to one or more recipients of Covered Software. However,
-  you may do so only on Your own behalf, and not on behalf of the Initial
-  Developer or any Contributor. You must make it absolutely clear that any such
-  warranty, support, indemnity or liability obligation is offered by You alone,
-  and You hereby agree to indemnify the Initial Developer and every Contributor
-  for any liability incurred by the Initial Developer or such Contributor as a
-  result of warranty, support, indemnity or liability terms You offer.
-  
-  3.5. Distribution of Executable Versions.  You may distribute the Executable
-  form of the Covered Software under the terms of this License or under the terms
-  of a license of Your choice, which may contain terms different from this
-  License, provided that You are in compliance with the terms of this License and
-  that the license for the Executable form does not attempt to limit or alter the
-  recipient's rights in the Source Code form from the rights set forth in this
-  License. If You distribute the Covered Software in Executable form under a
-  different license, You must make it absolutely clear that any terms which
-  differ from this License are offered by You alone, not by the Initial Developer
-  or Contributor. You hereby agree to indemnify the Initial Developer and every
-  Contributor for any liability incurred by the Initial Developer or such
-  Contributor as a result of any such terms You offer.
-  
-  3.6. Larger Works.  You may create a Larger Work by combining Covered Software
-  with other code not governed by the terms of this License and distribute the
-  Larger Work as a single product. In such a case, You must make sure the
-  requirements of this License are fulfilled for the Covered Software.
-  
-  4. Versions of the License.
-  
-  4.1. New Versions.  Oracle is the initial license steward and may publish
-  revised and/or new versions of this License from time to time. Each version
-  will be given a distinguishing version number. Except as provided in Section
-  4.3, no one other than the license steward has the right to modify this
-  License.
-  
-  4.2. Effect of New Versions.  You may always continue to use, distribute or
-  otherwise make the Covered Software available under the terms of the version of
-  the License under which You originally received the Covered Software. If the
-  Initial Developer includes a notice in the Original Software prohibiting it
-  from being distributed or otherwise made available under any subsequent version
-  of the License, You must distribute and make the Covered Software available
-  under the terms of the version of the License under which You originally
-  received the Covered Software. Otherwise, You may also choose to use,
-  distribute or otherwise make the Covered Software available under the terms of
-  any subsequent version of the License published by the license steward.
-  
-  4.3. Modified Versions.  When You are an Initial Developer and You want to
-  create a new license for Your Original Software, You may create and use a
-  modified version of this License if You: (a) rename the license and remove any
-  references to the name of the license steward (except to note that the license
-  differs from this License); and (b) otherwise make it clear that the license
-  contains terms which differ from this License.
-  
-  5. DISCLAIMER OF WARRANTY.  COVERED SOFTWARE IS PROVIDED UNDER THIS LICENSE ON
-  AN “AS IS” BASIS, WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED,
-  INCLUDING, WITHOUT LIMITATION, WARRANTIES THAT THE COVERED SOFTWARE IS FREE OF
-  DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR PURPOSE OR NON-INFRINGING. THE
-  ENTIRE RISK AS TO THE QUALITY AND PERFORMANCE OF THE COVERED SOFTWARE IS WITH
-  YOU. SHOULD ANY COVERED SOFTWARE PROVE DEFECTIVE IN ANY RESPECT, YOU (NOT THE
-  INITIAL DEVELOPER OR ANY OTHER CONTRIBUTOR) ASSUME THE COST OF ANY NECESSARY
-  SERVICING, REPAIR OR CORRECTION. THIS DISCLAIMER OF WARRANTY CONSTITUTES AN
-  ESSENTIAL PART OF THIS LICENSE. NO USE OF ANY COVERED SOFTWARE IS AUTHORIZED
-  HEREUNDER EXCEPT UNDER THIS DISCLAIMER.
-  
-  6. TERMINATION.
-  
-  6.1. This License and the rights granted hereunder will terminate automatically
-  if You fail to comply with terms herein and fail to cure such breach within 30
-  days of becoming aware of the breach. Provisions which, by their nature, must
-  remain in effect beyond the termination of this License shall survive.
-  
-  6.2. If You assert a patent infringement claim (excluding declaratory judgment
-  actions) against Initial Developer or a Contributor (the Initial Developer or
-  Contributor against whom You assert such claim is referred to as “Participant”)
-  alleging that the Participant Software (meaning the Contributor Version where
-  the Participant is a Contributor or the Original Software where the Participant
-  is the Initial Developer) directly or indirectly infringes any patent, then any
-  and all rights granted directly or indirectly to You by such Participant, the
-  Initial Developer (if the Initial Developer is not the Participant) and all
-  Contributors under Sections 2.1 and/or 2.2 of this License shall, upon 60 days
-  notice from Participant terminate prospectively and automatically at the
-  expiration of such 60 day notice period, unless if within such 60 day period
-  You withdraw Your claim with respect to the Participant Software against such
-  Participant either unilaterally or pursuant to a written agreement with
-  Participant.
-  
-  6.3. If You assert a patent infringement claim against Participant alleging
-  that the Participant Software directly or indirectly infringes any patent where
-  such claim is resolved (such as by license or settlement) prior to the
-  initiation of patent infringement litigation, then the reasonable value of the
-  licenses granted by such Participant under Sections 2.1 or 2.2 shall be taken
-  into account in determining the amount or value of any payment or license.
-  
-  6.4. In the event of termination under Sections 6.1 or 6.2 above, all end user
-  licenses that have been validly granted by You or any distributor hereunder
-  prior to termination (excluding licenses granted to You by any distributor)
-  shall survive termination.
-  
-  7. LIMITATION OF LIABILITY.
-  
-  UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT (INCLUDING
-  NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE INITIAL DEVELOPER, ANY
-  OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF COVERED SOFTWARE, OR ANY SUPPLIER OF
-  ANY OF SUCH PARTIES, BE LIABLE TO ANY PERSON FOR ANY INDIRECT, SPECIAL,
-  INCIDENTAL, OR CONSEQUENTIAL DAMAGES OF ANY CHARACTER INCLUDING, WITHOUT
-  LIMITATION, DAMAGES FOR LOSS OF GOODWILL, WORK STOPPAGE, COMPUTER FAILURE OR
-  MALFUNCTION, OR ANY AND ALL OTHER COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH
-  PARTY SHALL HAVE BEEN INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS
-  LIMITATION OF LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL
-  INJURY RESULTING FROM SUCH PARTY'S NEGLIGENCE TO THE EXTENT APPLICABLE LAW
-  PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO NOT ALLOW THE EXCLUSION OR
-  LIMITATION OF INCIDENTAL OR CONSEQUENTIAL DAMAGES, SO THIS EXCLUSION AND
-  LIMITATION MAY NOT APPLY TO YOU.
-  
-  8. U.S. GOVERNMENT END USERS.
-  
-  The Covered Software is a “commercial item,” as that term is defined in 48
-  C.F.R. 2.101 (Oct. 1995), consisting of “commercial computer software” (as that
-  term is defined at 48 C.F.R. § 252.227-7014(a)(1)) and “commercial computer
-  software documentation” as such terms are used in 48 C.F.R. 12.212 (Sept.
-  1995). Consistent with 48 C.F.R. 12.212 and 48 C.F.R. 227.7202-1 through
-  227.7202-4 (June 1995), all U.S. Government End Users acquire Covered Software
-  with only those rights set forth herein. This U.S. Government Rights clause is
-  in lieu of, and supersedes, any other FAR, DFAR, or other clause or provision
-  that addresses Government rights in computer software under this License.
-  
-  9. MISCELLANEOUS.
-  
-  This License represents the complete agreement concerning subject matter
-  hereof. If any provision of this License is held to be unenforceable, such
-  provision shall be reformed only to the extent necessary to make it
-  enforceable. This License shall be governed by the law of the jurisdiction
-  specified in a notice contained within the Original Software (except to the
-  extent applicable law, if any, provides otherwise), excluding such
-  jurisdiction's conflict-of-law provisions. Any litigation relating to this
-  License shall be subject to the jurisdiction of the courts located in the
-  jurisdiction and venue specified in a notice contained within the Original
-  Software, with the losing party responsible for costs, including, without
-  limitation, court costs and reasonable attorneys' fees and expenses. The
-  application of the United Nations Convention on Contracts for the International
-  Sale of Goods is expressly excluded. Any law or regulation which provides that
-  the language of a contract shall be construed against the drafter shall not
-  apply to this License. You agree that You alone are responsible for compliance
-  with the United States export administration regulations (and the export
-  control laws and regulation of any other countries) when You use, distribute or
-  otherwise make available any Covered Software.
-  
-  10. RESPONSIBILITY FOR CLAIMS.
-  
-  As between Initial Developer and the Contributors, each party is responsible
-  for claims and damages arising, directly or indirectly, out of its utilization
-  of rights under this License and You agree to work with Initial Developer and
-  Contributors to distribute such responsibility on an equitable basis. Nothing
-  herein is intended or shall be deemed to constitute any admission of liability.
-  
-  NOTICE PURSUANT TO SECTION 9 OF THE COMMON DEVELOPMENT AND DISTRIBUTION LICENSE
-  (CDDL) The code released under the CDDL shall be governed by the laws of the
-  State of California (excluding conflict-of-law provisions). Any litigation
-  relating to this License shall be subject to the jurisdiction of the Federal
-  Courts of the Northern District of California and the state courts of the State
-  of California, with venue lying in Santa Clara County, California.
-
-
-Eclipse Public License, version 1.0
-
-  THE ACCOMPANYING PROGRAM IS PROVIDED UNDER THE TERMS OF THIS ECLIPSE PUBLIC
-  LICENSE ("AGREEMENT"). ANY USE, REPRODUCTION OR DISTRIBUTION OF THE PROGRAM
-  CONSTITUTES RECIPIENT'S ACCEPTANCE OF THIS AGREEMENT.
-  
-  1. DEFINITIONS
-  
-  "Contribution" means:
-  
-  

<TRUNCATED>

[15/51] [abbrv] brooklyn-dist git commit: [SERVER] [LIBRARY] [DIST] multiple pom updates to pull brooklyn-parent via relative path to brooklyn-server repo, added dist and a root pom to build the all modules that are built in the pre-split incubator-brook

Posted by he...@apache.org.
[SERVER] [LIBRARY] [DIST] multiple pom updates to pull brooklyn-parent via relative path to brooklyn-server repo, added dist and a root pom to build the all modules that are built in the pre-split incubator-brooklyn repo

Conflicts:
	pom.xml - versions removed in root, hazelcast version updated in PR's; new version applied to server/library poms


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

Branch: refs/heads/master
Commit: d0a6e705a48b409c878eb4dee4f8b7de0280d397
Parents: 74877b1
Author: John McCabe <jo...@johnmccabe.net>
Authored: Thu Dec 17 18:14:41 2015 +0000
Committer: Alex Heneveld <al...@cloudsoftcorp.com>
Committed: Mon Dec 21 16:43:36 2015 +0000

----------------------------------------------------------------------
 brooklyn-dist/all/pom.xml                       |  4 +-
 brooklyn-dist/archetypes/quickstart/pom.xml     |  4 +-
 .../quickstart/src/brooklyn-sample/pom.xml      |  1 +
 brooklyn-dist/dist/pom.xml                      |  4 +-
 brooklyn-dist/downstream-parent/pom.xml         |  4 +-
 brooklyn-dist/pom.xml                           | 82 ++++++++++++++++++++
 6 files changed, 91 insertions(+), 8 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/d0a6e705/brooklyn-dist/all/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/all/pom.xml b/brooklyn-dist/all/pom.xml
index c257f0e..46397b1 100644
--- a/brooklyn-dist/all/pom.xml
+++ b/brooklyn-dist/all/pom.xml
@@ -30,9 +30,9 @@
 
     <parent>
         <groupId>org.apache.brooklyn</groupId>
-        <artifactId>brooklyn-parent</artifactId>
+        <artifactId>brooklyn-dist-root</artifactId>
         <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-        <relativePath>../../parent/pom.xml</relativePath>
+        <relativePath>../pom.xml</relativePath>
     </parent>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/d0a6e705/brooklyn-dist/archetypes/quickstart/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/pom.xml b/brooklyn-dist/archetypes/quickstart/pom.xml
index 1594181..39adbdd 100644
--- a/brooklyn-dist/archetypes/quickstart/pom.xml
+++ b/brooklyn-dist/archetypes/quickstart/pom.xml
@@ -30,9 +30,9 @@
 
   <parent>
     <groupId>org.apache.brooklyn</groupId>
-    <artifactId>brooklyn-parent</artifactId>
+    <artifactId>brooklyn-dist-root</artifactId>
     <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-    <relativePath>../../../parent/pom.xml</relativePath>
+    <relativePath>../../pom.xml</relativePath>
   </parent>
 
   <build>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/d0a6e705/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
index f879498..d1559a8 100644
--- a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
+++ b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
@@ -8,6 +8,7 @@
     <groupId>org.apache.brooklyn</groupId>
     <artifactId>brooklyn-downstream-parent</artifactId>
     <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+    <relativePath>../../../../downstream-parent/pom.xml</relativePath>
   </parent>
 
   <groupId>com.acme.sample</groupId>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/d0a6e705/brooklyn-dist/dist/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/pom.xml b/brooklyn-dist/dist/pom.xml
index eda7daf..abc6522 100644
--- a/brooklyn-dist/dist/pom.xml
+++ b/brooklyn-dist/dist/pom.xml
@@ -31,9 +31,9 @@
 
     <parent>
         <groupId>org.apache.brooklyn</groupId>
-        <artifactId>brooklyn-parent</artifactId>
+        <artifactId>brooklyn-dist-root</artifactId>
         <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-        <relativePath>../../parent/pom.xml</relativePath>
+        <relativePath>../pom.xml</relativePath>
     </parent>
 
     <dependencies>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/d0a6e705/brooklyn-dist/downstream-parent/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/downstream-parent/pom.xml b/brooklyn-dist/downstream-parent/pom.xml
index 027c1bf..e8f4fe0 100644
--- a/brooklyn-dist/downstream-parent/pom.xml
+++ b/brooklyn-dist/downstream-parent/pom.xml
@@ -22,9 +22,9 @@
 
   <parent>
     <groupId>org.apache.brooklyn</groupId>
-    <artifactId>brooklyn</artifactId>
+    <artifactId>brooklyn-dist-root</artifactId>
     <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-    <relativePath>../../pom.xml</relativePath>
+    <relativePath>../pom.xml</relativePath>
   </parent>
 
   <artifactId>brooklyn-downstream-parent</artifactId>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/d0a6e705/brooklyn-dist/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/pom.xml b/brooklyn-dist/pom.xml
new file mode 100644
index 0000000..904a20e
--- /dev/null
+++ b/brooklyn-dist/pom.xml
@@ -0,0 +1,82 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+	xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+
+    <modelVersion>4.0.0</modelVersion>
+    <parent>
+        <groupId>org.apache.brooklyn</groupId>
+        <artifactId>brooklyn-parent</artifactId>
+        <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+        <relativePath>../brooklyn-server/parent/pom.xml</relativePath>
+    </parent>
+
+    <groupId>org.apache.brooklyn</groupId>
+    <artifactId>brooklyn-dist-root</artifactId>
+    <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+    <packaging>pom</packaging>
+
+    <name>Brooklyn Dist Root</name>
+    <description>
+        Brooklyn Dist project root, serving as the ancestor POM for dist projects --
+        declaring modules to build
+    </description>
+    <url>https://brooklyn.apache.org/</url>
+    <inceptionYear>2012</inceptionYear>
+
+    <developers>
+        <!-- TODO update with PMC members and committers -->
+    </developers>
+
+    <scm>
+        <connection>scm:git:https://git-wip-us.apache.org/repos/asf/incubator-brooklyn.git</connection>
+        <developerConnection>scm:git:https://git-wip-us.apache.org/repos/asf/incubator-brooklyn.git</developerConnection>
+        <url>https://git-wip-us.apache.org/repos/asf?p=incubator-brooklyn.git</url>
+        <tag>HEAD</tag>
+    </scm>
+
+    <issueManagement>
+        <system>JIRA</system>
+        <url>https://issues.apache.org/jira/browse/BROOKLYN</url>
+    </issueManagement>
+    <ciManagement>
+        <system>Jenkins</system>
+        <url>https://builds.apache.org/job/incubator-brooklyn-master-build/</url>
+    </ciManagement>
+    <mailingLists>
+        <mailingList>
+            <name>Brooklyn Developer List</name>
+            <subscribe>dev-subscribe@brooklyn.apache.org</subscribe>
+            <unsubscribe>dev-unsubscribe@brooklyn.apache.org</unsubscribe>
+            <post>dev@brooklyn.apache.org</post>
+            <archive>
+                http://mail-archives.apache.org/mod_mbox/brooklyn-dev/
+            </archive>
+        </mailingList>
+    </mailingLists>
+
+    <modules>
+        <module>downstream-parent</module>
+        <module>archetypes/quickstart</module>
+        <module>all</module>
+        <module>dist</module>
+    </modules>
+
+</project>


[36/51] [abbrv] brooklyn-dist git commit: This closes #1170

Posted by he...@apache.org.
This closes #1170


Project: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/repo
Commit: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/commit/2e1e1ff0
Tree: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/tree/2e1e1ff0
Diff: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/diff/2e1e1ff0

Branch: refs/heads/master
Commit: 2e1e1ff0fa0a14c131a12841615c3a18e23f3ddf
Parents: 61128a9 8832771
Author: Alex Heneveld <al...@cloudsoftcorp.com>
Authored: Sat Jan 30 02:31:35 2016 +0000
Committer: Alex Heneveld <al...@cloudsoftcorp.com>
Committed: Sat Jan 30 02:31:35 2016 +0000

----------------------------------------------------------------------
 brooklyn-dist/.gitignore                        |  1 +
 brooklyn-dist/pom.xml                           |  1 +
 brooklyn-dist/release/make-release-artifacts.sh | 24 ++++-
 brooklyn-dist/vagrant/pom.xml                   | 83 ++++++++++++++++++
 .../src/main/config/build-distribution.xml      | 33 +++++++
 .../vagrant/src/main/vagrant/README.md          | 41 +++++++++
 .../vagrant/src/main/vagrant/Vagrantfile        | 76 ++++++++++++++++
 .../src/main/vagrant/files/brooklyn.properties  | 23 +++++
 .../src/main/vagrant/files/brooklyn.service     | 32 +++++++
 .../src/main/vagrant/files/install_brooklyn.sh  | 92 ++++++++++++++++++++
 .../vagrant/src/main/vagrant/files/logback.xml  | 32 +++++++
 .../src/main/vagrant/files/vagrant-catalog.bom  | 82 +++++++++++++++++
 .../vagrant/src/main/vagrant/servers.yaml       | 73 ++++++++++++++++
 13 files changed, 589 insertions(+), 4 deletions(-)
----------------------------------------------------------------------



[27/51] [abbrv] brooklyn-dist git commit: add apache-brooklyn-VER-vagrant release artifact

Posted by he...@apache.org.
add apache-brooklyn-VER-vagrant release artifact


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

Branch: refs/heads/master
Commit: fbdd2f77b8b23cc56ceba11c2a8183092b6c250d
Parents: d09c945
Author: John McCabe <jo...@johnmccabe.net>
Authored: Thu Jan 21 18:49:31 2016 +0000
Committer: John McCabe <jo...@johnmccabe.net>
Committed: Thu Jan 21 18:49:31 2016 +0000

----------------------------------------------------------------------
 brooklyn-dist/release/make-release-artifacts.sh | 14 ++++++++++++++
 1 file changed, 14 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/fbdd2f77/brooklyn-dist/release/make-release-artifacts.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/make-release-artifacts.sh b/brooklyn-dist/release/make-release-artifacts.sh
index dfdd976..90f138e 100755
--- a/brooklyn-dist/release/make-release-artifacts.sh
+++ b/brooklyn-dist/release/make-release-artifacts.sh
@@ -21,6 +21,7 @@
 # Creates the following releases with archives (.tar.gz/.zip), signatures and checksums:
 #   binary  (-bin)     - contains the brooklyn dist binary release
 #   source  (-src)     - contains all the source code files that are permitted to be released
+#   vagrant (-vagrant) - contains a Vagrantfile/scripts to start a Brooklyn getting started environment
 
 set -e
 
@@ -222,6 +223,19 @@ mv ${bin_staging_dir}/brooklyn-dist-${current_version} ${bin_staging_dir}/${rele
 ( cd ${bin_staging_dir} && zip -qr ${artifact_dir}/${artifact_name}-bin.zip ${release_name}-bin )
 
 ###############################################################################
+# Vagrant release
+set +x
+echo "Proceeding to rename and repackage vagrant environment release"
+set -x
+
+# Re-pack the archive with the correct names
+tar xzf ${src_staging_dir}/brooklyn-dist/vagrant/target/brooklyn-vagrant-${current_version}-dist.tar.gz -C ${bin_staging_dir}
+mv ${bin_staging_dir}/brooklyn-vagrant-${current_version} ${bin_staging_dir}/${release_name}-vagrant
+
+( cd ${bin_staging_dir} && tar czf ${artifact_dir}/${artifact_name}-vagrant.tar.gz ${release_name}-vagrant )
+( cd ${bin_staging_dir} && zip -qr ${artifact_dir}/${artifact_name}-vagrant.zip ${release_name}-vagrant )
+
+###############################################################################
 # Signatures and checksums
 
 # OSX doesn't have sha256sum, even if MacPorts md5sha1sum package is installed.


[51/51] [abbrv] brooklyn-dist git commit: move subdir from incubator up a level as it is promoted to its own repo (first non-incubator commit!)

Posted by he...@apache.org.
move subdir from incubator up a level as it is promoted to its own repo (first non-incubator commit!)


Project: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/repo
Commit: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/commit/26c4604c
Tree: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/tree/26c4604c
Diff: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/diff/26c4604c

Branch: refs/heads/master
Commit: 26c4604ca41d5b79829d595235b4fdc45b28aba9
Parents: e8c23d3
Author: Alex Heneveld <al...@cloudsoftcorp.com>
Authored: Sat Jan 30 12:59:53 2016 +0000
Committer: Alex Heneveld <al...@cloudsoftcorp.com>
Committed: Sat Jan 30 12:59:53 2016 +0000

----------------------------------------------------------------------
 .gitignore                                      |    1 +
 README.md                                       |    8 +
 all/pom.xml                                     |  117 +
 archetypes/quickstart/NOTES.txt                 |   76 +
 archetypes/quickstart/pom.xml                   |  232 ++
 .../quickstart/src/brooklyn-sample/README.md    |   73 +
 .../quickstart/src/brooklyn-sample/pom.xml      |  102 +
 .../src/main/assembly/assembly.xml              |   88 +
 .../src/main/assembly/files/README.txt          |   96 +
 .../src/main/assembly/files/conf/logback.xml    |   11 +
 .../src/main/assembly/scripts/start.sh          |   40 +
 .../com/acme/sample/brooklyn/SampleMain.java    |   81 +
 .../app/ClusterWebServerDatabaseSample.java     |  137 ++
 .../sample/app/SingleWebServerSample.java       |   32 +
 .../src/main/resources/logback-custom.xml       |   10 +
 .../src/main/resources/sample-icon.png          |  Bin 0 -> 46490 bytes
 .../main/resources/visitors-creation-script.sql |   35 +
 .../app/SampleLocalhostIntegrationTest.java     |   81 +
 .../brooklyn/sample/app/SampleUnitTest.java     |   69 +
 .../quickstart/src/main/resources/.gitignore    |    1 +
 .../META-INF/maven/archetype-metadata.xml       |   65 +
 .../projects/integration-test-1/.gitignore      |    1 +
 .../integration-test-1/archetype.properties     |   22 +
 .../projects/integration-test-1/goal.txt        |    1 +
 brooklyn-dist/.gitattributes                    |    6 -
 brooklyn-dist/.gitignore                        |   33 -
 brooklyn-dist/LICENSE                           |  455 ----
 brooklyn-dist/NOTICE                            |    5 -
 brooklyn-dist/README.md                         |    8 -
 brooklyn-dist/all/pom.xml                       |  117 -
 brooklyn-dist/archetypes/quickstart/NOTES.txt   |   76 -
 brooklyn-dist/archetypes/quickstart/pom.xml     |  232 --
 .../quickstart/src/brooklyn-sample/README.md    |   73 -
 .../quickstart/src/brooklyn-sample/pom.xml      |  102 -
 .../src/main/assembly/assembly.xml              |   88 -
 .../src/main/assembly/files/README.txt          |   96 -
 .../src/main/assembly/files/conf/logback.xml    |   11 -
 .../src/main/assembly/scripts/start.sh          |   40 -
 .../com/acme/sample/brooklyn/SampleMain.java    |   81 -
 .../app/ClusterWebServerDatabaseSample.java     |  137 --
 .../sample/app/SingleWebServerSample.java       |   32 -
 .../src/main/resources/logback-custom.xml       |   10 -
 .../src/main/resources/sample-icon.png          |  Bin 46490 -> 0 bytes
 .../main/resources/visitors-creation-script.sql |   35 -
 .../app/SampleLocalhostIntegrationTest.java     |   81 -
 .../brooklyn/sample/app/SampleUnitTest.java     |   69 -
 .../quickstart/src/main/resources/.gitignore    |    1 -
 .../META-INF/maven/archetype-metadata.xml       |   65 -
 .../projects/integration-test-1/.gitignore      |    1 -
 .../integration-test-1/archetype.properties     |   22 -
 .../projects/integration-test-1/goal.txt        |    1 -
 brooklyn-dist/dist/licensing/.gitignore         |    2 -
 brooklyn-dist/dist/licensing/MAIN_LICENSE_ASL2  |  176 --
 brooklyn-dist/dist/licensing/README.md          |   78 -
 brooklyn-dist/dist/licensing/extras-files       |    1 -
 .../dist/licensing/licenses/binary/ASL2         |  177 --
 .../dist/licensing/licenses/binary/BSD-2-Clause |   23 -
 .../dist/licensing/licenses/binary/BSD-3-Clause |   27 -
 .../dist/licensing/licenses/binary/CDDL1        |  381 ---
 .../dist/licensing/licenses/binary/CDDL1.1      |  304 ---
 .../dist/licensing/licenses/binary/EPL1         |  212 --
 .../dist/licensing/licenses/binary/MIT          |   20 -
 .../dist/licensing/licenses/binary/WTFPL        |   15 -
 .../dist/licensing/licenses/binary/bouncycastle |   23 -
 .../dist/licensing/licenses/binary/jtidy        |   53 -
 .../dist/licensing/licenses/binary/jython       |   27 -
 .../licenses/binary/metastuff-bsd-style         |   43 -
 .../licenses/binary/xpp3_indiana_university     |   45 -
 .../licensing/licenses/brooklyn-ui/BSD-2-Clause |   23 -
 .../licensing/licenses/brooklyn-ui/BSD-3-Clause |   27 -
 .../dist/licensing/licenses/brooklyn-ui/MIT     |   20 -
 .../dist/licensing/licenses/server-cli/MIT      |   20 -
 .../dist/licensing/licenses/source/BSD-2-Clause |   23 -
 .../dist/licensing/licenses/source/BSD-3-Clause |   27 -
 .../dist/licensing/licenses/source/MIT          |   20 -
 .../dist/licensing/make-all-licenses.sh         |   65 -
 .../dist/licensing/make-one-license.sh          |   79 -
 brooklyn-dist/dist/licensing/overrides.yaml     |  385 ----
 .../licensing/projects-with-custom-licenses     |    2 -
 brooklyn-dist/dist/pom.xml                      |  159 --
 .../dist/src/main/config/build-distribution.xml |   95 -
 brooklyn-dist/dist/src/main/dist/README.md      |   17 -
 .../dist/src/main/dist/bin/.gitattributes       |    3 -
 brooklyn-dist/dist/src/main/dist/bin/brooklyn   |   51 -
 .../dist/src/main/dist/bin/brooklyn.bat         |  111 -
 .../dist/src/main/dist/bin/brooklyn.ps1         |  135 --
 .../dist/src/main/dist/conf/logback.xml         |   14 -
 brooklyn-dist/dist/src/main/license/README.md   |    2 -
 .../dist/src/main/license/files/DISCLAIMER      |    8 -
 .../dist/src/main/license/files/LICENSE         | 2169 ------------------
 .../dist/src/main/license/files/NOTICE          |    5 -
 .../brooklyn/cli/BaseCliIntegrationTest.java    |  189 --
 .../apache/brooklyn/cli/CliIntegrationTest.java |  219 --
 brooklyn-dist/downstream-parent/pom.xml         |  524 -----
 brooklyn-dist/pom.xml                           |   83 -
 brooklyn-dist/release/.gitignore                |    2 -
 brooklyn-dist/release/README.md                 |   50 -
 brooklyn-dist/release/Vagrantfile               |   66 -
 brooklyn-dist/release/change-version.sh         |   70 -
 brooklyn-dist/release/gpg-agent.conf            |    2 -
 brooklyn-dist/release/make-release-artifacts.sh |  273 ---
 brooklyn-dist/release/print-vote-email.sh       |  130 --
 .../release/pull-request-reports/Gemfile        |    5 -
 .../release/pull-request-reports/Gemfile.lock   |   38 -
 .../release/pull-request-reports/pr_report.rb   |   12 -
 brooklyn-dist/release/settings.xml              |   29 -
 brooklyn-dist/scripts/buildAndTest              |  102 -
 brooklyn-dist/scripts/grep-in-poms.sh           |   25 -
 .../scripts/release-branch-from-master          |  114 -
 brooklyn-dist/scripts/release-make              |   83 -
 brooklyn-dist/vagrant/pom.xml                   |   83 -
 .../src/main/config/build-distribution.xml      |   33 -
 .../vagrant/src/main/vagrant/README.md          |   41 -
 .../vagrant/src/main/vagrant/Vagrantfile        |   76 -
 .../src/main/vagrant/files/brooklyn.properties  |   23 -
 .../src/main/vagrant/files/brooklyn.service     |   32 -
 .../src/main/vagrant/files/install_brooklyn.sh  |   92 -
 .../vagrant/src/main/vagrant/files/logback.xml  |   32 -
 .../src/main/vagrant/files/vagrant-catalog.bom  |   82 -
 .../vagrant/src/main/vagrant/servers.yaml       |   73 -
 dist/licensing/.gitignore                       |    2 +
 dist/licensing/MAIN_LICENSE_ASL2                |  176 ++
 dist/licensing/README.md                        |   78 +
 dist/licensing/extras-files                     |    1 +
 dist/licensing/licenses/binary/ASL2             |  177 ++
 dist/licensing/licenses/binary/BSD-2-Clause     |   23 +
 dist/licensing/licenses/binary/BSD-3-Clause     |   27 +
 dist/licensing/licenses/binary/CDDL1            |  381 +++
 dist/licensing/licenses/binary/CDDL1.1          |  304 +++
 dist/licensing/licenses/binary/EPL1             |  212 ++
 dist/licensing/licenses/binary/MIT              |   20 +
 dist/licensing/licenses/binary/WTFPL            |   15 +
 dist/licensing/licenses/binary/bouncycastle     |   23 +
 dist/licensing/licenses/binary/jtidy            |   53 +
 dist/licensing/licenses/binary/jython           |   27 +
 .../licenses/binary/metastuff-bsd-style         |   43 +
 .../licenses/binary/xpp3_indiana_university     |   45 +
 .../licensing/licenses/brooklyn-ui/BSD-2-Clause |   23 +
 .../licensing/licenses/brooklyn-ui/BSD-3-Clause |   27 +
 dist/licensing/licenses/brooklyn-ui/MIT         |   20 +
 dist/licensing/licenses/server-cli/MIT          |   20 +
 dist/licensing/licenses/source/BSD-2-Clause     |   23 +
 dist/licensing/licenses/source/BSD-3-Clause     |   27 +
 dist/licensing/licenses/source/MIT              |   20 +
 dist/licensing/make-all-licenses.sh             |   65 +
 dist/licensing/make-one-license.sh              |   79 +
 dist/licensing/overrides.yaml                   |  385 ++++
 dist/licensing/projects-with-custom-licenses    |    2 +
 dist/pom.xml                                    |  159 ++
 dist/src/main/config/build-distribution.xml     |   95 +
 dist/src/main/dist/README.md                    |   17 +
 dist/src/main/dist/bin/.gitattributes           |    3 +
 dist/src/main/dist/bin/brooklyn                 |   51 +
 dist/src/main/dist/bin/brooklyn.bat             |  111 +
 dist/src/main/dist/bin/brooklyn.ps1             |  135 ++
 dist/src/main/dist/conf/logback.xml             |   14 +
 dist/src/main/license/README.md                 |    2 +
 dist/src/main/license/files/DISCLAIMER          |    8 +
 dist/src/main/license/files/LICENSE             | 2169 ++++++++++++++++++
 dist/src/main/license/files/NOTICE              |    5 +
 .../brooklyn/cli/BaseCliIntegrationTest.java    |  189 ++
 .../apache/brooklyn/cli/CliIntegrationTest.java |  219 ++
 downstream-parent/pom.xml                       |  524 +++++
 pom.xml                                         |   83 +
 release/.gitignore                              |    2 +
 release/README.md                               |   50 +
 release/Vagrantfile                             |   66 +
 release/change-version.sh                       |   70 +
 release/gpg-agent.conf                          |    2 +
 release/make-release-artifacts.sh               |  273 +++
 release/print-vote-email.sh                     |  130 ++
 release/pull-request-reports/Gemfile            |    5 +
 release/pull-request-reports/Gemfile.lock       |   38 +
 release/pull-request-reports/pr_report.rb       |   12 +
 release/settings.xml                            |   29 +
 scripts/buildAndTest                            |  102 +
 scripts/grep-in-poms.sh                         |   25 +
 scripts/release-branch-from-master              |  114 +
 scripts/release-make                            |   83 +
 vagrant/pom.xml                                 |   83 +
 vagrant/src/main/config/build-distribution.xml  |   33 +
 vagrant/src/main/vagrant/README.md              |   41 +
 vagrant/src/main/vagrant/Vagrantfile            |   76 +
 .../src/main/vagrant/files/brooklyn.properties  |   23 +
 vagrant/src/main/vagrant/files/brooklyn.service |   32 +
 .../src/main/vagrant/files/install_brooklyn.sh  |   92 +
 vagrant/src/main/vagrant/files/logback.xml      |   32 +
 .../src/main/vagrant/files/vagrant-catalog.bom  |   82 +
 vagrant/src/main/vagrant/servers.yaml           |   73 +
 189 files changed, 9029 insertions(+), 9527 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/.gitignore
----------------------------------------------------------------------
diff --git a/.gitignore b/.gitignore
index ed439f2..2ef22e4 100644
--- a/.gitignore
+++ b/.gitignore
@@ -28,5 +28,6 @@ prodDb.*
 brooklyn*.log.*
 
 *brooklyn-persisted-state/
+*.vagrant/
 
 ignored

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/README.md
----------------------------------------------------------------------
diff --git a/README.md b/README.md
new file mode 100644
index 0000000..0b34dc4
--- /dev/null
+++ b/README.md
@@ -0,0 +1,8 @@
+
+# [![**Brooklyn**](https://brooklyn.apache.org/style/img/apache-brooklyn-logo-244px-wide.png)](http://brooklyn.apache.org/)
+
+### Distribution Sub-Project for Apache Brooklyn
+
+This repo contains modules for creating the distributable binary
+combining the `server`, the `ui`, and other elements in other Brooklyn repos.
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/all/pom.xml
----------------------------------------------------------------------
diff --git a/all/pom.xml b/all/pom.xml
new file mode 100644
index 0000000..bcaa758
--- /dev/null
+++ b/all/pom.xml
@@ -0,0 +1,117 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+    
+     http://www.apache.org/licenses/LICENSE-2.0
+    
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+    <modelVersion>4.0.0</modelVersion>
+    <packaging>jar</packaging>
+
+    <artifactId>brooklyn-all</artifactId>
+
+    <name>Brooklyn All Things</name>
+    <description>
+        A meta-dependency for all the major Brooklyn modules.
+    </description>
+
+    <parent>
+        <groupId>org.apache.brooklyn</groupId>
+        <artifactId>brooklyn-dist-root</artifactId>
+        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+        <relativePath>../pom.xml</relativePath>
+    </parent>
+
+    <dependencies>
+        <dependency>
+            <groupId>com.google.guava</groupId>
+            <artifactId>guava</artifactId>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-policy</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-locations-jclouds</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-software-webapp</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-software-messaging</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-software-monitoring</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-software-database</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-software-osgi</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-software-nosql</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-software-network</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-launcher</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-cli</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-test-framework</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+
+        <!-- bring in all jclouds-supported cloud providers -->
+        <dependency>
+            <groupId>${jclouds.groupId}</groupId>
+            <artifactId>jclouds-allcompute</artifactId>
+        </dependency>
+    </dependencies>
+
+</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/NOTES.txt
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/NOTES.txt b/archetypes/quickstart/NOTES.txt
new file mode 100644
index 0000000..4028bf6
--- /dev/null
+++ b/archetypes/quickstart/NOTES.txt
@@ -0,0 +1,76 @@
+
+This file contains notes for anyone working on the archetype.
+
+
+Some things to keep in mind:
+
+* The sample project in `src/brooklyn-sample` is what populates the
+  archetype source (in `src/main/resources/archetype-resources`, 
+  copied there by the `pom.xml` in this directory, in `clean` phase).
+  (You can open and edit it in your IDE.)
+  
+* That archetype source then becomes the archetype (in `install` phase)
+  according to the copy and filter rules in `src/main/resources/META-INF/maven/archetype-metadata.xml`
+
+* For any changes to the project:
+
+  * ensure `brooklyn-sample` builds as you would like
+  * ensure the resulting archetype builds as you would like
+    (should be reasonably safe and automated, but check that the 2 sets of 
+    copy/translation rules above do what you intended!)
+  * update the `README.*` files in the root of `brooklyn-sample` and the
+    `src/main/assembly/files` within that
+  * update the docs under `use/guide/defining-applications/archetype.md` and `use/guide/quickstart/index.md`
+
+
+To build:
+
+    mvn clean install
+
+
+To test a build:
+
+    pushd /tmp
+    rm -rf brooklyn-sample
+    export BV=0.9.0-SNAPSHOT    # BROOKLYN_VERSION
+    
+    mvn archetype:generate                                  \
+                                                            \
+      -DarchetypeGroupId=org.apache.brooklyn                \
+      -DarchetypeArtifactId=brooklyn-archetype-quickstart   \
+      -DarchetypeVersion=${BV} \
+      \
+      -DgroupId=com.acme.sample                             \
+      -DartifactId=brooklyn-sample                          \
+      -Dversion=0.1.0-SNAPSHOT                              \
+      -Dpackage=com.acme.sample.brooklyn                    \
+      \
+      --batch-mode
+    
+    cd brooklyn-sample
+    mvn clean assembly:assembly
+    cd target/brooklyn-sample-0.1.0-SNAPSHOT-dist/brooklyn-sample-0.1.0-SNAPSHOT/
+    ./start.sh launch --cluster --location localhost
+
+
+References
+
+ * http://stackoverflow.com/questions/4082643/how-can-i-test-a-maven-archetype-that-ive-just-created/18916065#18916065
+
+----
+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.

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/pom.xml
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/pom.xml b/archetypes/quickstart/pom.xml
new file mode 100644
index 0000000..f47c395
--- /dev/null
+++ b/archetypes/quickstart/pom.xml
@@ -0,0 +1,232 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+    
+     http://www.apache.org/licenses/LICENSE-2.0
+    
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+  <modelVersion>4.0.0</modelVersion>
+  <artifactId>brooklyn-archetype-quickstart</artifactId>
+  <packaging>maven-archetype</packaging>
+  <name>Brooklyn Quick-Start Project Archetype</name>
+  <description>
+    This project defines an archetype for creating new projects which consume brooklyn,
+    including an example application and an example new entity type,
+    able to build an OSGi JAR and a binary assembly, with logging and READMEs.
+  </description>
+
+  <parent>
+    <groupId>org.apache.brooklyn</groupId>
+    <artifactId>brooklyn-parent</artifactId>
+    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+    <relativePath>../../../brooklyn-server/parent/pom.xml</relativePath>
+  </parent>
+
+  <build>
+    <plugins>
+      <plugin>
+        <artifactId>maven-archetype-plugin</artifactId>
+        <!-- all we want to do is skip _integration tests_ when skipTests is set, not other phases;
+             but for some reason this seems to do it, and it still builds the archetype (!?).
+             whereas setting skip inside the integration-test execution goal does NOT work.
+              
+             TODO promote to root pom.xml when we better understand why
+        -->
+        <configuration>
+          <skip>${skipTests}</skip>
+        </configuration>
+      </plugin>
+      
+      <plugin>
+        <artifactId>maven-clean-plugin</artifactId>
+        <configuration>
+          <filesets>
+            <fileset> 
+                <directory>src/test/resources/projects/integration-test-1/reference</directory> 
+                <includes><include>**/*</include></includes>
+            </fileset>
+            <fileset> 
+                <directory>src/main/resources/archetype-resources/</directory> 
+                <includes><include>**/*</include></includes>
+            </fileset>
+          </filesets>
+        </configuration>
+      </plugin>
+
+      <plugin>
+        <groupId>com.google.code.maven-replacer-plugin</groupId>
+        <artifactId>maven-replacer-plugin</artifactId>
+        <executions>
+          <execution>
+            <id>copy-brooklyn-sample-to-integration-test-reference</id>
+            <phase>clean</phase>
+            <goals> <goal>replace</goal> </goals>
+            <configuration>
+              <basedir>${basedir}/src/brooklyn-sample</basedir> 
+              <outputBasedir>${basedir}</outputBasedir>
+              <outputDir>src/test/resources/projects/integration-test-1/reference</outputDir>
+              <includes> <include>**</include> </includes>
+              <excludes> 
+                <exclude>.*</exclude> 
+                <exclude>.*/**</exclude> 
+                <exclude>target/**</exclude> 
+                <exclude>*.log</exclude> 
+              </excludes>
+              
+              <replacements />
+            </configuration>
+          </execution>
+          <!-- would be nice to reduce the repetion below, but don't see how;
+               have tried with valueTokenMap but it must lie beneath basedir;
+               and tried with {input,output}FilePattern but that doesn't apply to dirs  -->
+          <execution>
+            <!-- copy creating variables and unpackaged, for src/main/java -->
+            <id>copy-brooklyn-sample-to-archetype-src-main-java</id>
+            <phase>clean</phase>
+            <goals> <goal>replace</goal> </goals>
+            <configuration>
+              <basedir>${basedir}/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn</basedir>
+              <outputBasedir>${basedir}</outputBasedir>
+              <outputDir>src/main/resources/archetype-resources/src/main/java</outputDir>
+              <includes> <include>**/*</include> </includes>
+              <replacements>
+                <replacement> <token>brooklyn-sample</token> <value>\$\{artifactId}</value> </replacement>
+                <replacement> <token>com\.acme\.sample\.brooklyn</token> <value>\$\{package}</value> </replacement>
+                <replacement> <token>com/acme/sample/brooklyn</token> <value>\$\{packageInPathFormat}</value> </replacement>
+                <replacement> <token>com\.acme\.sample</token> <value>\$\{groupId}</value> </replacement>
+                <replacement> <token>0.1.0-SNAPSHOT</token> <value>\$\{version}</value> </replacement>
+              </replacements>
+            </configuration>
+          </execution>
+          <execution>
+            <!-- copy creating variables and unpackaged, for src/test/java -->
+            <id>copy-brooklyn-sample-to-archetype-src-test-java</id>
+            <phase>clean</phase>
+            <goals> <goal>replace</goal> </goals>
+            <configuration>
+              <basedir>${basedir}/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn</basedir>
+              <outputBasedir>${basedir}</outputBasedir>
+              <outputDir>src/main/resources/archetype-resources/src/test/java</outputDir>
+              <includes> <include>**/*</include> </includes>
+              <replacements>
+                <replacement> <token>brooklyn-sample</token> <value>\$\{artifactId}</value> </replacement>
+                <replacement> <token>com\.acme\.sample\.brooklyn</token> <value>\$\{package}</value> </replacement>
+                <replacement> <token>com/acme/sample/brooklyn</token> <value>\$\{packageInPathFormat}</value> </replacement>
+                <replacement> <token>com\.acme\.sample</token> <value>\$\{groupId}</value> </replacement>
+                <replacement> <token>0.1.0-SNAPSHOT</token> <value>\$\{version}</value> </replacement>
+              </replacements>
+            </configuration>
+          </execution>
+          <execution>
+            <!-- copy creating variables, for all other places -->
+            <id>copy-brooklyn-sample-to-archetype-resources</id>
+            <phase>clean</phase>
+            <goals> <goal>replace</goal> </goals>
+            <configuration>
+              <basedir>${basedir}/src/brooklyn-sample/</basedir>
+              <outputBasedir>${basedir}</outputBasedir>
+              <outputDir>src/main/resources/archetype-resources/</outputDir>
+              <includes> <include>**/*</include> </includes>
+              <excludes> 
+                <exclude>src/main/java/**</exclude> 
+                <exclude>src/test/java/**</exclude> 
+                <exclude>target/**</exclude> 
+                <exclude>test-output/**</exclude> 
+                <exclude>.*</exclude> 
+                <exclude>**/*.png</exclude> 
+                <exclude>.*/**</exclude> 
+                <exclude>*.log</exclude>
+                <exclude>**/*.sh</exclude>
+              </excludes>
+              <replacements>
+                <!-- special chars in velocity have to be escaped.
+                     fortunately we only use fairly simple examples so we don't need to solve the general case! -->
+                <!-- escaping # is ugly -->
+                <replacement> <token>(#+)</token> <value>#set\(\$H='$1'\)\${H}</value> </replacement>
+                <!-- and escaping $ doesn't even seem to work; perhaps an old version of velocity in use?
+                     (however velocity ignores $ except for variables which are defined, so we're okay)
+                <replacement> <token>\$</token> <value>\\\$</value> </replacement>
+                -->
+                
+                <replacement> <token>brooklyn-sample</token> <value>\$\{artifactId}</value> </replacement>
+                <replacement> <token>com\.acme\.sample\.brooklyn</token> <value>\$\{package}</value> </replacement>
+                <replacement> <token>com/acme/sample/brooklyn</token> <value>\$\{packageInPathFormat}</value> </replacement>
+                <replacement> <token>com\.acme\.sample</token> <value>\$\{groupId}</value> </replacement>
+                <replacement> <token>0.1.0-SNAPSHOT</token> <value>\$\{version}</value> </replacement>
+              </replacements>
+            </configuration>
+          </execution>
+          <execution>
+            <!-- copy creating variables, for all other places -->
+            <id>copy-brooklyn-sample-to-archetype-resources-binary</id>
+            <phase>clean</phase>
+            <goals> <goal>replace</goal> </goals>
+            <configuration>
+              <basedir>${basedir}/src/brooklyn-sample/</basedir>
+              <outputBasedir>${basedir}</outputBasedir>
+              <outputDir>src/main/resources/archetype-resources/</outputDir>
+              <includes>
+                <include>**/*.png</include>
+                <include>**/*.sh</include>
+              </includes>
+              <excludes> 
+                <exclude>target/**</exclude> 
+                <exclude>test-output/**</exclude> 
+                <exclude>.*</exclude> 
+                <exclude>.*/**</exclude> 
+              </excludes>
+              <!-- no replacements for binary (put one just so we can use this plugin for consistency) -->
+              <replacements><replacement> <token>NONCE_123456789XYZ</token> <value>NONCE_123456789XYZ</value> </replacement></replacements>
+            </configuration>
+          </execution>
+          
+        </executions>
+      </plugin>
+
+    </plugins>
+      <pluginManagement>
+        <plugins>
+          <plugin>
+            <groupId>org.apache.rat</groupId>
+            <artifactId>apache-rat-plugin</artifactId>
+            <configuration>
+              <excludes combine.children="append">
+                <!-- 
+                    The maven archetype are files "without any degree of creativity". They are intended
+                    purely as a template to generate a new project for a user, where upon the user can
+                    write their code within this new project.
+                    The exclusions seem to need to include code that is auto-generated during a test run.
+                -->
+                <exclude>**/src/main/resources/archetype-resources/**/*</exclude>
+                <exclude>**/src/test/resources/projects/integration-test-1/goal.txt</exclude>
+                <exclude>**/src/test/resources/projects/integration-test-1/reference/**/*</exclude>
+                <exclude>**/src/main/java/sample/**/*Sample*.java</exclude>
+                <exclude>**/src/main/resources/logback-custom.xml</exclude>
+                <exclude>**/src/brooklyn-sample/README.md</exclude>
+                <exclude>**/src/brooklyn-sample/pom.xml</exclude>
+                <exclude>**/src/brooklyn-sample/src/main/assembly/files/conf/*</exclude>
+                <exclude>**/src/brooklyn-sample/src/main/java/**/*.java</exclude>
+                <exclude>**/src/brooklyn-sample/src/main/resources/logback-custom.xml</exclude>
+                <exclude>**/src/brooklyn-sample/src/test/java/**/*.java</exclude>
+              </excludes>
+            </configuration>
+          </plugin>
+        </plugins>
+      </pluginManagement>
+
+  </build>
+
+</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/brooklyn-sample/README.md
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/brooklyn-sample/README.md b/archetypes/quickstart/src/brooklyn-sample/README.md
new file mode 100644
index 0000000..b40df41
--- /dev/null
+++ b/archetypes/quickstart/src/brooklyn-sample/README.md
@@ -0,0 +1,73 @@
+brooklyn-sample
+===
+
+This is a Sample Brooklyn project, showing how to define an application
+which Brooklyn will deploy and manage.
+
+This sample project is intended to be customized to suit your purposes: but
+search for all lines containing the word "sample" to make sure all the
+references to this being a sample are removed!   
+
+To build an assembly, simply run:
+
+    mvn clean assembly:assembly
+
+This creates a tarball with a full standalone application which can be installed in any *nix machine at:
+    target/brooklyn-sample-0.1.0-SNAPSHOT-dist.tar.gz
+
+It also installs an unpacked version which you can run locally:
+ 
+     cd target/brooklyn-sample-0.1.0-SNAPSHOT-dist/brooklyn-sample-0.1.0-SNAPSHOT
+     ./start.sh server
+ 
+For more information see the README (or `./start.sh help`) in that directory.
+On OS X and Linux, this application will deploy to localhost *if* you have key-based 
+password-less (and passphrase-less) ssh enabled.
+
+To configure cloud and fixed-IP locations, see the README file in the built application directly.
+For more information you can run `./start.sh help`) in that directory.
+
+
+### Opening in an IDE
+
+To open this project in an IDE, you will need maven support enabled
+(e.g. with the relevant plugin).  You should then be able to develop
+it and run it as usual.  For more information on IDE support, visit:
+
+    https://brooklyn.incubator.apache.org/v/latest/dev/env/ide/
+
+
+### Customizing the Assembly
+
+The artifacts (directory and tar.gz by default) which get built into
+`target/` can be changed.  Simply edit the relevant files under
+`src/main/assembly`.
+
+You will likely wish to customize the `SampleMain` class as well as
+the `Sample*App` classes provided.  That is the intention!
+You will also likely want to update the `start.sh` script and
+the `README.*` files.
+
+To easily find the bits you should customize, do a:
+
+    grep -ri sample src/ *.*
+
+
+### More About Apache Brooklyn
+
+Apache Brooklyn is a code library and framework for managing applications in a 
+cloud-first dev-ops-y way.  It has been used to create this sample project 
+which shows how to define an application and entities for Brooklyn.
+
+This project can be extended for more complex topologies and more 
+interesting applications, and to develop the policies to scale or tune the 
+deployment depending on what the application needs.
+
+For more information consider:
+
+* Visiting the Apache Brooklyn home page at https://brooklyn.incubator.apache.org
+* Finding us on IRC #brooklyncentral or email (click "Community" at the site above) 
+* Forking the project at  http://github.com/apache/incubator-brooklyn/
+
+A sample Brooklyn project should specify its license.
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/brooklyn-sample/pom.xml
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/brooklyn-sample/pom.xml b/archetypes/quickstart/src/brooklyn-sample/pom.xml
new file mode 100644
index 0000000..44f5f93
--- /dev/null
+++ b/archetypes/quickstart/src/brooklyn-sample/pom.xml
@@ -0,0 +1,102 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+
+  <modelVersion>4.0.0</modelVersion>
+
+  <parent>
+    <groupId>org.apache.brooklyn</groupId>
+    <artifactId>brooklyn-downstream-parent</artifactId>
+    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+  </parent>
+
+  <groupId>com.acme.sample</groupId>
+  <artifactId>brooklyn-sample</artifactId>
+  <version>0.1.0-SNAPSHOT</version>
+  <packaging>jar</packaging>
+
+  <name>Sample Brooklyn Project com.acme.sample:brooklyn-sample v0.1.0-SNAPSHOT</name>
+  <description>
+    Sample optional description goes here.
+  </description>
+
+  <!-- Optional metadata (commented out in this sample) 
+
+  <url>https://github.com/sample/sample</url>
+
+  <licenses>
+    <license>
+      <name>The Apache Software License, Version 2.0</name>
+      <url>http://www.apache.org/licenses/LICENSE-2.0.txt</url>
+      <distribution>repo</distribution>
+    </license>
+  </licenses>
+
+  <developers>
+    <developer>
+      <name>Sample Project Committers</name>
+    </developer>
+  </developers>
+
+  <scm>
+    <connection>scm:git:git://github.com/sample/sample</connection>
+    <developerConnection>scm:git:git@github.com:sample/sample.git</developerConnection>
+    <url>http://github.com/sample/sample</url>
+  </scm>
+
+  -->
+
+  <properties>
+    <project.entry>com.acme.sample.brooklyn.SampleMain</project.entry>
+  </properties>
+
+  <repositories>
+    <repository>
+      <id>apache.snapshots</id>
+      <name>Apache Snapshot Repository</name>
+      <url>http://repository.apache.org/snapshots</url>
+      <releases>
+        <enabled>false</enabled>
+      </releases>
+    </repository>
+  </repositories>
+
+  <dependencies>
+    <dependency>
+      <!-- this pulls in all brooklyn entities and clouds; 
+           you can cherry pick selected ones instead (for a smaller build) -->
+      <groupId>org.apache.brooklyn</groupId>
+      <artifactId>brooklyn-all</artifactId>
+      <version>${brooklyn.version}</version>
+    </dependency>
+
+    <dependency>
+      <!-- includes testng and useful logging for tests -->
+      <groupId>org.apache.brooklyn</groupId>
+      <artifactId>brooklyn-test-support</artifactId>
+      <version>${brooklyn.version}</version>
+      <scope>test</scope>
+    </dependency>
+
+    <dependency>
+      <!-- this gives us flexible and easy-to-use logging; just edit logback-custom.xml! -->
+      <groupId>org.apache.brooklyn</groupId>
+      <artifactId>brooklyn-logback-xml</artifactId>
+      <version>${brooklyn.version}</version>
+    </dependency>
+  </dependencies>
+
+  <build>
+    <plugins>
+      <plugin>
+        <artifactId>maven-assembly-plugin</artifactId>
+        <configuration>
+          <descriptors>
+            <descriptor>src/main/assembly/assembly.xml</descriptor>
+          </descriptors>
+        </configuration>
+      </plugin>
+    </plugins>
+  </build>
+
+</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/assembly.xml
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/assembly.xml b/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/assembly.xml
new file mode 100644
index 0000000..2875a8a
--- /dev/null
+++ b/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/assembly.xml
@@ -0,0 +1,88 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+    
+     http://www.apache.org/licenses/LICENSE-2.0
+    
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<assembly>
+    <id>dist</id>
+    <!-- Generates an archive and a dir containing the needed files; 
+         can add e.g. zip to the following
+         (but executable bit is not preserved) -->
+    <formats>
+        <format>dir</format>
+        <format>tar.gz</format>
+    </formats>
+
+    <!-- Adds dependencies to zip package under lib directory -->
+    <dependencySets>
+        <dependencySet>
+            <!--
+               Project artifact is not copied under library directory since
+               it is added to the root directory of the zip package.
+           -->
+            <useProjectArtifact>false</useProjectArtifact>
+            <outputDirectory>lib</outputDirectory>
+            <unpack>false</unpack>
+        </dependencySet>
+    </dependencySets>
+
+    <!--
+       Adds startup scripts to the root directory of zip package. The startup
+       scripts are located to src/main/scripts directory as stated by Maven
+       conventions.
+    -->
+    <files>
+        <file>
+            <source>src/main/assembly/scripts/start.sh</source>
+            <outputDirectory></outputDirectory>
+            <fileMode>0755</fileMode>
+            <filtered>true</filtered>
+        </file>
+    </files>
+    <fileSets>
+        <fileSet>
+            <directory>src/main/assembly/scripts</directory>
+            <outputDirectory></outputDirectory>
+            <fileMode>0755</fileMode>
+            <includes>
+                <include>*</include>
+            </includes>
+            <excludes>
+                <exclude>start.sh</exclude>
+            </excludes>
+        </fileSet>
+        <!--  add additional files (but not marked executable) -->
+        <fileSet>
+            <directory>src/main/assembly/files</directory>
+            <outputDirectory></outputDirectory>
+            <includes>
+                <include>**</include>
+            </includes>
+        </fileSet>
+        <!-- adds jar package to the root directory of zip package -->
+        <fileSet>
+            <directory>target</directory>
+            <outputDirectory></outputDirectory>
+            <includes>
+                <include>*.jar</include>
+            </includes>
+            <excludes>
+                <exclude>*-tests.jar</exclude>
+            </excludes>
+        </fileSet>
+    </fileSets>
+</assembly>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/README.txt
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/README.txt b/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/README.txt
new file mode 100644
index 0000000..8ba14f1
--- /dev/null
+++ b/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/README.txt
@@ -0,0 +1,96 @@
+brooklyn-sample
+===
+
+This is a sample application which is launched and managed by Brooklyn.
+This README file is at the root of the built assembly, which can be uploaded
+and run most anywhere.  This file provides end-user instructions.
+
+To use this, configure any cloud credentials then run  ./start.sh  in this 
+directory. You can then access the management context in your browser, 
+typically on  http://localhost:8081 , and through that console deploy the
+applications contained in this archive.
+
+
+### Cloud Credentials
+
+To run, you'll need to specify credentials for your preferred cloud.  This 
+can be done in `~/.brooklyn/brooklyn.properties`.
+
+A recommended starting point is the file at:
+
+    https://brooklyn.incubator.apache.org/v/latest/use/guide/quickstart/brooklyn.properties
+
+As a quick-start, you can specify:
+
+    brooklyn.location.jclouds.aws-ec2.identity=AKXXXXXXXXXXXXXXXXXX
+    brooklyn.location.jclouds.aws-ec2.credential=secret01xxxxxxxxxxxxxxxxxxxxxxxxxxx
+    
+    brooklyn.location.named.My_Amazon_US_west=jclouds:aws-ec2:us-west-1
+    brooklyn.location.named.My_Amazon_EU=jclouds:aws-ec2:eu-west-1
+
+Alternatively these can be set as shell environment parameters or JVM system properties.
+
+Many other clouds are supported also, as well as pre-existing machines 
+("bring your own nodes"), custom endpoints for private clouds, and specifying 
+custom keys and passphrases. For more information see:
+
+    https://brooklyn.incubator.apache.org/v/latest/use/guide/defining-applications/common-usage#locations
+
+
+### Run
+
+Usage:
+
+    ./start.sh launch [--WHAT] \
+        [--port 8081+] \
+        [--location location] 
+
+The optional port argument specifies the port where the Brooklyn console 
+will be running, such as localhost:8081. (The console is only bound to 
+localhost, unless you set up users and security, as described at
+https://brooklyn.incubator.apache.org/v/latest/use/guide/management/ .)
+
+In the console, you can access the catalog and deploy applications to
+configured locations.
+
+In this sample application, `--cluster` and `--single` are supported in place of `--WHAT`,
+corresponding to sample blueprints in the project. This can be left blank to have nothing 
+launched; note that the blueprints can be launched at runtime via the GUI or API.
+
+Use `./start.sh help` or `./start.sh help launch` for more detailed help.
+
+The location might be `localhost` (the default), `aws-ec2:us-east-1`, 
+`openstack:endpoint`, `softlayer`, or based on names, such as
+`named:My_Amazon_US_west`, so long as it is configured as above. 
+(Localhost does not need any configuration in `~/brooklyn/brooklyn.properties`, 
+provided you have password-less ssh access enabled to localhost, using a 
+private key with no passphrase.) 
+
+
+### More About Brooklyn
+
+Brooklyn is a code library and framework for managing applications in a 
+cloud-first dev-ops-y way.  It has been used to create this sample project 
+which shows how to define an application and entities for Brooklyn.
+
+This project can be extended for more complex topologies and more 
+interesting applications, and to develop the policies to scale or tune the 
+deployment depending on what the application needs.
+
+For more information consider:
+
+* Visiting the open-source Brooklyn home page at  http://brooklyncentral.github.com
+* Forking the Brooklyn project at  http://github.com/brooklyncentral/brooklyn
+* Emailing  brooklyn-users@googlegroups.com 
+
+For commercial enquiries -- including bespoke development and paid support --
+contact Cloudsoft, the supporters of Brooklyn, at:
+
+* www.CloudsoftCorp.com
+* info@cloudsoftcorp.com
+
+Brooklyn is (c) 2014 Cloudsoft Corporation and released as open source under 
+the Apache License v2.0.
+
+A sample Brooklyn project should specify its license here.
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/conf/logback.xml
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/conf/logback.xml b/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/conf/logback.xml
new file mode 100644
index 0000000..7b7a972
--- /dev/null
+++ b/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/conf/logback.xml
@@ -0,0 +1,11 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<configuration>
+
+  <!-- logging configuration for this project; edit this file as required, or override the files 
+       this includes as described in the Logging section of the brooklyn users guide.
+       this project already supplies a logback-custom.xml which gets included to log our
+       classes at debug level and write to a log file named after this project -->
+
+  <include resource="logback-main.xml"/>
+  
+</configuration>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/scripts/start.sh
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/scripts/start.sh b/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/scripts/start.sh
new file mode 100755
index 0000000..2879b6d
--- /dev/null
+++ b/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/scripts/start.sh
@@ -0,0 +1,40 @@
+#!/bin/bash
+#
+# 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.
+#
+
+if [ ! -z "$JAVA_HOME" ] ; then 
+    JAVA=$JAVA_HOME/bin/java
+else
+    JAVA=`which java`
+fi
+
+if [ ! -x "$JAVA" ] ; then
+  echo Cannot find java. Set JAVA_HOME or add java to path.
+  exit 1
+fi
+
+if [[ ! `ls ${project.artifactId}-*.jar 2> /dev/null` ]] ; then
+  echo Command must be run from the directory where the JAR is installed.
+  exit 4
+fi
+
+$JAVA -Xms256m -Xmx1024m -XX:MaxPermSize=1024m \
+    -classpath "conf/:patch/*:*:lib/*" \
+    ${project.entry} \
+    "$@"

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/SampleMain.java
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/SampleMain.java b/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/SampleMain.java
new file mode 100644
index 0000000..253f657
--- /dev/null
+++ b/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/SampleMain.java
@@ -0,0 +1,81 @@
+package com.acme.sample.brooklyn;
+
+import java.util.Arrays;
+
+import io.airlift.command.Command;
+import io.airlift.command.Option;
+
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import org.apache.brooklyn.api.catalog.BrooklynCatalog;
+import org.apache.brooklyn.cli.Main;
+
+import com.google.common.base.Objects.ToStringHelper;
+
+import com.acme.sample.brooklyn.sample.app.*;
+
+/**
+ * This class provides a static main entry point for launching a custom Brooklyn-based app.
+ * <p>
+ * It inherits the standard Brooklyn CLI options from {@link Main},
+ * plus adds a few more shortcuts for favourite blueprints to the {@link LaunchCommand}.
+ */
+public class SampleMain extends Main {
+    
+    private static final Logger log = LoggerFactory.getLogger(SampleMain.class);
+    
+    public static final String DEFAULT_LOCATION = "localhost";
+
+    public static void main(String... args) {
+        log.debug("CLI invoked with args "+Arrays.asList(args));
+        new SampleMain().execCli(args);
+    }
+
+    @Override
+    protected String cliScriptName() {
+        return "start.sh";
+    }
+    
+    @Override
+    protected Class<? extends BrooklynCommand> cliLaunchCommand() {
+        return LaunchCommand.class;
+    }
+
+    @Command(name = "launch", description = "Starts a server, and optionally an application. "
+        + "Use e.g. --single or --cluster to launch one-node and clustered variants of the sample web application.")
+    public static class LaunchCommand extends Main.LaunchCommand {
+
+        // add these options to the LaunchCommand as shortcuts for our favourite applications
+        
+        @Option(name = { "--single" }, description = "Launch a single web-server instance")
+        public boolean single;
+
+        @Option(name = { "--cluster" }, description = "Launch a web-server cluster")
+        public boolean cluster;
+
+        @Override
+        public Void call() throws Exception {
+            // process our CLI arguments
+            if (single) setAppToLaunch( SingleWebServerSample.class.getCanonicalName() );
+            if (cluster) setAppToLaunch( ClusterWebServerDatabaseSample.class.getCanonicalName() );
+            
+            // now process the standard launch arguments
+            return super.call();
+        }
+
+        @Override
+        protected void populateCatalog(BrooklynCatalog catalog) {
+            super.populateCatalog(catalog);
+            catalog.addItem(SingleWebServerSample.class);
+            catalog.addItem(ClusterWebServerDatabaseSample.class);
+        }
+
+        @Override
+        public ToStringHelper string() {
+            return super.string()
+                    .add("single", single)
+                    .add("cluster", cluster);
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/ClusterWebServerDatabaseSample.java
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/ClusterWebServerDatabaseSample.java b/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/ClusterWebServerDatabaseSample.java
new file mode 100644
index 0000000..11d977f
--- /dev/null
+++ b/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/ClusterWebServerDatabaseSample.java
@@ -0,0 +1,137 @@
+package com.acme.sample.brooklyn.sample.app;
+
+import java.util.concurrent.TimeUnit;
+
+import org.apache.brooklyn.api.catalog.Catalog;
+import org.apache.brooklyn.api.catalog.CatalogConfig;
+import org.apache.brooklyn.api.entity.EntitySpec;
+import org.apache.brooklyn.api.sensor.AttributeSensor;
+import org.apache.brooklyn.config.ConfigKey;
+import org.apache.brooklyn.core.config.ConfigKeys;
+import org.apache.brooklyn.core.entity.AbstractApplication;
+import org.apache.brooklyn.core.entity.Entities;
+import org.apache.brooklyn.core.location.PortRanges;
+import org.apache.brooklyn.core.sensor.Sensors;
+import org.apache.brooklyn.enricher.stock.SensorPropagatingEnricher;
+import org.apache.brooklyn.enricher.stock.SensorTransformingEnricher;
+import org.apache.brooklyn.entity.database.DatastoreMixins.DatastoreCommon;
+import org.apache.brooklyn.entity.database.mysql.MySqlNode;
+import org.apache.brooklyn.entity.group.DynamicCluster;
+import org.apache.brooklyn.entity.java.JavaEntityMethods;
+import org.apache.brooklyn.entity.webapp.ControlledDynamicWebAppCluster;
+import org.apache.brooklyn.entity.webapp.DynamicWebAppCluster;
+import org.apache.brooklyn.entity.webapp.JavaWebAppService;
+import org.apache.brooklyn.entity.webapp.WebAppService;
+import org.apache.brooklyn.entity.webapp.WebAppServiceConstants;
+import org.apache.brooklyn.policy.autoscaling.AutoScalerPolicy;
+import org.apache.brooklyn.policy.enricher.HttpLatencyDetector;
+import org.apache.brooklyn.util.maven.MavenArtifact;
+import org.apache.brooklyn.util.maven.MavenRetriever;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import com.google.common.base.Functions;
+
+import static org.apache.brooklyn.core.sensor.DependentConfiguration.attributeWhenReady;
+import static org.apache.brooklyn.core.sensor.DependentConfiguration.formatString;
+
+
+/** This sample builds a 3-tier application with an elastic app-server cluster,
+ *  and it sets it up for use in the Brooklyn catalog. 
+ *  <p>
+ *  Note that root access (and xcode etc) may be required to install nginx.
+ **/
+@Catalog(name="Elastic Java Web + DB",
+    description="Deploys a WAR to a load-balanced elastic Java AppServer cluster, " +
+        "with an auto-scaling policy, " +
+        "wired to a database initialized with the provided SQL; " +
+        "defaults to a 'Hello World' chatroom app.",
+    iconUrl="classpath://sample-icon.png")
+public class ClusterWebServerDatabaseSample extends AbstractApplication {
+
+    public static final Logger LOG = LoggerFactory.getLogger(ClusterWebServerDatabaseSample.class);
+
+    // ---------- WAR configuration ---------------
+    
+    public static final String DEFAULT_WAR_URL =
+            // can supply any URL -- this loads a stock example from maven central / sonatype
+            MavenRetriever.localUrl(MavenArtifact.fromCoordinate("io.brooklyn.example:brooklyn-example-hello-world-sql-webapp:war:0.5.0"));
+
+    @CatalogConfig(label="WAR (URL)", priority=2)
+    public static final ConfigKey<String> WAR_URL = ConfigKeys.newConfigKey(
+        "app.war", "URL to the application archive which should be deployed", DEFAULT_WAR_URL);    
+
+    
+    // ---------- DB configuration ----------------
+    
+    // this is included in src/main/resources. if in an IDE, ensure your build path is set appropriately.
+    public static final String DEFAULT_DB_SETUP_SQL_URL = "classpath://visitors-creation-script.sql";
+    
+    @CatalogConfig(label="DB Setup SQL (URL)", priority=1)
+    public static final ConfigKey<String> DB_SETUP_SQL_URL = ConfigKeys.newConfigKey(
+        "app.db_sql", "URL to the SQL script to set up the database", 
+        DEFAULT_DB_SETUP_SQL_URL);
+    
+    public static final String DB_TABLE = "visitors";
+    public static final String DB_USERNAME = "brooklyn";
+    public static final String DB_PASSWORD = "br00k11n";
+    
+
+    // --------- Custom Sensor --------------------
+    
+    AttributeSensor<Integer> APPSERVERS_COUNT = Sensors.newIntegerSensor( 
+            "appservers.count", "Number of app servers deployed");
+
+    
+    // --------- Initialization -------------------
+    
+    /** Initialize our application. In this case it consists of 
+     *  a single DB, with a load-balanced cluster (nginx + multiple JBosses, by default),
+     *  with some sensors and a policy. */
+    @Override
+    public void init() {
+        DatastoreCommon db = addChild(
+                EntitySpec.create(MySqlNode.class)
+                        .configure(MySqlNode.CREATION_SCRIPT_URL, Entities.getRequiredUrlConfig(this, DB_SETUP_SQL_URL)));
+
+        ControlledDynamicWebAppCluster web = addChild(
+                EntitySpec.create(ControlledDynamicWebAppCluster.class)
+                        // set WAR to use, and port to use
+                        .configure(JavaWebAppService.ROOT_WAR, getConfig(WAR_URL))
+                        .configure(WebAppService.HTTP_PORT, PortRanges.fromString("8080+"))
+                        
+//                        // optionally - use Tomcat instead of JBoss (default:
+//                        .configure(ControlledDynamicWebAppCluster.MEMBER_SPEC, EntitySpec.create(TomcatServer.class))
+                        
+                        // inject a JVM system property to point to the DB
+                        .configure(JavaEntityMethods.javaSysProp("brooklyn.example.db.url"), 
+                                formatString("jdbc:%s%s?user=%s\\&password=%s", 
+                                        attributeWhenReady(db, DatastoreCommon.DATASTORE_URL), DB_TABLE, DB_USERNAME, DB_PASSWORD))
+                    
+                        // start with 2 appserver nodes, initially
+                        .configure(DynamicCluster.INITIAL_SIZE, 2) 
+                    );
+
+        // add an enricher which measures latency
+        web.addEnricher(HttpLatencyDetector.builder().
+                url(WebAppServiceConstants.ROOT_URL).
+                rollup(10, TimeUnit.SECONDS).
+                build());
+
+        // add a policy which scales out based on Reqs/Sec
+        web.getCluster().addPolicy(AutoScalerPolicy.builder().
+                metric(DynamicWebAppCluster.REQUESTS_PER_SECOND_IN_WINDOW_PER_NODE).
+                metricRange(10, 100).
+                sizeRange(2, 5).
+                build());
+
+        // add a few more sensors at the top-level (KPI's at the root of the application)
+        addEnricher(SensorPropagatingEnricher.newInstanceListeningTo(web,  
+                WebAppServiceConstants.ROOT_URL,
+                DynamicWebAppCluster.REQUESTS_PER_SECOND_IN_WINDOW,
+                HttpLatencyDetector.REQUEST_LATENCY_IN_SECONDS_IN_WINDOW));
+        addEnricher(SensorTransformingEnricher.newInstanceTransforming(web, 
+                DynamicWebAppCluster.GROUP_SIZE, Functions.<Integer>identity(), APPSERVERS_COUNT));
+    }
+    
+}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/SingleWebServerSample.java
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/SingleWebServerSample.java b/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/SingleWebServerSample.java
new file mode 100644
index 0000000..3cc9426
--- /dev/null
+++ b/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/SingleWebServerSample.java
@@ -0,0 +1,32 @@
+package com.acme.sample.brooklyn.sample.app;
+
+import org.apache.brooklyn.api.entity.EntitySpec;
+import org.apache.brooklyn.core.entity.AbstractApplication;
+import org.apache.brooklyn.core.entity.Attributes;
+import org.apache.brooklyn.core.location.PortRanges;
+import org.apache.brooklyn.entity.webapp.JavaWebAppService;
+import org.apache.brooklyn.entity.webapp.jboss.JBoss7Server;
+import org.apache.brooklyn.util.maven.MavenArtifact;
+import org.apache.brooklyn.util.maven.MavenRetriever;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+/** This example starts one web app on 8080. */
+public class SingleWebServerSample extends AbstractApplication {
+
+    public static final Logger LOG = LoggerFactory.getLogger(SingleWebServerSample.class);
+
+    public static final String DEFAULT_WAR_URL =
+            // can supply any URL -- this loads a stock example from maven central / sonatype
+            MavenRetriever.localUrl(MavenArtifact.fromCoordinate("io.brooklyn.example:brooklyn-example-hello-world-sql-webapp:war:0.5.0"));
+
+    /** Initialize our application. In this case it consists of 
+     *  a single JBoss entity, configured to run the WAR above. */
+    @Override
+    public void init() {
+        addChild(EntitySpec.create(JBoss7Server.class)
+                .configure(JavaWebAppService.ROOT_WAR, DEFAULT_WAR_URL)
+                .configure(Attributes.HTTP_PORT, PortRanges.fromString("8080+")));
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/brooklyn-sample/src/main/resources/logback-custom.xml
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/brooklyn-sample/src/main/resources/logback-custom.xml b/archetypes/quickstart/src/brooklyn-sample/src/main/resources/logback-custom.xml
new file mode 100644
index 0000000..5a1ec98
--- /dev/null
+++ b/archetypes/quickstart/src/brooklyn-sample/src/main/resources/logback-custom.xml
@@ -0,0 +1,10 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<included>
+
+    <!-- include everything in this project at debug level -->
+    <logger name="com.acme.sample.brooklyn" level="DEBUG"/>    
+    
+    <!-- logfile named after this project -->
+    <property name="logging.basename" scope="context" value="brooklyn-sample" />
+
+</included>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/brooklyn-sample/src/main/resources/sample-icon.png
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/brooklyn-sample/src/main/resources/sample-icon.png b/archetypes/quickstart/src/brooklyn-sample/src/main/resources/sample-icon.png
new file mode 100644
index 0000000..542a1de
Binary files /dev/null and b/archetypes/quickstart/src/brooklyn-sample/src/main/resources/sample-icon.png differ

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/brooklyn-sample/src/main/resources/visitors-creation-script.sql
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/brooklyn-sample/src/main/resources/visitors-creation-script.sql b/archetypes/quickstart/src/brooklyn-sample/src/main/resources/visitors-creation-script.sql
new file mode 100644
index 0000000..0a805c4
--- /dev/null
+++ b/archetypes/quickstart/src/brooklyn-sample/src/main/resources/visitors-creation-script.sql
@@ -0,0 +1,35 @@
+--
+-- 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.
+--
+create database visitors;
+use visitors;
+create user 'brooklyn' identified by 'br00k11n';
+grant usage on *.* to 'brooklyn'@'%' identified by 'br00k11n';
+# ''@localhost is sometimes set up, overriding brooklyn@'%', so do a second explicit grant
+grant usage on *.* to 'brooklyn'@'localhost' identified by 'br00k11n';
+grant all privileges on visitors.* to 'brooklyn'@'%';
+flush privileges;
+
+CREATE TABLE MESSAGES (
+        id INT NOT NULL AUTO_INCREMENT,
+        NAME VARCHAR(30) NOT NULL,
+        MESSAGE VARCHAR(400) NOT NULL,
+        PRIMARY KEY (ID)
+    );
+
+INSERT INTO MESSAGES values (default, 'Isaac Asimov', 'I grew up in Brooklyn' );

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleLocalhostIntegrationTest.java
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleLocalhostIntegrationTest.java b/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleLocalhostIntegrationTest.java
new file mode 100644
index 0000000..f640f6a
--- /dev/null
+++ b/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleLocalhostIntegrationTest.java
@@ -0,0 +1,81 @@
+package com.acme.sample.brooklyn.sample.app;
+
+import java.util.Arrays;
+import java.util.Iterator;
+
+import org.apache.brooklyn.api.entity.Entity;
+import org.apache.brooklyn.api.entity.EntitySpec;
+import org.apache.brooklyn.api.mgmt.ManagementContext;
+import org.apache.brooklyn.core.mgmt.internal.LocalManagementContext;
+import org.apache.brooklyn.core.entity.Entities;
+import org.apache.brooklyn.core.entity.StartableApplication;
+import org.apache.brooklyn.entity.webapp.JavaWebAppService;
+import org.apache.brooklyn.util.core.ResourceUtils;
+import org.apache.brooklyn.util.text.Strings;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+import org.testng.Assert;
+import org.testng.annotations.AfterMethod;
+import org.testng.annotations.BeforeMethod;
+import org.testng.annotations.Test;
+
+/**
+ * Sample integration tests which show how to launch the sample applications on localhost,
+ * make some assertions about them, and then destroy them.
+ */
+@Test(groups="Integration")
+public class SampleLocalhostIntegrationTest {
+
+    private static final Logger log = LoggerFactory.getLogger(SampleLocalhostIntegrationTest.class);
+    
+    private ManagementContext mgmt;
+
+    @BeforeMethod(alwaysRun=true)
+    public void setup() {
+        mgmt = new LocalManagementContext();
+    }
+
+    @AfterMethod(alwaysRun=true)
+    public void shutdown() {
+        if (mgmt != null) Entities.destroyAll(mgmt);
+    }
+
+
+    public void testSingle() {
+        StartableApplication app = mgmt.getEntityManager().createEntity(
+                EntitySpec.create(StartableApplication.class, SingleWebServerSample.class));
+        Entities.startManagement(app, mgmt);
+        Entities.start(app, Arrays.asList(mgmt.getLocationRegistry().resolve("localhost")));
+        
+        Iterator<Entity> children = app.getChildren().iterator();
+        if (!children.hasNext()) Assert.fail("Should have had a single JBoss child; had none");
+        
+        Entity web = children.next();
+        
+        if (children.hasNext()) Assert.fail("Should have had a single JBoss child; had too many: "+app.getChildren());
+        
+        String url = web.getAttribute(JavaWebAppService.ROOT_URL);
+        Assert.assertNotNull(url);
+        
+        String page = new ResourceUtils(this).getResourceAsString(url);
+        log.info("Read web page for "+app+" from "+url+":\n"+page);
+        Assert.assertTrue(!Strings.isBlank(page));
+    }
+
+    public void testCluster() {
+        StartableApplication app = mgmt.getEntityManager().createEntity(
+                EntitySpec.create(StartableApplication.class, ClusterWebServerDatabaseSample.class));
+        Entities.startManagement(app, mgmt);
+        Entities.start(app, Arrays.asList(mgmt.getLocationRegistry().resolve("localhost")));
+        
+        log.debug("APP is started");
+        
+        String url = app.getAttribute(JavaWebAppService.ROOT_URL);
+        Assert.assertNotNull(url);
+
+        String page = new ResourceUtils(this).getResourceAsString(url);
+        log.info("Read web page for "+app+" from "+url+":\n"+page);
+        Assert.assertTrue(!Strings.isBlank(page));
+    }
+    
+}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleUnitTest.java
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleUnitTest.java b/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleUnitTest.java
new file mode 100644
index 0000000..6a34301
--- /dev/null
+++ b/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleUnitTest.java
@@ -0,0 +1,69 @@
+package com.acme.sample.brooklyn.sample.app;
+
+import org.apache.brooklyn.api.entity.Entity;
+import org.apache.brooklyn.api.entity.EntitySpec;
+import org.apache.brooklyn.api.mgmt.ManagementContext;
+import org.apache.brooklyn.core.mgmt.internal.LocalManagementContext;
+import org.apache.brooklyn.core.entity.Entities;
+import org.apache.brooklyn.core.entity.StartableApplication;
+import org.apache.brooklyn.entity.database.DatastoreMixins.DatastoreCommon;
+import org.apache.brooklyn.entity.database.mysql.MySqlNode;
+import org.apache.brooklyn.entity.webapp.JavaWebAppService;
+import org.apache.brooklyn.entity.webapp.WebAppService;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+import org.testng.Assert;
+import org.testng.annotations.AfterMethod;
+import org.testng.annotations.BeforeMethod;
+import org.testng.annotations.Test;
+
+import com.google.common.base.Predicates;
+import com.google.common.collect.Iterables;
+
+/** 
+ * Unit tests for the sample applications defined in this project.
+ * Shows how to examine the spec and make assertions about configuration.
+ */
+@Test
+public class SampleUnitTest {
+
+    private static final Logger log = LoggerFactory.getLogger(SampleUnitTest.class);
+
+    
+    private ManagementContext mgmt;
+
+    @BeforeMethod(alwaysRun=true)
+    public void setup() {
+        mgmt = new LocalManagementContext();
+    }
+
+    @AfterMethod(alwaysRun=true)
+    public void shutdown() {
+        if (mgmt != null) Entities.destroyAll(mgmt);
+    }
+
+    
+    public void testSampleSingleStructure() {
+        StartableApplication app = mgmt.getEntityManager().createEntity(
+                EntitySpec.create(StartableApplication.class, SingleWebServerSample.class));
+        log.info("app from spec is: "+app);
+        
+        Assert.assertEquals(app.getChildren().size(), 1);
+        Assert.assertNotNull( app.getChildren().iterator().next().getConfig(JavaWebAppService.ROOT_WAR) );
+    }
+    
+    public void testSampleClusterStructure() {
+        StartableApplication app = mgmt.getEntityManager().createEntity(
+                EntitySpec.create(StartableApplication.class, ClusterWebServerDatabaseSample.class));
+        log.info("app from spec is: "+app);
+        
+        Assert.assertEquals(app.getChildren().size(), 2);
+        
+        Entity webappCluster = Iterables.find(app.getChildren(), Predicates.instanceOf(WebAppService.class));
+        Entity database = Iterables.find(app.getChildren(), Predicates.instanceOf(DatastoreCommon.class));
+        
+        Assert.assertNotNull( webappCluster.getConfig(JavaWebAppService.ROOT_WAR) );
+        Assert.assertNotNull( database.getConfig(MySqlNode.CREATION_SCRIPT_URL) );
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/main/resources/.gitignore
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/main/resources/.gitignore b/archetypes/quickstart/src/main/resources/.gitignore
new file mode 100644
index 0000000..6d7b6a3
--- /dev/null
+++ b/archetypes/quickstart/src/main/resources/.gitignore
@@ -0,0 +1 @@
+archetype-resources

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/main/resources/META-INF/maven/archetype-metadata.xml
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/main/resources/META-INF/maven/archetype-metadata.xml b/archetypes/quickstart/src/main/resources/META-INF/maven/archetype-metadata.xml
new file mode 100644
index 0000000..4768945
--- /dev/null
+++ b/archetypes/quickstart/src/main/resources/META-INF/maven/archetype-metadata.xml
@@ -0,0 +1,65 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+    
+     http://www.apache.org/licenses/LICENSE-2.0
+    
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<archetype xmlns="http://maven.apache.org/plugins/maven-archetype-plugin/archetype/1.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+  xsi:schemaLocation="http://maven.apache.org/plugins/maven-archetype-plugin/archetype/1.0.0 http://maven.apache.org/xsd/archetype-1.0.0.xsd">
+
+  <fileSets>
+    <fileSet filtered="true" packaged="true">
+      <directory>src/main/java</directory>
+      <includes>
+        <include>**/*.java</include>
+      </includes>
+    </fileSet>
+    
+    <fileSet filtered="true" packaged="true">
+      <directory>src/test/java</directory>
+      <includes>
+        <include>**/*.java</include>
+      </includes>
+    </fileSet>
+    
+    <!-- we cannot have src/main/resources/** be "packaged" (package dirs prepended) and non-packaged;
+         so we put everything non-packaged here.
+         (also note for src/main/java, the root pom uses google-replacer to drop the "package" directory) -->
+           
+    <fileSet filtered="false" packaged="false">
+      <directory></directory>
+      <includes>
+        <include>**/*.png</include>
+        <include>**/*.sh</include>
+      </includes>
+    </fileSet>
+    <fileSet filtered="true" packaged="false">
+      <directory></directory>
+      <includes>
+        <include>**/*</include>
+        <include>*</include>
+      </includes>
+      <excludes>
+        <exclude>src/main/java/**</exclude> 
+        <exclude>src/test/java/**</exclude> 
+        <exclude>pom.xml</exclude>
+        <exclude>**.png</exclude>
+        <exclude>**.sh</exclude>
+      </excludes>
+    </fileSet>
+  </fileSets>
+
+</archetype>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/test/resources/projects/integration-test-1/.gitignore
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/test/resources/projects/integration-test-1/.gitignore b/archetypes/quickstart/src/test/resources/projects/integration-test-1/.gitignore
new file mode 100644
index 0000000..25d80f5
--- /dev/null
+++ b/archetypes/quickstart/src/test/resources/projects/integration-test-1/.gitignore
@@ -0,0 +1 @@
+reference

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/test/resources/projects/integration-test-1/archetype.properties
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/test/resources/projects/integration-test-1/archetype.properties b/archetypes/quickstart/src/test/resources/projects/integration-test-1/archetype.properties
new file mode 100644
index 0000000..d1f4da4
--- /dev/null
+++ b/archetypes/quickstart/src/test/resources/projects/integration-test-1/archetype.properties
@@ -0,0 +1,22 @@
+#
+# 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.
+#
+groupId=com.acme.sample
+artifactId=brooklyn-sample
+version=0.1.0-SNAPSHOT
+package=com.acme.sample.brooklyn

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/archetypes/quickstart/src/test/resources/projects/integration-test-1/goal.txt
----------------------------------------------------------------------
diff --git a/archetypes/quickstart/src/test/resources/projects/integration-test-1/goal.txt b/archetypes/quickstart/src/test/resources/projects/integration-test-1/goal.txt
new file mode 100644
index 0000000..f7ffc47
--- /dev/null
+++ b/archetypes/quickstart/src/test/resources/projects/integration-test-1/goal.txt
@@ -0,0 +1 @@
+install
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/.gitattributes
----------------------------------------------------------------------
diff --git a/brooklyn-dist/.gitattributes b/brooklyn-dist/.gitattributes
deleted file mode 100644
index 7920d0e..0000000
--- a/brooklyn-dist/.gitattributes
+++ /dev/null
@@ -1,6 +0,0 @@
-#Don't auto-convert line endings for shell scripts on Windows (breaks the scripts)
-* text=auto
-*.sh text eol=lf
-*.bat text eol=crlf
-*.ps1 text eol=crlf
-*.ini text eol=crlf

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/.gitignore
----------------------------------------------------------------------
diff --git a/brooklyn-dist/.gitignore b/brooklyn-dist/.gitignore
deleted file mode 100644
index 2ef22e4..0000000
--- a/brooklyn-dist/.gitignore
+++ /dev/null
@@ -1,33 +0,0 @@
-\#*\#
-*~
-*.bak
-*.swp
-*.swo
-.DS_Store
-
-atlassian-ide-plugin.xml
-*.class
-
-target/
-test-output/
-
-.project
-.classpath
-.settings/
-.metadata/
-
-.idea/
-*.iml
-
-nbactions.xml
-nb-configuration.xml
-
-prodDb.*
-
-*.log
-brooklyn*.log.*
-
-*brooklyn-persisted-state/
-*.vagrant/
-
-ignored


[12/51] [abbrv] brooklyn-dist git commit: downstream-parent excludes a number of non-OSGi packages

Posted by he...@apache.org.
downstream-parent excludes a number of non-OSGi packages

All of them can break catalogue loading.


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

Branch: refs/heads/master
Commit: f5c7339158030c221de73b4203a655352fb008f4
Parents: 5e1c06b
Author: Sam Corbett <sa...@cloudsoftcorp.com>
Authored: Wed Dec 16 14:38:56 2015 +0000
Committer: Sam Corbett <sa...@cloudsoftcorp.com>
Committed: Thu Dec 17 12:28:02 2015 +0000

----------------------------------------------------------------------
 usage/downstream-parent/pom.xml | 23 ++++++++++++++++++++++-
 1 file changed, 22 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/f5c73391/usage/downstream-parent/pom.xml
----------------------------------------------------------------------
diff --git a/usage/downstream-parent/pom.xml b/usage/downstream-parent/pom.xml
index c4d5a74..c1731fd 100644
--- a/usage/downstream-parent/pom.xml
+++ b/usage/downstream-parent/pom.xml
@@ -448,8 +448,29 @@
               </supportedProjectTypes>
               <instructions>
                 <!--
+                  Exclude packages used by Brooklyn that are not OSGi bundles. Including any
+                  of the below may cause bundles to fail to load into the catalogue with
+                  messages like "Unable to resolve 150.0: missing requirement [150.0]
+                  osgi.wiring.package; (osgi.wiring.package=com.maxmind.geoip2)".
+                -->
+                <Import-Package>
+                  !com.maxmind.geoip2.*,
+                  !io.airlift.command.*,
+                  !io.cloudsoft.winrm4j.*,
+                  !javax.inject.*,
+                  !org.apache.felix.framework.*,
+                  !org.apache.http.*,
+                  !org.jclouds.googlecomputeengine.*,
+                  !org.osgi.jmx,
+                  !org.python.*,
+                  !org.reflections.*,
+                  !org.w3c.tidy.*,
+                  *
+                </Import-Package>
+                <!--
+                  Brooklyn-Feature prefix triggers inclusion of the project's metadata in the
+                  server's features list.
                 -->
-                <!-- Brooklyn-Feature prefix triggers inclusion of the project's metadata in the server's features list. -->
                 <Brooklyn-Feature-Name>${project.name}</Brooklyn-Feature-Name>
               </instructions>
             </configuration>


[21/51] [abbrv] brooklyn-dist git commit: [ALL] keep version properties in one place

Posted by he...@apache.org.
[ALL] keep version properties in one place

in server/pom.xml (inherited by parent) for most things, but library/pom.xml for software


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

Branch: refs/heads/master
Commit: cdd021ee7437b2c4b88d8120b3bf02eecb41c224
Parents: 6826326
Author: Alex Heneveld <al...@cloudsoftcorp.com>
Authored: Tue Dec 22 16:08:20 2015 +0000
Committer: Alex Heneveld <al...@cloudsoftcorp.com>
Committed: Tue Dec 22 16:49:42 2015 +0000

----------------------------------------------------------------------
 brooklyn-dist/dist/pom.xml | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/cdd021ee/brooklyn-dist/dist/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/pom.xml b/brooklyn-dist/dist/pom.xml
index a595094..0d01390 100644
--- a/brooklyn-dist/dist/pom.xml
+++ b/brooklyn-dist/dist/pom.xml
@@ -98,6 +98,7 @@
                     <excludes combine.children="append">
                         <!-- Exclude sample config files because they are illustrative, intended for changing -->
                         <exclude>src/main/dist/conf/**</exclude>
+                        <exclude>src/main/dist/README.md</exclude>
                         <exclude>licensing/licenses/**</exclude>
                         <exclude>licensing/README.md</exclude>
                         <exclude>licensing/*LICENSE*</exclude>


[18/51] [abbrv] brooklyn-dist git commit: [DIST] revert parent updates and move archetype to last built module (currently failing Rat)

Posted by he...@apache.org.
[DIST] revert parent updates and move archetype to last built module (currently failing Rat)


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

Branch: refs/heads/master
Commit: ff5a57c444eee369f7696cce123a845373e5922b
Parents: 445c9c1
Author: John McCabe <jo...@johnmccabe.net>
Authored: Sat Dec 19 19:21:19 2015 +0000
Committer: Alex Heneveld <al...@cloudsoftcorp.com>
Committed: Mon Dec 21 16:43:39 2015 +0000

----------------------------------------------------------------------
 brooklyn-dist/archetypes/quickstart/pom.xml                     | 4 ++--
 brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml | 1 -
 brooklyn-dist/pom.xml                                           | 2 +-
 3 files changed, 3 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/ff5a57c4/brooklyn-dist/archetypes/quickstart/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/pom.xml b/brooklyn-dist/archetypes/quickstart/pom.xml
index 39adbdd..7154f76 100644
--- a/brooklyn-dist/archetypes/quickstart/pom.xml
+++ b/brooklyn-dist/archetypes/quickstart/pom.xml
@@ -30,9 +30,9 @@
 
   <parent>
     <groupId>org.apache.brooklyn</groupId>
-    <artifactId>brooklyn-dist-root</artifactId>
+    <artifactId>brooklyn-parent</artifactId>
     <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-    <relativePath>../../pom.xml</relativePath>
+    <relativePath>../../../brooklyn-server/parent/pom.xml</relativePath>
   </parent>
 
   <build>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/ff5a57c4/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
index d1559a8..f879498 100644
--- a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
+++ b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
@@ -8,7 +8,6 @@
     <groupId>org.apache.brooklyn</groupId>
     <artifactId>brooklyn-downstream-parent</artifactId>
     <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-    <relativePath>../../../../downstream-parent/pom.xml</relativePath>
   </parent>
 
   <groupId>com.acme.sample</groupId>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/ff5a57c4/brooklyn-dist/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/pom.xml b/brooklyn-dist/pom.xml
index 904a20e..652738c 100644
--- a/brooklyn-dist/pom.xml
+++ b/brooklyn-dist/pom.xml
@@ -74,9 +74,9 @@
 
     <modules>
         <module>downstream-parent</module>
-        <module>archetypes/quickstart</module>
         <module>all</module>
         <module>dist</module>
+        <module>archetypes/quickstart</module>
     </modules>
 
 </project>


[11/51] [abbrv] brooklyn-dist git commit: downstream-parent does not set Export-Package

Posted by he...@apache.org.
downstream-parent does not set Export-Package

There's no need for a downstream project to automatically export
brooklyn.* and org.apache.brooklyn.* and it causes a number of issues
when loading bundles into catalogues.


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

Branch: refs/heads/master
Commit: 5e1c06b7bbfa3d8ad3e4a730bf6e0ae3f568b6c0
Parents: ba4d990
Author: Sam Corbett <sa...@cloudsoftcorp.com>
Authored: Wed Dec 16 14:38:11 2015 +0000
Committer: Sam Corbett <sa...@cloudsoftcorp.com>
Committed: Thu Dec 17 12:28:01 2015 +0000

----------------------------------------------------------------------
 usage/downstream-parent/pom.xml | 8 --------
 1 file changed, 8 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/5e1c06b7/usage/downstream-parent/pom.xml
----------------------------------------------------------------------
diff --git a/usage/downstream-parent/pom.xml b/usage/downstream-parent/pom.xml
index 6580281..c4d5a74 100644
--- a/usage/downstream-parent/pom.xml
+++ b/usage/downstream-parent/pom.xml
@@ -447,16 +447,8 @@
                 <supportedProjectType>jar</supportedProjectType>
               </supportedProjectTypes>
               <instructions>
-                <!-- OSGi specific instruction -->
                 <!--
-                    By default packages containing impl and internal
-                    are not included in the export list. Setting an
-                    explicit wildcard will include all packages
-                    regardless of name.
-                    In time we should minimize our export lists to
-                    what is really needed.
                 -->
-                <Export-Package>brooklyn.*,org.apache.brooklyn.*</Export-Package>
                 <!-- Brooklyn-Feature prefix triggers inclusion of the project's metadata in the server's features list. -->
                 <Brooklyn-Feature-Name>${project.name}</Brooklyn-Feature-Name>
               </instructions>


[45/51] [abbrv] brooklyn-dist git commit: move subdir from incubator up a level as it is promoted to its own repo (first non-incubator commit!)

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/vagrant/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/pom.xml b/brooklyn-dist/vagrant/pom.xml
deleted file mode 100644
index fbe6539..0000000
--- a/brooklyn-dist/vagrant/pom.xml
+++ /dev/null
@@ -1,83 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-    
-     http://www.apache.org/licenses/LICENSE-2.0
-    
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-    <modelVersion>4.0.0</modelVersion>
-    <packaging>pom</packaging>
-
-    <artifactId>brooklyn-vagrant</artifactId>
-
-    <name>Brooklyn Vagrant Getting Started Environment</name>
-    <description>
-        Brooklyn Getting Started Vagrant environment archive, includes all required
-        files to start Brooklyn and sample BYON nodes for use.
-    </description>
-
-    <parent>
-        <groupId>org.apache.brooklyn</groupId>
-        <artifactId>brooklyn-dist-root</artifactId>
-        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-        <relativePath>../pom.xml</relativePath>
-    </parent>
-
-    <build>
-        <plugins>
-            <plugin>
-                <artifactId>maven-assembly-plugin</artifactId>
-                <executions>
-                    <execution>
-                        <id>build-distribution-archive</id>
-                        <phase>package</phase>
-                        <goals>
-                            <goal>single</goal>
-                        </goals>
-                        <configuration>
-                            <appendAssemblyId>true</appendAssemblyId>
-                            <descriptors>
-                                <descriptor>src/main/config/build-distribution.xml</descriptor>
-                            </descriptors>
-                          <!-- finalName affects name in `target/` but we cannot influence name when it is attached/installed,
-                               so `apache-` prefix would be lost there. to keep it consistent this is commented out, 
-                               but would be nice to have if there is a way!
-                            <finalName>apache-brooklyn-${project.version}</finalName>
-                          -->
-                            <formats>
-                                <format>tar.gz</format>
-                                <format>zip</format>
-                            </formats>
-                        </configuration>
-                    </execution>
-                </executions>
-            </plugin>
-        </plugins>
-        <pluginManagement>
-            <plugins>
-                <plugin>
-                    <groupId>org.apache.rat</groupId>
-                    <artifactId>apache-rat-plugin</artifactId>
-                    <configuration>
-                        <excludes combine.children="append">
-                            <exclude>src/main/vagrant/README.md</exclude>
-                        </excludes>
-                    </configuration>
-                </plugin>
-            </plugins>
-        </pluginManagement>
-    </build>
-</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/vagrant/src/main/config/build-distribution.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/config/build-distribution.xml b/brooklyn-dist/vagrant/src/main/config/build-distribution.xml
deleted file mode 100644
index 823ad2a..0000000
--- a/brooklyn-dist/vagrant/src/main/config/build-distribution.xml
+++ /dev/null
@@ -1,33 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-    
-     http://www.apache.org/licenses/LICENSE-2.0
-    
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-<assembly xmlns="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2"
-        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-        xsi:schemaLocation="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2 http://maven.apache.org/xsd/assembly-1.1.2.xsd">
-    <id>dist</id>
-    <formats><!-- empty, intended for caller to specify --></formats>
-    <fileSets>
-        <fileSet>
-            <directory>${project.basedir}/src/main/vagrant</directory>
-            <outputDirectory></outputDirectory>
-            <fileMode>0644</fileMode>
-            <directoryMode>0755</directoryMode>
-        </fileSet>
-    </fileSets>
-</assembly>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/vagrant/src/main/vagrant/README.md
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/README.md b/brooklyn-dist/vagrant/src/main/vagrant/README.md
deleted file mode 100644
index 2f5573c..0000000
--- a/brooklyn-dist/vagrant/src/main/vagrant/README.md
+++ /dev/null
@@ -1,41 +0,0 @@
-
-# [![**Brooklyn**](https://brooklyn.apache.org/style/img/apache-brooklyn-logo-244px-wide.png)](http://brooklyn.apache.org/)
-
-### Using Vagrant with Brooklyn -SNAPSHOT builds
-
-##### Install a community-managed version from Maven
-1. No action is required other than setting the  `BROOKLYN_VERSION:` environment variable in `servers.yaml` to a `-SNAPSHOT` version. For example:
-
-   ```
-   env:
-     BROOKLYN_VERSION: 0.9.0-SNAPSHOT
-   ```
-
-2. You may proceed to use the `Vagrantfile` as normal; `vagrant up`, `vagrant destroy` etc.
-
-##### Install a locally built `-dist.tar.gz`
-
-1. Set the `BROOKLYN_VERSION:` environment variable in `servers.yaml` to your current `-SNAPSHOT` version. For example:
-
-   ```
-   env:
-     BROOKLYN_VERSION: 0.9.0-SNAPSHOT
-   ```
-
-2. Set the `INSTALL_FROM_LOCAL_DIST:` environment variable in `servers.yaml` to `true`. For example:
-
-   ```
-   env:
-     INSTALL_FROM_LOCAL_DIST: true
-   ```
-
-
-3. Copy your locally built `-dist.tar.gz` archive to the same directory as the Vagrantfile (this directory is mounted in the Vagrant VM at `/vagrant/`).
-
-   For example to copy a locally built `0.9.0-SNAPSHOT` dist:
-
-   ```
-   cp ~/.m2/repository/org/apache/brooklyn/brooklyn-dist/0.9.0-SNAPSHOT/brooklyn-dist-0.9.0-SNAPSHOT-dist.tar.gz .
-   ```
-
-4. You may proceed to use the `Vagrantfile` as normal; `vagrant up`, `vagrant destroy` etc.
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile b/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
deleted file mode 100644
index fb35a15..0000000
--- a/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
+++ /dev/null
@@ -1,76 +0,0 @@
-# -*- mode: ruby -*-
-# vi: set ft=ruby :
-#
-# 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.
-#
-
-# Specify minimum Vagrant version and Vagrant API version
-Vagrant.require_version ">= 1.8.1"
-VAGRANTFILE_API_VERSION = "2"
-
-# Update OS (Debian/RedHat based only)
-UPDATE_OS_CMD = "(sudo apt-get update && sudo apt-get -y upgrade) || (sudo yum -y update)"
-
-# Require YAML module
-require 'yaml'
-
-# Read YAML file with box details
-yaml_cfg = YAML.load_file(__dir__ + '/servers.yaml')
-
-# Create boxes
-Vagrant.configure(VAGRANTFILE_API_VERSION) do |config|
-
-  # Iterate through server entries in YAML file
-  yaml_cfg["servers"].each do |server|
-    config.vm.define server["name"] do |server_config|
-
-      server_config.vm.box = server["box"]
-
-      server_config.vm.box_check_update = yaml_cfg["default_config"]["check_newer_vagrant_box"]
-
-      if server.has_key?("ip")
-        server_config.vm.network "private_network", ip: server["ip"]
-      end
-
-      if server.has_key?("forwarded_ports")
-        server["forwarded_ports"].each do |ports|
-          server_config.vm.network "forwarded_port", guest: ports["guest"], host: ports["host"], guest_ip: ports["guest_ip"]
-        end
-      end
-
-      server_config.vm.hostname = server["name"]
-      server_config.vm.provider :virtualbox do |vb|
-        vb.name = server["name"]
-        vb.memory = server["ram"]
-        vb.cpus = server["cpus"]
-      end
-
-      if yaml_cfg["default_config"]["run_os_update"]
-        server_config.vm.provision "shell", privileged: false, inline: UPDATE_OS_CMD
-      end
-
-      if server["shell"] && server["shell"]["cmd"]
-        server["shell"]["cmd"].each do |cmd|
-          server_config.vm.provision "shell", privileged: false, inline: cmd, env: server["shell"]["env"]
-        end
-      end
-
-      server_config.vm.post_up_message = server["post_up_message"]
-    end
-  end
-end
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties b/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties
deleted file mode 100644
index 0784ff3..0000000
--- a/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties
+++ /dev/null
@@ -1,23 +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.
-#
-
-# Disabling security on the Vagrant Brooklyn instance for training purposes
-brooklyn.webconsole.security.provider = org.apache.brooklyn.rest.security.provider.AnyoneSecurityProvider
-
-# Note: BYON locations are loaded from the files/vagrant-catalog.bom on startup
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service b/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service
deleted file mode 100644
index 28b0fea..0000000
--- a/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service
+++ /dev/null
@@ -1,32 +0,0 @@
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#  http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-[Unit]
-Description=Apache Brooklyn service
-Documentation=http://brooklyn.apache.org/documentation/index.html
-
-[Service]
-ExecStart=/home/vagrant/apache-brooklyn/bin/brooklyn launch --persist auto --persistenceDir /vagrant/brooklyn-persisted-state --catalogAdd /vagrant/files/vagrant-catalog.bom
-WorkingDirectory=/home/vagrant/apache-brooklyn
-Restart=on-abort
-User=vagrant
-Group=vagrant
-
-[Install]
-WantedBy=multi-user.target

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/vagrant/src/main/vagrant/files/install_brooklyn.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/files/install_brooklyn.sh b/brooklyn-dist/vagrant/src/main/vagrant/files/install_brooklyn.sh
deleted file mode 100755
index 9c52017..0000000
--- a/brooklyn-dist/vagrant/src/main/vagrant/files/install_brooklyn.sh
+++ /dev/null
@@ -1,92 +0,0 @@
-#!/usr/bin/env bash
-
-#
-# 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.
-#
-
-BROOKLYN_VERSION=""
-INSTALL_FROM_LOCAL_DIST="false"
-TMP_ARCHIVE_NAME=apache-brooklyn.tar.gz
-
-do_help() {
-  echo "./install.sh -v <Brooklyn Version> [-l <install from local file: true|false>]"
-  exit 1
-}
-
-while getopts ":hv:l:" opt; do
-    case "$opt" in
-    v)  BROOKLYN_VERSION=$OPTARG ;;
-        # using a true/false argopt rather than just flag to allow easier integration with servers.yaml config
-    l)  INSTALL_FROM_LOCAL_DIST=$OPTARG ;;
-    h)  do_help;;
-    esac
-done
-
-# Exit if any step fails
-set -e
-
-if [ "x${BROOKLYN_VERSION}" == "x" ]; then
-  echo "Error: you must supply a Brooklyn version [-v]"
-  do_help
-fi
-
-if [ ! "${INSTALL_FROM_LOCAL_DIST}" == "true" ]; then
-  if [ ! -z "${BROOKLYN_VERSION##*-SNAPSHOT}" ] ; then
-    # url for official release versions
-    BROOKLYN_URL="https://www.apache.org/dyn/closer.lua?action=download&filename=brooklyn/apache-brooklyn-${BROOKLYN_VERSION}/apache-brooklyn-${BROOKLYN_VERSION}-bin.tar.gz"
-    BROOKLYN_DIR="apache-brooklyn-${BROOKLYN_VERSION}-bin"
-  else
-    # url for community-managed snapshots
-    BROOKLYN_URL="https://repository.apache.org/service/local/artifact/maven/redirect?r=snapshots&g=org.apache.brooklyn&a=brooklyn-dist&v=${BROOKLYN_VERSION}&c=dist&e=tar.gz"
-    BROOKLYN_DIR="brooklyn-dist-${BROOKLYN_VERSION}"
-  fi
-else
-  echo "Installing from a local -dist archive [ /vagrant/brooklyn-dist-${BROOKLYN_VERSION}-dist.tar.gz]"
-  # url to install from mounted /vagrant dir
-  BROOKLYN_URL="file:///vagrant/brooklyn-dist-${BROOKLYN_VERSION}-dist.tar.gz"
-  BROOKLYN_DIR="brooklyn-dist-${BROOKLYN_VERSION}"
-
-  # ensure local file exists
-  if [ ! -f /vagrant/brooklyn-dist-${BROOKLYN_VERSION}-dist.tar.gz ]; then
-    echo "Error: file not found /vagrant/brooklyn-dist-${BROOKLYN_VERSION}-dist.tar.gz"
-    exit 1
-  fi
-fi
-
-echo "Installing Apache Brooklyn version ${BROOKLYN_VERSION} from [${BROOKLYN_URL}]"
-
-echo "Downloading Brooklyn release archive"
-curl --fail --silent --show-error --location --output ${TMP_ARCHIVE_NAME} "${BROOKLYN_URL}"
-echo "Extracting Brooklyn release archive"
-tar zxf ${TMP_ARCHIVE_NAME}
-
-echo "Creating Brooklyn dirs and symlinks"
-ln -s ${BROOKLYN_DIR} apache-brooklyn
-sudo mkdir -p /var/log/brooklyn
-sudo chown -R vagrant:vagrant /var/log/brooklyn
-mkdir -p /home/vagrant/.brooklyn
-
-echo "Copying default vagrant Brooklyn properties file"
-cp /vagrant/files/brooklyn.properties /home/vagrant/.brooklyn/
-chmod 600 /home/vagrant/.brooklyn/brooklyn.properties
-
-echo "Installing JRE"
-sudo sh -c 'export DEBIAN_FRONTEND=noninteractive; apt-get install --yes openjdk-8-jre-headless'
-
-echo "Copying Brooklyn systemd service unit file"
-sudo cp /vagrant/files/brooklyn.service /etc/systemd/system/brooklyn.service
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/vagrant/src/main/vagrant/files/logback.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/files/logback.xml b/brooklyn-dist/vagrant/src/main/vagrant/files/logback.xml
deleted file mode 100644
index 1560d8b..0000000
--- a/brooklyn-dist/vagrant/src/main/vagrant/files/logback.xml
+++ /dev/null
@@ -1,32 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-
-<configuration scan="true">
-
-    <!-- to supply custom logging, either change this file, supply your own logback-main.xml
-         (overriding the default provided on the classpath) or any of the files it references;
-         see the Logging section of the Brooklyn web site for more information -->
-
-    <property name="logging.basename" scope="context" value="brooklyn" />
-    <property name="logging.dir" scope="context" value="/var/log/brooklyn/" />
-
-    <include resource="logback-main.xml"/>
-
-</configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/vagrant/src/main/vagrant/files/vagrant-catalog.bom
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/files/vagrant-catalog.bom b/brooklyn-dist/vagrant/src/main/vagrant/files/vagrant-catalog.bom
deleted file mode 100644
index d8b8450..0000000
--- a/brooklyn-dist/vagrant/src/main/vagrant/files/vagrant-catalog.bom
+++ /dev/null
@@ -1,82 +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.
-#
-brooklyn.catalog:
-  items:
-  - id: byon1
-    name: Vagrant BYON VM 1
-    version: 0.9.0-SNAPSHOT  # BROOKLYN_VERSION
-    itemType: location
-    item:
-      type: byon
-      brooklyn.config:
-        user: vagrant
-        password: vagrant
-        hosts:
-        - 10.10.10.101
-
-  - id: byon2
-    name: Vagrant BYON VM 2
-    version: 0.9.0-SNAPSHOT  # BROOKLYN_VERSION
-    itemType: location
-    item:
-      type: byon
-      brooklyn.config:
-        user: vagrant
-        password: vagrant
-        hosts:
-        - 10.10.10.102
-
-  - id: byon3
-    name: Vagrant BYON VM 3
-    version: 0.9.0-SNAPSHOT  # BROOKLYN_VERSION
-    itemType: location
-    item:
-      type: byon
-      brooklyn.config:
-        user: vagrant
-        password: vagrant
-        hosts:
-        - 10.10.10.103
-
-  - id: byon4
-    name: Vagrant BYON VM 4
-    version: 0.9.0-SNAPSHOT  # BROOKLYN_VERSION
-    itemType: location
-    item:
-      type: byon
-      brooklyn.config:
-        user: vagrant
-        password: vagrant
-        hosts:
-        - 10.10.10.104
-
-  - id: byon-all
-    name: Vagrant BYON VM 1-4
-    version: 0.9.0-SNAPSHOT  # BROOKLYN_VERSION
-    itemType: location
-    item:
-      type: byon
-      brooklyn.config:
-        user: vagrant
-        password: vagrant
-        hosts:
-        - 10.10.10.101
-        - 10.10.10.102
-        - 10.10.10.103
-        - 10.10.10.104

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml b/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml
deleted file mode 100644
index 3959fff..0000000
--- a/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml
+++ /dev/null
@@ -1,73 +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.
-#
-#
-# Default Config
-#   check_newer_vagrant_box
-#     enable/disable the vagrant check for an updated box
-#   run_os_update
-#     enable/disable running a yum/apt-get update on box start
-#
-# Brooklyn Server Config
-#   shell:env:BROOKLYN_VERSION
-#     specifies the version of Brooklyn to install, be aware that for SNAPSHOTS you
-#     may wish to download a local -dist.tar.gz for the latest version.
-#   shell:env:INSTALL_FROM_LOCAL_DIST
-#     if set to `true` Vagrant will install from a local -dist.tar.gz stored in /vagrant
-#     on the guest VM (which is mounted from the Vagrantfile directory). You must
-#     ensure that a -dist.tar.gz archive has been copied to this directory on your host.
-
----
-default_config:
-    check_newer_vagrant_box: true
-    run_os_update: true
-servers:
-  - name: brooklyn
-    box: ubuntu/vivid64
-    ram: 2048
-    cpus: 4
-    ip: 10.10.10.100
-    shell:
-      env:
-        BROOKLYN_VERSION: 0.9.0-SNAPSHOT
-        INSTALL_FROM_LOCAL_DIST: false
-      cmd:
-        - /vagrant/files/install_brooklyn.sh -v ${BROOKLYN_VERSION} -l ${INSTALL_FROM_LOCAL_DIST}
-        - sudo systemctl start brooklyn
-        - sudo systemctl enable brooklyn
-  - name: byon1
-    box: ubuntu/vivid64
-    ram: 512
-    cpus: 2
-    ip: 10.10.10.101
-  - name: byon2
-    box: ubuntu/vivid64
-    ram: 512
-    cpus: 2
-    ip: 10.10.10.102
-  - name: byon3
-    box: ubuntu/vivid64
-    ram: 512
-    cpus: 2
-    ip: 10.10.10.103
-  - name: byon4
-    box: ubuntu/vivid64
-    ram: 512
-    cpus: 2
-    ip: 10.10.10.104
-...

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/.gitignore
----------------------------------------------------------------------
diff --git a/dist/licensing/.gitignore b/dist/licensing/.gitignore
new file mode 100644
index 0000000..2d17061
--- /dev/null
+++ b/dist/licensing/.gitignore
@@ -0,0 +1,2 @@
+LICENSE.autogenerated
+notices.autogenerated

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/MAIN_LICENSE_ASL2
----------------------------------------------------------------------
diff --git a/dist/licensing/MAIN_LICENSE_ASL2 b/dist/licensing/MAIN_LICENSE_ASL2
new file mode 100644
index 0000000..68c771a
--- /dev/null
+++ b/dist/licensing/MAIN_LICENSE_ASL2
@@ -0,0 +1,176 @@
+
+                                 Apache License
+                           Version 2.0, January 2004
+                        http://www.apache.org/licenses/
+
+   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+
+   1. Definitions.
+
+      "License" shall mean the terms and conditions for use, reproduction,
+      and distribution as defined by Sections 1 through 9 of this document.
+
+      "Licensor" shall mean the copyright owner or entity authorized by
+      the copyright owner that is granting the License.
+
+      "Legal Entity" shall mean the union of the acting entity and all
+      other entities that control, are controlled by, or are under common
+      control with that entity. For the purposes of this definition,
+      "control" means (i) the power, direct or indirect, to cause the
+      direction or management of such entity, whether by contract or
+      otherwise, or (ii) ownership of fifty percent (50%) or more of the
+      outstanding shares, or (iii) beneficial ownership of such entity.
+
+      "You" (or "Your") shall mean an individual or Legal Entity
+      exercising permissions granted by this License.
+
+      "Source" form shall mean the preferred form for making modifications,
+      including but not limited to software source code, documentation
+      source, and configuration files.
+
+      "Object" form shall mean any form resulting from mechanical
+      transformation or translation of a Source form, including but
+      not limited to compiled object code, generated documentation,
+      and conversions to other media types.
+
+      "Work" shall mean the work of authorship, whether in Source or
+      Object form, made available under the License, as indicated by a
+      copyright notice that is included in or attached to the work
+      (an example is provided in the Appendix below).
+
+      "Derivative Works" shall mean any work, whether in Source or Object
+      form, that is based on (or derived from) the Work and for which the
+      editorial revisions, annotations, elaborations, or other modifications
+      represent, as a whole, an original work of authorship. For the purposes
+      of this License, Derivative Works shall not include works that remain
+      separable from, or merely link (or bind by name) to the interfaces of,
+      the Work and Derivative Works thereof.
+
+      "Contribution" shall mean any work of authorship, including
+      the original version of the Work and any modifications or additions
+      to that Work or Derivative Works thereof, that is intentionally
+      submitted to Licensor for inclusion in the Work by the copyright owner
+      or by an individual or Legal Entity authorized to submit on behalf of
+      the copyright owner. For the purposes of this definition, "submitted"
+      means any form of electronic, verbal, or written communication sent
+      to the Licensor or its representatives, including but not limited to
+      communication on electronic mailing lists, source code control systems,
+      and issue tracking systems that are managed by, or on behalf of, the
+      Licensor for the purpose of discussing and improving the Work, but
+      excluding communication that is conspicuously marked or otherwise
+      designated in writing by the copyright owner as "Not a Contribution."
+
+      "Contributor" shall mean Licensor and any individual or Legal Entity
+      on behalf of whom a Contribution has been received by Licensor and
+      subsequently incorporated within the Work.
+
+   2. Grant of Copyright License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      copyright license to reproduce, prepare Derivative Works of,
+      publicly display, publicly perform, sublicense, and distribute the
+      Work and such Derivative Works in Source or Object form.
+
+   3. Grant of Patent License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      (except as stated in this section) patent license to make, have made,
+      use, offer to sell, sell, import, and otherwise transfer the Work,
+      where such license applies only to those patent claims licensable
+      by such Contributor that are necessarily infringed by their
+      Contribution(s) alone or by combination of their Contribution(s)
+      with the Work to which such Contribution(s) was submitted. If You
+      institute patent litigation against any entity (including a
+      cross-claim or counterclaim in a lawsuit) alleging that the Work
+      or a Contribution incorporated within the Work constitutes direct
+      or contributory patent infringement, then any patent licenses
+      granted to You under this License for that Work shall terminate
+      as of the date such litigation is filed.
+
+   4. Redistribution. You may reproduce and distribute copies of the
+      Work or Derivative Works thereof in any medium, with or without
+      modifications, and in Source or Object form, provided that You
+      meet the following conditions:
+
+      (a) You must give any other recipients of the Work or
+          Derivative Works a copy of this License; and
+
+      (b) You must cause any modified files to carry prominent notices
+          stating that You changed the files; and
+
+      (c) You must retain, in the Source form of any Derivative Works
+          that You distribute, all copyright, patent, trademark, and
+          attribution notices from the Source form of the Work,
+          excluding those notices that do not pertain to any part of
+          the Derivative Works; and
+
+      (d) If the Work includes a "NOTICE" text file as part of its
+          distribution, then any Derivative Works that You distribute must
+          include a readable copy of the attribution notices contained
+          within such NOTICE file, excluding those notices that do not
+          pertain to any part of the Derivative Works, in at least one
+          of the following places: within a NOTICE text file distributed
+          as part of the Derivative Works; within the Source form or
+          documentation, if provided along with the Derivative Works; or,
+          within a display generated by the Derivative Works, if and
+          wherever such third-party notices normally appear. The contents
+          of the NOTICE file are for informational purposes only and
+          do not modify the License. You may add Your own attribution
+          notices within Derivative Works that You distribute, alongside
+          or as an addendum to the NOTICE text from the Work, provided
+          that such additional attribution notices cannot be construed
+          as modifying the License.
+
+      You may add Your own copyright statement to Your modifications and
+      may provide additional or different license terms and conditions
+      for use, reproduction, or distribution of Your modifications, or
+      for any such Derivative Works as a whole, provided Your use,
+      reproduction, and distribution of the Work otherwise complies with
+      the conditions stated in this License.
+
+   5. Submission of Contributions. Unless You explicitly state otherwise,
+      any Contribution intentionally submitted for inclusion in the Work
+      by You to the Licensor shall be under the terms and conditions of
+      this License, without any additional terms or conditions.
+      Notwithstanding the above, nothing herein shall supersede or modify
+      the terms of any separate license agreement you may have executed
+      with Licensor regarding such Contributions.
+
+   6. Trademarks. This License does not grant permission to use the trade
+      names, trademarks, service marks, or product names of the Licensor,
+      except as required for reasonable and customary use in describing the
+      origin of the Work and reproducing the content of the NOTICE file.
+
+   7. Disclaimer of Warranty. Unless required by applicable law or
+      agreed to in writing, Licensor provides the Work (and each
+      Contributor provides its Contributions) on an "AS IS" BASIS,
+      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+      implied, including, without limitation, any warranties or conditions
+      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
+      PARTICULAR PURPOSE. You are solely responsible for determining the
+      appropriateness of using or redistributing the Work and assume any
+      risks associated with Your exercise of permissions under this License.
+
+   8. Limitation of Liability. In no event and under no legal theory,
+      whether in tort (including negligence), contract, or otherwise,
+      unless required by applicable law (such as deliberate and grossly
+      negligent acts) or agreed to in writing, shall any Contributor be
+      liable to You for damages, including any direct, indirect, special,
+      incidental, or consequential damages of any character arising as a
+      result of this License or out of the use or inability to use the
+      Work (including but not limited to damages for loss of goodwill,
+      work stoppage, computer failure or malfunction, or any and all
+      other commercial damages or losses), even if such Contributor
+      has been advised of the possibility of such damages.
+
+   9. Accepting Warranty or Additional Liability. While redistributing
+      the Work or Derivative Works thereof, You may choose to offer,
+      and charge a fee for, acceptance of support, warranty, indemnity,
+      or other liability obligations and/or rights consistent with this
+      License. However, in accepting such obligations, You may act only
+      on Your own behalf and on Your sole responsibility, not on behalf
+      of any other Contributor, and only if You agree to indemnify,
+      defend, and hold each Contributor harmless for any liability
+      incurred by, or claims asserted against, such Contributor by reason
+      of your accepting any such warranty or additional liability.
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/README.md
----------------------------------------------------------------------
diff --git a/dist/licensing/README.md b/dist/licensing/README.md
new file mode 100644
index 0000000..94ae070
--- /dev/null
+++ b/dist/licensing/README.md
@@ -0,0 +1,78 @@
+
+We use a special maven plugin and scripts to automatically create the LICENSE
+files, including all notices, based on metadata in overrides.yaml and **/source-inclusions.yaml.
+
+First install  https://github.com/ahgittin/license-audit-maven-plugin 
+and then, in the usage/dist/ project of Brooklyn...
+
+
+# Quick Usage
+
+To see a tree of license info:
+
+    mvn org.heneveld.maven:license-audit-maven-plugin:report \
+        -Dformat=summary \
+        -DlicensesPreferred=ASL2,ASL,EPL1,BSD-2-Clause,BSD-3-Clause,CDDL1.1,CDDL1,CDDL \
+        -DoverridesFile=licensing/overrides.yaml \
+        -DextrasFiles=`cat licensing/extras-files`
+
+
+To create the LICENSE files needed for Apache Brooklyn
+(consisting of: one in the root for the source build, in the dist project for the binary build,
+and in `projects-with-custom-licenses` for those JARs which include other source code):
+
+    pushd licensing
+    ./make-all-licenses.sh || ( echo 'FAILED!!!' && rm LICENSE.autogenerated )
+    popd
+
+This combines the relevant `source-inclusions.yaml` files to create `extrasFile` files
+for `license-audit-maven-plugin` then runs the `notices` target for the various dists we make.
+If you need to add a new project to those which require custom LICENSE files, see below.
+
+
+# CSV License Report
+
+If you need to generate a CSV report of license usage, e.g. for use in a spreadsheet:
+
+    mvn org.heneveld.maven:license-audit-maven-plugin:report \
+        -Dformat=csv \
+        -DlistDependencyIdOnly=true \
+        -DsuppressExcludedDependencies=true \
+        -DlicensesPreferred=ASL2,ASL,EPL1,BSD-2-Clause,BSD-3-Clause,CDDL1.1,CDDL1,CDDL \
+        -DoverridesFile=licensing/overrides.yaml \
+        -DextrasFiles=`cat licensing/extras-files` \
+        -DoutputFile=dependencies-licenses.csv
+
+
+# When Projects Need Custom Licenses
+
+If a JAR includes 3rd party source code (as opposed to binary dependencies), it will typically 
+require a custom LICENSE file.
+
+To support this: 
+
+1. Add the relative path to that project to `projects-with-custom-licenses`,
+
+2. Create the necessary file structure and maven instructions:
+
+* in `src/main/license/` put a `README.md` pointing here
+* in `src/main/license/` put a `source-inclusion.yaml` listing the included 3rd-party projects by an `id:`
+  (you may need to choose an ID; this should be a meaningful name, e.g. `typeahead.js` or `Swagger UI`)
+* in `src/main/license/files` put the relevant non-LICENSE license files you want included (e.g. NOTICE)
+* in `src/test/license/files` put the standard files *including* LICENSE to include in the test JAR
+  (NB: these scripts don't generate custom licenses for test JARs, as so far that has not been needed)
+* in `pom.xml` add instructions to include `src/{main,test}/license/files` in the main and test JARs
+
+You can follow the pattern done for `cli` and `jsgui`.
+
+3. In `licensing/overrides.yaml` in this directory, add the metadata for the included projects.
+
+4. In `licensing/licenses/<your_project>/` include the relevant licenses for any included 3rd-party projects;
+   look in `licensing/licenses/binary` for samples.
+
+5. Run `make-all-licenses.sh` to auto-generate required config files and license copies,
+   and to generate the LICENSE for your project.
+
+Confirm that a LICENSE file for your project was generated, and that it is present in the JAR,
+and then open a pull-request, and confirm the changes there are appropriate.
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/extras-files
----------------------------------------------------------------------
diff --git a/dist/licensing/extras-files b/dist/licensing/extras-files
new file mode 100644
index 0000000..cbba9c5
--- /dev/null
+++ b/dist/licensing/extras-files
@@ -0,0 +1 @@
+../../brooklyn-ui/src/main/license/source-inclusions.yaml:../../brooklyn-server/server-cli/src/main/license/source-inclusions.yaml

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/binary/ASL2
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/binary/ASL2 b/dist/licensing/licenses/binary/ASL2
new file mode 100644
index 0000000..eccbc6a
--- /dev/null
+++ b/dist/licensing/licenses/binary/ASL2
@@ -0,0 +1,177 @@
+Apache License, Version 2.0
+
+  Apache License
+  Version 2.0, January 2004
+  http://www.apache.org/licenses/
+  
+  TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+  
+  1. Definitions.
+  
+  "License" shall mean the terms and conditions for use, reproduction,
+  and distribution as defined by Sections 1 through 9 of this document.
+  
+  "Licensor" shall mean the copyright owner or entity authorized by
+  the copyright owner that is granting the License.
+  
+  "Legal Entity" shall mean the union of the acting entity and all
+  other entities that control, are controlled by, or are under common
+  control with that entity. For the purposes of this definition,
+  "control" means (i) the power, direct or indirect, to cause the
+  direction or management of such entity, whether by contract or
+  otherwise, or (ii) ownership of fifty percent (50%) or more of the
+  outstanding shares, or (iii) beneficial ownership of such entity.
+  
+  "You" (or "Your") shall mean an individual or Legal Entity
+  exercising permissions granted by this License.
+  
+  "Source" form shall mean the preferred form for making modifications,
+  including but not limited to software source code, documentation
+  source, and configuration files.
+  
+  "Object" form shall mean any form resulting from mechanical
+  transformation or translation of a Source form, including but
+  not limited to compiled object code, generated documentation,
+  and conversions to other media types.
+  
+  "Work" shall mean the work of authorship, whether in Source or
+  Object form, made available under the License, as indicated by a
+  copyright notice that is included in or attached to the work
+  (an example is provided in the Appendix below).
+  
+  "Derivative Works" shall mean any work, whether in Source or Object
+  form, that is based on (or derived from) the Work and for which the
+  editorial revisions, annotations, elaborations, or other modifications
+  represent, as a whole, an original work of authorship. For the purposes
+  of this License, Derivative Works shall not include works that remain
+  separable from, or merely link (or bind by name) to the interfaces of,
+  the Work and Derivative Works thereof.
+  
+  "Contribution" shall mean any work of authorship, including
+  the original version of the Work and any modifications or additions
+  to that Work or Derivative Works thereof, that is intentionally
+  submitted to Licensor for inclusion in the Work by the copyright owner
+  or by an individual or Legal Entity authorized to submit on behalf of
+  the copyright owner. For the purposes of this definition, "submitted"
+  means any form of electronic, verbal, or written communication sent
+  to the Licensor or its representatives, including but not limited to
+  communication on electronic mailing lists, source code control systems,
+  and issue tracking systems that are managed by, or on behalf of, the
+  Licensor for the purpose of discussing and improving the Work, but
+  excluding communication that is conspicuously marked or otherwise
+  designated in writing by the copyright owner as "Not a Contribution."
+  
+  "Contributor" shall mean Licensor and any individual or Legal Entity
+  on behalf of whom a Contribution has been received by Licensor and
+  subsequently incorporated within the Work.
+  
+  2. Grant of Copyright License. Subject to the terms and conditions of
+  this License, each Contributor hereby grants to You a perpetual,
+  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+  copyright license to reproduce, prepare Derivative Works of,
+  publicly display, publicly perform, sublicense, and distribute the
+  Work and such Derivative Works in Source or Object form.
+  
+  3. Grant of Patent License. Subject to the terms and conditions of
+  this License, each Contributor hereby grants to You a perpetual,
+  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+  (except as stated in this section) patent license to make, have made,
+  use, offer to sell, sell, import, and otherwise transfer the Work,
+  where such license applies only to those patent claims licensable
+  by such Contributor that are necessarily infringed by their
+  Contribution(s) alone or by combination of their Contribution(s)
+  with the Work to which such Contribution(s) was submitted. If You
+  institute patent litigation against any entity (including a
+  cross-claim or counterclaim in a lawsuit) alleging that the Work
+  or a Contribution incorporated within the Work constitutes direct
+  or contributory patent infringement, then any patent licenses
+  granted to You under this License for that Work shall terminate
+  as of the date such litigation is filed.
+  
+  4. Redistribution. You may reproduce and distribute copies of the
+  Work or Derivative Works thereof in any medium, with or without
+  modifications, and in Source or Object form, provided that You
+  meet the following conditions:
+  
+  (a) You must give any other recipients of the Work or
+  Derivative Works a copy of this License; and
+  
+  (b) You must cause any modified files to carry prominent notices
+  stating that You changed the files; and
+  
+  (c) You must retain, in the Source form of any Derivative Works
+  that You distribute, all copyright, patent, trademark, and
+  attribution notices from the Source form of the Work,
+  excluding those notices that do not pertain to any part of
+  the Derivative Works; and
+  
+  (d) If the Work includes a "NOTICE" text file as part of its
+  distribution, then any Derivative Works that You distribute must
+  include a readable copy of the attribution notices contained
+  within such NOTICE file, excluding those notices that do not
+  pertain to any part of the Derivative Works, in at least one
+  of the following places: within a NOTICE text file distributed
+  as part of the Derivative Works; within the Source form or
+  documentation, if provided along with the Derivative Works; or,
+  within a display generated by the Derivative Works, if and
+  wherever such third-party notices normally appear. The contents
+  of the NOTICE file are for informational purposes only and
+  do not modify the License. You may add Your own attribution
+  notices within Derivative Works that You distribute, alongside
+  or as an addendum to the NOTICE text from the Work, provided
+  that such additional attribution notices cannot be construed
+  as modifying the License.
+  
+  You may add Your own copyright statement to Your modifications and
+  may provide additional or different license terms and conditions
+  for use, reproduction, or distribution of Your modifications, or
+  for any such Derivative Works as a whole, provided Your use,
+  reproduction, and distribution of the Work otherwise complies with
+  the conditions stated in this License.
+  
+  5. Submission of Contributions. Unless You explicitly state otherwise,
+  any Contribution intentionally submitted for inclusion in the Work
+  by You to the Licensor shall be under the terms and conditions of
+  this License, without any additional terms or conditions.
+  Notwithstanding the above, nothing herein shall supersede or modify
+  the terms of any separate license agreement you may have executed
+  with Licensor regarding such Contributions.
+  
+  6. Trademarks. This License does not grant permission to use the trade
+  names, trademarks, service marks, or product names of the Licensor,
+  except as required for reasonable and customary use in describing the
+  origin of the Work and reproducing the content of the NOTICE file.
+  
+  7. Disclaimer of Warranty. Unless required by applicable law or
+  agreed to in writing, Licensor provides the Work (and each
+  Contributor provides its Contributions) on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+  implied, including, without limitation, any warranties or conditions
+  of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
+  PARTICULAR PURPOSE. You are solely responsible for determining the
+  appropriateness of using or redistributing the Work and assume any
+  risks associated with Your exercise of permissions under this License.
+  
+  8. Limitation of Liability. In no event and under no legal theory,
+  whether in tort (including negligence), contract, or otherwise,
+  unless required by applicable law (such as deliberate and grossly
+  negligent acts) or agreed to in writing, shall any Contributor be
+  liable to You for damages, including any direct, indirect, special,
+  incidental, or consequential damages of any character arising as a
+  result of this License or out of the use or inability to use the
+  Work (including but not limited to damages for loss of goodwill,
+  work stoppage, computer failure or malfunction, or any and all
+  other commercial damages or losses), even if such Contributor
+  has been advised of the possibility of such damages.
+  
+  9. Accepting Warranty or Additional Liability. While redistributing
+  the Work or Derivative Works thereof, You may choose to offer,
+  and charge a fee for, acceptance of support, warranty, indemnity,
+  or other liability obligations and/or rights consistent with this
+  License. However, in accepting such obligations, You may act only
+  on Your own behalf and on Your sole responsibility, not on behalf
+  of any other Contributor, and only if You agree to indemnify,
+  defend, and hold each Contributor harmless for any liability
+  incurred by, or claims asserted against, such Contributor by reason
+  of your accepting any such warranty or additional liability.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/binary/BSD-2-Clause
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/binary/BSD-2-Clause b/dist/licensing/licenses/binary/BSD-2-Clause
new file mode 100644
index 0000000..832c10e
--- /dev/null
+++ b/dist/licensing/licenses/binary/BSD-2-Clause
@@ -0,0 +1,23 @@
+The BSD 2-Clause License
+
+  Redistribution and use in source and binary forms, with or without
+  modification, are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, this
+  list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice,
+  this list of conditions and the following disclaimer in the documentation
+  and/or other materials provided with the distribution.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
+  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
+  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
+  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
+  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
+  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
+  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
+  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/binary/BSD-3-Clause
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/binary/BSD-3-Clause b/dist/licensing/licenses/binary/BSD-3-Clause
new file mode 100644
index 0000000..be2692c
--- /dev/null
+++ b/dist/licensing/licenses/binary/BSD-3-Clause
@@ -0,0 +1,27 @@
+The BSD 3-Clause License ("New BSD")
+
+  Redistribution and use in source and binary forms, with or without modification,
+  are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, 
+  this list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice, 
+  this list of conditions and the following disclaimer in the documentation 
+  and/or other materials provided with the distribution.
+  
+  3. Neither the name of the copyright holder nor the names of its contributors 
+  may be used to endorse or promote products derived from this software without 
+  specific prior written permission.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
+  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
+  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
+  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
+  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
+  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
+  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
+  POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/binary/CDDL1
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/binary/CDDL1 b/dist/licensing/licenses/binary/CDDL1
new file mode 100644
index 0000000..611d916
--- /dev/null
+++ b/dist/licensing/licenses/binary/CDDL1
@@ -0,0 +1,381 @@
+COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.0
+
+  1. Definitions.
+  
+  1.1. "Contributor" means each individual or entity that
+  creates or contributes to the creation of Modifications.
+  
+  1.2. "Contributor Version" means the combination of the
+  Original Software, prior Modifications used by a
+  Contributor (if any), and the Modifications made by that
+  particular Contributor.
+  
+  1.3. "Covered Software" means (a) the Original Software, or
+  (b) Modifications, or (c) the combination of files
+  containing Original Software with files containing
+  Modifications, in each case including portions thereof.
+  
+  1.4. "Executable" means the Covered Software in any form
+  other than Source Code. 
+  
+  1.5. "Initial Developer" means the individual or entity
+  that first makes Original Software available under this
+  License. 
+  
+  1.6. "Larger Work" means a work which combines Covered
+  Software or portions thereof with code not governed by the
+  terms of this License.
+  
+  1.7. "License" means this document.
+  
+  1.8. "Licensable" means having the right to grant, to the
+  maximum extent possible, whether at the time of the initial
+  grant or subsequently acquired, any and all of the rights
+  conveyed herein.
+  
+  1.9. "Modifications" means the Source Code and Executable
+  form of any of the following: 
+  
+  A. Any file that results from an addition to,
+  deletion from or modification of the contents of a
+  file containing Original Software or previous
+  Modifications; 
+  
+  B. Any new file that contains any part of the
+  Original Software or previous Modification; or 
+  
+  C. Any new file that is contributed or otherwise made
+  available under the terms of this License.
+  
+  1.10. "Original Software" means the Source Code and
+  Executable form of computer software code that is
+  originally released under this License. 
+  
+  1.11. "Patent Claims" means any patent claim(s), now owned
+  or hereafter acquired, including without limitation,
+  method, process, and apparatus claims, in any patent
+  Licensable by grantor. 
+  
+  1.12. "Source Code" means (a) the common form of computer
+  software code in which modifications are made and (b)
+  associated documentation included in or with such code.
+  
+  1.13. "You" (or "Your") means an individual or a legal
+  entity exercising rights under, and complying with all of
+  the terms of, this License. For legal entities, "You"
+  includes any entity which controls, is controlled by, or is
+  under common control with You. For purposes of this
+  definition, "control" means (a) the power, direct or
+  indirect, to cause the direction or management of such
+  entity, whether by contract or otherwise, or (b) ownership
+  of more than fifty percent (50%) of the outstanding shares
+  or beneficial ownership of such entity.
+  
+  2. License Grants. 
+  
+  2.1. The Initial Developer Grant.
+  
+  Conditioned upon Your compliance with Section 3.1 below and
+  subject to third party intellectual property claims, the
+  Initial Developer hereby grants You a world-wide,
+  royalty-free, non-exclusive license: 
+  
+  (a) under intellectual property rights (other than
+  patent or trademark) Licensable by Initial Developer,
+  to use, reproduce, modify, display, perform,
+  sublicense and distribute the Original Software (or
+  portions thereof), with or without Modifications,
+  and/or as part of a Larger Work; and 
+  
+  (b) under Patent Claims infringed by the making,
+  using or selling of Original Software, to make, have
+  made, use, practice, sell, and offer for sale, and/or
+  otherwise dispose of the Original Software (or
+  portions thereof). 
+  
+  (c) The licenses granted in Sections 2.1(a) and (b)
+  are effective on the date Initial Developer first
+  distributes or otherwise makes the Original Software
+  available to a third party under the terms of this
+  License. 
+  
+  (d) Notwithstanding Section 2.1(b) above, no patent
+  license is granted: (1) for code that You delete from
+  the Original Software, or (2) for infringements
+  caused by: (i) the modification of the Original
+  Software, or (ii) the combination of the Original
+  Software with other software or devices. 
+  
+  2.2. Contributor Grant.
+  
+  Conditioned upon Your compliance with Section 3.1 below and
+  subject to third party intellectual property claims, each
+  Contributor hereby grants You a world-wide, royalty-free,
+  non-exclusive license:
+  
+  (a) under intellectual property rights (other than
+  patent or trademark) Licensable by Contributor to
+  use, reproduce, modify, display, perform, sublicense
+  and distribute the Modifications created by such
+  Contributor (or portions thereof), either on an
+  unmodified basis, with other Modifications, as
+  Covered Software and/or as part of a Larger Work; and
+  
+  (b) under Patent Claims infringed by the making,
+  using, or selling of Modifications made by that
+  Contributor either alone and/or in combination with
+  its Contributor Version (or portions of such
+  combination), to make, use, sell, offer for sale,
+  have made, and/or otherwise dispose of: (1)
+  Modifications made by that Contributor (or portions
+  thereof); and (2) the combination of Modifications
+  made by that Contributor with its Contributor Version
+  (or portions of such combination). 
+  
+  (c) The licenses granted in Sections 2.2(a) and
+  2.2(b) are effective on the date Contributor first
+  distributes or otherwise makes the Modifications
+  available to a third party. 
+  
+  (d) Notwithstanding Section 2.2(b) above, no patent
+  license is granted: (1) for any code that Contributor
+  has deleted from the Contributor Version; (2) for
+  infringements caused by: (i) third party
+  modifications of Contributor Version, or (ii) the
+  combination of Modifications made by that Contributor
+  with other software (except as part of the
+  Contributor Version) or other devices; or (3) under
+  Patent Claims infringed by Covered Software in the
+  absence of Modifications made by that Contributor. 
+  
+  3. Distribution Obligations.
+  
+  3.1. Availability of Source Code.
+  
+  Any Covered Software that You distribute or otherwise make
+  available in Executable form must also be made available in
+  Source Code form and that Source Code form must be
+  distributed only under the terms of this License. You must
+  include a copy of this License with every copy of the
+  Source Code form of the Covered Software You distribute or
+  otherwise make available. You must inform recipients of any
+  such Covered Software in Executable form as to how they can
+  obtain such Covered Software in Source Code form in a
+  reasonable manner on or through a medium customarily used
+  for software exchange.
+  
+  3.2. Modifications.
+  
+  The Modifications that You create or to which You
+  contribute are governed by the terms of this License. You
+  represent that You believe Your Modifications are Your
+  original creation(s) and/or You have sufficient rights to
+  grant the rights conveyed by this License.
+  
+  3.3. Required Notices.
+  
+  You must include a notice in each of Your Modifications
+  that identifies You as the Contributor of the Modification.
+  You may not remove or alter any copyright, patent or
+  trademark notices contained within the Covered Software, or
+  any notices of licensing or any descriptive text giving
+  attribution to any Contributor or the Initial Developer.
+  
+  3.4. Application of Additional Terms.
+  
+  You may not offer or impose any terms on any Covered
+  Software in Source Code form that alters or restricts the
+  applicable version of this License or the recipients"
+  rights hereunder. You may choose to offer, and to charge a
+  fee for, warranty, support, indemnity or liability
+  obligations to one or more recipients of Covered Software.
+  However, you may do so only on Your own behalf, and not on
+  behalf of the Initial Developer or any Contributor. You
+  must make it absolutely clear that any such warranty,
+  support, indemnity or liability obligation is offered by
+  You alone, and You hereby agree to indemnify the Initial
+  Developer and every Contributor for any liability incurred
+  by the Initial Developer or such Contributor as a result of
+  warranty, support, indemnity or liability terms You offer.
+      
+  3.5. Distribution of Executable Versions.
+  
+  You may distribute the Executable form of the Covered
+  Software under the terms of this License or under the terms
+  of a license of Your choice, which may contain terms
+  different from this License, provided that You are in
+  compliance with the terms of this License and that the
+  license for the Executable form does not attempt to limit
+  or alter the recipient"s rights in the Source Code form
+  from the rights set forth in this License. If You
+  distribute the Covered Software in Executable form under a
+  different license, You must make it absolutely clear that
+  any terms which differ from this License are offered by You
+  alone, not by the Initial Developer or Contributor. You
+  hereby agree to indemnify the Initial Developer and every
+  Contributor for any liability incurred by the Initial
+  Developer or such Contributor as a result of any such terms
+  You offer.
+  
+  3.6. Larger Works.
+  
+  You may create a Larger Work by combining Covered Software
+  with other code not governed by the terms of this License
+  and distribute the Larger Work as a single product. In such
+  a case, You must make sure the requirements of this License
+  are fulfilled for the Covered Software. 
+  
+  4. Versions of the License. 
+  
+  4.1. New Versions.
+  
+  Sun Microsystems, Inc. is the initial license steward and
+  may publish revised and/or new versions of this License
+  from time to time. Each version will be given a
+  distinguishing version number. Except as provided in
+  Section 4.3, no one other than the license steward has the
+  right to modify this License. 
+  
+  4.2. Effect of New Versions.
+  
+  You may always continue to use, distribute or otherwise
+  make the Covered Software available under the terms of the
+  version of the License under which You originally received
+  the Covered Software. If the Initial Developer includes a
+  notice in the Original Software prohibiting it from being
+  distributed or otherwise made available under any
+  subsequent version of the License, You must distribute and
+  make the Covered Software available under the terms of the
+  version of the License under which You originally received
+  the Covered Software. Otherwise, You may also choose to
+  use, distribute or otherwise make the Covered Software
+  available under the terms of any subsequent version of the
+  License published by the license steward. 
+  
+  4.3. Modified Versions.
+  
+  When You are an Initial Developer and You want to create a
+  new license for Your Original Software, You may create and
+  use a modified version of this License if You: (a) rename
+  the license and remove any references to the name of the
+  license steward (except to note that the license differs
+  from this License); and (b) otherwise make it clear that
+  the license contains terms which differ from this License.
+  
+  5. DISCLAIMER OF WARRANTY.
+  
+  COVERED SOFTWARE IS PROVIDED UNDER THIS LICENSE ON AN "AS IS"
+  BASIS, WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED,
+  INCLUDING, WITHOUT LIMITATION, WARRANTIES THAT THE COVERED
+  SOFTWARE IS FREE OF DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR
+  PURPOSE OR NON-INFRINGING. THE ENTIRE RISK AS TO THE QUALITY AND
+  PERFORMANCE OF THE COVERED SOFTWARE IS WITH YOU. SHOULD ANY
+  COVERED SOFTWARE PROVE DEFECTIVE IN ANY RESPECT, YOU (NOT THE
+  INITIAL DEVELOPER OR ANY OTHER CONTRIBUTOR) ASSUME THE COST OF
+  ANY NECESSARY SERVICING, REPAIR OR CORRECTION. THIS DISCLAIMER OF
+  WARRANTY CONSTITUTES AN ESSENTIAL PART OF THIS LICENSE. NO USE OF
+  ANY COVERED SOFTWARE IS AUTHORIZED HEREUNDER EXCEPT UNDER THIS
+  DISCLAIMER. 
+  
+  6. TERMINATION. 
+  
+  6.1. This License and the rights granted hereunder will
+  terminate automatically if You fail to comply with terms
+  herein and fail to cure such breach within 30 days of
+  becoming aware of the breach. Provisions which, by their
+  nature, must remain in effect beyond the termination of
+  this License shall survive.
+  
+  6.2. If You assert a patent infringement claim (excluding
+  declaratory judgment actions) against Initial Developer or
+  a Contributor (the Initial Developer or Contributor against
+  whom You assert such claim is referred to as "Participant")
+  alleging that the Participant Software (meaning the
+  Contributor Version where the Participant is a Contributor
+  or the Original Software where the Participant is the
+  Initial Developer) directly or indirectly infringes any
+  patent, then any and all rights granted directly or
+  indirectly to You by such Participant, the Initial
+  Developer (if the Initial Developer is not the Participant)
+  and all Contributors under Sections 2.1 and/or 2.2 of this
+  License shall, upon 60 days notice from Participant
+  terminate prospectively and automatically at the expiration
+  of such 60 day notice period, unless if within such 60 day
+  period You withdraw Your claim with respect to the
+  Participant Software against such Participant either
+  unilaterally or pursuant to a written agreement with
+  Participant.
+  
+  6.3. In the event of termination under Sections 6.1 or 6.2
+  above, all end user licenses that have been validly granted
+  by You or any distributor hereunder prior to termination
+  (excluding licenses granted to You by any distributor)
+  shall survive termination.
+  
+  7. LIMITATION OF LIABILITY.
+  
+  UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT
+  (INCLUDING NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE
+  INITIAL DEVELOPER, ANY OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF
+  COVERED SOFTWARE, OR ANY SUPPLIER OF ANY OF SUCH PARTIES, BE
+  LIABLE TO ANY PERSON FOR ANY INDIRECT, SPECIAL, INCIDENTAL, OR
+  CONSEQUENTIAL DAMAGES OF ANY CHARACTER INCLUDING, WITHOUT
+  LIMITATION, DAMAGES FOR LOST PROFITS, LOSS OF GOODWILL, WORK
+  STOPPAGE, COMPUTER FAILURE OR MALFUNCTION, OR ANY AND ALL OTHER
+  COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH PARTY SHALL HAVE BEEN
+  INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS LIMITATION OF
+  LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL
+  INJURY RESULTING FROM SUCH PARTY"S NEGLIGENCE TO THE EXTENT
+  APPLICABLE LAW PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO
+  NOT ALLOW THE EXCLUSION OR LIMITATION OF INCIDENTAL OR
+  CONSEQUENTIAL DAMAGES, SO THIS EXCLUSION AND LIMITATION MAY NOT
+  APPLY TO YOU.
+  
+  8. U.S. GOVERNMENT END USERS.
+  
+  The Covered Software is a "commercial item," as that term is
+  defined in 48 C.F.R. 2.101 (Oct. 1995), consisting of "commercial
+  computer software" (as that term is defined at 48 C.F.R. "
+  252.227-7014(a)(1)) and "commercial computer software
+  documentation" as such terms are used in 48 C.F.R. 12.212 (Sept.
+  1995). Consistent with 48 C.F.R. 12.212 and 48 C.F.R. 227.7202-1
+  through 227.7202-4 (June 1995), all U.S. Government End Users
+  acquire Covered Software with only those rights set forth herein.
+  This U.S. Government Rights clause is in lieu of, and supersedes,
+  any other FAR, DFAR, or other clause or provision that addresses
+  Government rights in computer software under this License.
+  
+  9. MISCELLANEOUS.
+  
+  This License represents the complete agreement concerning subject
+  matter hereof. If any provision of this License is held to be
+  unenforceable, such provision shall be reformed only to the
+  extent necessary to make it enforceable. This License shall be
+  governed by the law of the jurisdiction specified in a notice
+  contained within the Original Software (except to the extent
+  applicable law, if any, provides otherwise), excluding such
+  jurisdiction"s conflict-of-law provisions. Any litigation
+  relating to this License shall be subject to the jurisdiction of
+  the courts located in the jurisdiction and venue specified in a
+  notice contained within the Original Software, with the losing
+  party responsible for costs, including, without limitation, court
+  costs and reasonable attorneys" fees and expenses. The
+  application of the United Nations Convention on Contracts for the
+  International Sale of Goods is expressly excluded. Any law or
+  regulation which provides that the language of a contract shall
+  be construed against the drafter shall not apply to this License.
+  You agree that You alone are responsible for compliance with the
+  United States export administration regulations (and the export
+  control laws and regulation of any other countries) when You use,
+  distribute or otherwise make available any Covered Software.
+  
+  10. RESPONSIBILITY FOR CLAIMS.
+  
+  As between Initial Developer and the Contributors, each party is
+  responsible for claims and damages arising, directly or
+  indirectly, out of its utilization of rights under this License
+  and You agree to work with Initial Developer and Contributors to
+  distribute such responsibility on an equitable basis. Nothing
+  herein is intended or shall be deemed to constitute any admission
+  of liability.
+  


[06/51] [abbrv] brooklyn-dist git commit: [SPLITPREP] rearranged to have structure of new repositories

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/src/main/license/files/NOTICE
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/license/files/NOTICE b/brooklyn-dist/dist/src/main/license/files/NOTICE
new file mode 100644
index 0000000..f790f13
--- /dev/null
+++ b/brooklyn-dist/dist/src/main/license/files/NOTICE
@@ -0,0 +1,5 @@
+Apache Brooklyn
+Copyright 2014-2015 The Apache Software Foundation
+
+This product includes software developed at
+The Apache Software Foundation (http://www.apache.org/).

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/src/test/java/org/apache/brooklyn/cli/BaseCliIntegrationTest.java
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/test/java/org/apache/brooklyn/cli/BaseCliIntegrationTest.java b/brooklyn-dist/dist/src/test/java/org/apache/brooklyn/cli/BaseCliIntegrationTest.java
new file mode 100644
index 0000000..4cb2d2b
--- /dev/null
+++ b/brooklyn-dist/dist/src/test/java/org/apache/brooklyn/cli/BaseCliIntegrationTest.java
@@ -0,0 +1,189 @@
+/*
+ * 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.brooklyn.cli;
+
+import static org.testng.Assert.assertEquals;
+import static org.testng.Assert.assertFalse;
+import static org.testng.Assert.assertTrue;
+import static org.testng.Assert.fail;
+
+import java.io.InputStream;
+import java.io.OutputStream;
+import java.util.NoSuchElementException;
+import java.util.Scanner;
+import java.util.concurrent.Callable;
+import java.util.concurrent.ExecutionException;
+import java.util.concurrent.ExecutorService;
+import java.util.concurrent.Executors;
+import java.util.concurrent.Future;
+import java.util.concurrent.TimeUnit;
+import java.util.concurrent.TimeoutException;
+
+import org.apache.brooklyn.core.entity.factory.ApplicationBuilder;
+import org.testng.annotations.AfterMethod;
+import org.testng.annotations.BeforeMethod;
+
+import com.google.common.collect.Lists;
+
+/**
+ * Command line interface test support.
+ */
+public class BaseCliIntegrationTest {
+
+    // TODO does this need to be hard-coded?
+    private static final String BROOKLYN_BIN_PATH = "./target/brooklyn-dist/bin/brooklyn";
+    private static final String BROOKLYN_CLASSPATH = "./target/test-classes/:./target/classes/";
+
+    // Times in seconds to allow Brooklyn to run and produce output
+    private static final long DELAY = 10l;
+    private static final long TIMEOUT = DELAY + 30l;
+
+    private ExecutorService executor;
+
+    @BeforeMethod(alwaysRun = true)
+    public void setup() {
+        executor = Executors.newCachedThreadPool();
+    }
+
+    @AfterMethod(alwaysRun = true)
+    public void teardown() {
+        executor.shutdownNow();
+    }
+
+    /** Invoke the brooklyn script with arguments. */
+    public Process startBrooklyn(String...argv) throws Throwable {
+        ProcessBuilder pb = new ProcessBuilder();
+        pb.environment().remove("BROOKLYN_HOME");
+        pb.environment().put("BROOKLYN_CLASSPATH", BROOKLYN_CLASSPATH);
+        pb.command(Lists.asList(BROOKLYN_BIN_PATH, argv));
+        return pb.start();
+    }
+
+    public void testBrooklyn(Process brooklyn, BrooklynCliTest test, int expectedExit) throws Throwable {
+        testBrooklyn(brooklyn, test, expectedExit, false);
+    }
+
+    /** Tests the operation of the Brooklyn CLI. */
+    public void testBrooklyn(Process brooklyn, BrooklynCliTest test, int expectedExit, boolean stop) throws Throwable {
+        try {
+            Future<Integer> future = executor.submit(test);
+
+            // Send CR to stop if required
+            if (stop) {
+                OutputStream out = brooklyn.getOutputStream();
+                out.write('\n');
+                out.flush();
+            }
+
+            int exitStatus = future.get(TIMEOUT, TimeUnit.SECONDS);
+
+            // Check error code from process
+            assertEquals(exitStatus, expectedExit, "Command returned wrong status");
+        } catch (TimeoutException te) {
+            fail("Timed out waiting for process to complete", te);
+        } catch (ExecutionException ee) {
+            if (ee.getCause() instanceof AssertionError) {
+                throw ee.getCause();
+            } else throw ee;
+        } finally {
+            brooklyn.destroy();
+        }
+    }
+
+    /** A {@link Callable} that encapsulates Brooklyn CLI test logic. */
+    public static abstract class BrooklynCliTest implements Callable<Integer> {
+
+        private final Process brooklyn;
+
+        private String consoleOutput;
+        private String consoleError;
+
+        public BrooklynCliTest(Process brooklyn) {
+            this.brooklyn = brooklyn;
+        }
+
+        @Override
+        public Integer call() throws Exception {
+            // Wait for initial output
+            Thread.sleep(TimeUnit.SECONDS.toMillis(DELAY));
+
+            // Get the console output of running that command
+            consoleOutput = convertStreamToString(brooklyn.getInputStream());
+            consoleError = convertStreamToString(brooklyn.getErrorStream());
+
+            // Check if the output looks as expected
+            checkConsole();
+
+            // Return exit status on completion
+            return brooklyn.waitFor();
+        }
+
+        /** Perform test assertions on console output and error streams. */
+        public abstract void checkConsole();
+
+        private String convertStreamToString(InputStream is) {
+            try {
+                return new Scanner(is).useDelimiter("\\A").next();
+            } catch (NoSuchElementException e) {
+                return "";
+            }
+        }
+
+        protected void assertConsoleOutput(String...expected) {
+            for (String e : expected) {
+                assertTrue(consoleOutput.contains(e), "Execution output not logged; output=" + consoleOutput);
+            }
+        }
+
+        protected void assertNoConsoleOutput(String...expected) {
+            for (String e : expected) {
+                assertFalse(consoleOutput.contains(e), "Execution output logged; output=" + consoleOutput);
+            }
+        }
+
+        protected void assertConsoleError(String...expected) {
+            for (String e : expected) {
+                assertTrue(consoleError.contains(e), "Execution error not logged; error=" + consoleError);
+            }
+        }
+
+        protected void assertNoConsoleError(String...expected) {
+            for (String e : expected) {
+                assertFalse(consoleError.contains(e), "Execution error logged; error=" + consoleError);
+            }
+        }
+
+        protected void assertConsoleOutputEmpty() {
+            assertTrue(consoleOutput.isEmpty(), "Output present; output=" + consoleOutput);
+        }
+
+        protected void assertConsoleErrorEmpty() {
+            assertTrue(consoleError.isEmpty(), "Error present; error=" + consoleError);
+        }
+    };
+
+    /** An empty application for testing. */
+    public static class TestApplication extends ApplicationBuilder {
+        @Override
+        protected void doBuild() {
+            // Empty, for testing
+        }
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/src/test/java/org/apache/brooklyn/cli/CliIntegrationTest.java
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/test/java/org/apache/brooklyn/cli/CliIntegrationTest.java b/brooklyn-dist/dist/src/test/java/org/apache/brooklyn/cli/CliIntegrationTest.java
new file mode 100644
index 0000000..adf9559
--- /dev/null
+++ b/brooklyn-dist/dist/src/test/java/org/apache/brooklyn/cli/CliIntegrationTest.java
@@ -0,0 +1,219 @@
+/*
+ * 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.brooklyn.cli;
+
+import org.testng.annotations.Test;
+
+/**
+ * Test the command line interface operation.
+ */
+public class CliIntegrationTest extends BaseCliIntegrationTest {
+
+    /**
+     * Checks if running {@code brooklyn help} produces the expected output.
+     */
+    @Test(groups = {"Integration","Broken"})
+    public void testLaunchCliHelp() throws Throwable {
+        final Process brooklyn = startBrooklyn("help");
+
+        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
+            @Override
+            public void checkConsole() {
+                assertConsoleOutput("usage: brooklyn"); // Usage info not present
+                assertConsoleOutput("The most commonly used brooklyn commands are:");
+                assertConsoleOutput("help     Display help for available commands",
+                                    "info     Display information about brooklyn",
+                                    "launch   Starts a brooklyn application"); // List of common commands not present
+                assertConsoleOutput("See 'brooklyn help <command>' for more information on a specific command.");
+                assertConsoleErrorEmpty();
+            }
+        };
+
+        testBrooklyn(brooklyn, test, 0);
+    }
+
+    /*
+        Exception java.io.IOException
+        
+        Message: Cannot run program "./target/brooklyn-dist/bin/brooklyn": error=2, No such file or directory
+        Stacktrace:
+        
+        
+        at java.lang.ProcessBuilder.start(ProcessBuilder.java:1047)
+        at org.apache.brooklyn.cli.BaseCliIntegrationTest.startBrooklyn(BaseCliIntegrationTest.java:75)
+        at org.apache.brooklyn.cli.CliIntegrationTest.testLaunchCliApp(CliIntegrationTest.java:56)
+        at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
+        at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:57)
+        at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
+        at java.lang.reflect.Method.invoke(Method.java:606)
+        at org.testng.internal.MethodInvocationHelper.invokeMethod(MethodInvocationHelper.java:84)
+        at org.testng.internal.Invoker.invokeMethod(Invoker.java:714)
+        at org.testng.internal.Invoker.invokeTestMethod(Invoker.java:901)
+        at org.testng.internal.Invoker.invokeTestMethods(Invoker.java:1231)
+        at org.testng.internal.TestMethodWorker.invokeTestMethods(TestMethodWorker.java:127)
+        at org.testng.internal.TestMethodWorker.run(TestMethodWorker.java:111)
+        at org.testng.TestRunner.privateRun(TestRunner.java:767)
+        at org.testng.TestRunner.run(TestRunner.java:617)
+        at org.testng.SuiteRunner.runTest(SuiteRunner.java:348)
+        at org.testng.SuiteRunner.runSequentially(SuiteRunner.java:343)
+        at org.testng.SuiteRunner.privateRun(SuiteRunner.java:305)
+        at org.testng.SuiteRunner.run(SuiteRunner.java:254)
+        at org.testng.SuiteRunnerWorker.runSuite(SuiteRunnerWorker.java:52)
+        at org.testng.SuiteRunnerWorker.run(SuiteRunnerWorker.java:86)
+        at org.testng.TestNG.runSuitesSequentially(TestNG.java:1224)
+        at org.testng.TestNG.runSuitesLocally(TestNG.java:1149)
+        at org.testng.TestNG.run(TestNG.java:1057)
+        at org.apache.maven.surefire.testng.TestNGExecutor.run(TestNGExecutor.java:115)
+        at org.apache.maven.surefire.testng.TestNGDirectoryTestSuite.executeMulti(TestNGDirectoryTestSuite.java:205)
+        at org.apache.maven.surefire.testng.TestNGDirectoryTestSuite.execute(TestNGDirectoryTestSuite.java:108)
+        at org.apache.maven.surefire.testng.TestNGProvider.invoke(TestNGProvider.java:111)
+        at org.apache.maven.surefire.booter.ForkedBooter.invokeProviderInSameClassLoader(ForkedBooter.java:203)
+        at org.apache.maven.surefire.booter.ForkedBooter.runSuitesInProcess(ForkedBooter.java:155)
+        at org.apache.maven.surefire.booter.ForkedBooter.main(ForkedBooter.java:103)
+        Caused by: java.io.IOException: error=2, No such file or directory
+        at java.lang.UNIXProcess.forkAndExec(Native Method)
+        at java.lang.UNIXProcess.<init>(UNIXProcess.java:186)
+        at java.lang.ProcessImpl.start(ProcessImpl.java:130)
+        at java.lang.ProcessBuilder.start(ProcessBuilder.java:1028)
+        ... 30 more
+     */
+    /**
+     * Checks if launching an application using {@code brooklyn launch} produces the expected output.
+     */
+    @Test(groups = {"Integration","Broken"})
+    public void testLaunchCliApp() throws Throwable {
+        final Process brooklyn = startBrooklyn("--verbose", "launch", "--stopOnKeyPress", "--app", "org.apache.brooklyn.cli.BaseCliIntegrationTest$TestApplication", "--location", "localhost", "--noConsole");
+
+        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
+            @Override
+            public void checkConsole() {
+                assertConsoleOutput("Launching brooklyn app:"); // Launch message not output
+                assertNoConsoleOutput("Initiating Jersey application"); // Web console started
+                assertConsoleOutput("Started application BasicApplicationImpl"); // Application not started
+                assertConsoleOutput("Server started. Press return to stop."); // Server started message not output
+                assertConsoleErrorEmpty();
+            }
+        };
+
+        testBrooklyn(brooklyn, test, 0, true);
+    }
+
+    /**
+     * Checks if a correct error and help message is given if using incorrect param.
+     */
+    @Test(groups = {"Integration","Broken"})
+    public void testLaunchCliAppParamError() throws Throwable {
+        final Process brooklyn = startBrooklyn("launch", "nothing", "--app");
+
+        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
+            @Override
+            public void checkConsole() {
+                assertConsoleError("Parse error: Required values for option 'application class or file' not provided");
+                assertConsoleError("NAME", "SYNOPSIS", "OPTIONS", "COMMANDS");
+                assertConsoleOutputEmpty();
+            }
+        };
+
+        testBrooklyn(brooklyn, test, 1);
+    }
+
+    /*
+        Exception java.io.IOException
+        
+        Message: Cannot run program "./target/brooklyn-dist/bin/brooklyn": error=2, No such file or directory
+        Stacktrace:
+        
+        
+        at java.lang.ProcessBuilder.start(ProcessBuilder.java:1047)
+        at org.apache.brooklyn.cli.BaseCliIntegrationTest.startBrooklyn(BaseCliIntegrationTest.java:75)
+        at org.apache.brooklyn.cli.CliIntegrationTest.testLaunchCliAppCommandError(CliIntegrationTest.java:96)
+        at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
+        at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:57)
+        at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
+        at java.lang.reflect.Method.invoke(Method.java:606)
+        at org.testng.internal.MethodInvocationHelper.invokeMethod(MethodInvocationHelper.java:84)
+        at org.testng.internal.Invoker.invokeMethod(Invoker.java:714)
+        at org.testng.internal.Invoker.invokeTestMethod(Invoker.java:901)
+        at org.testng.internal.Invoker.invokeTestMethods(Invoker.java:1231)
+        at org.testng.internal.TestMethodWorker.invokeTestMethods(TestMethodWorker.java:127)
+        at org.testng.internal.TestMethodWorker.run(TestMethodWorker.java:111)
+        at org.testng.TestRunner.privateRun(TestRunner.java:767)
+        at org.testng.TestRunner.run(TestRunner.java:617)
+        at org.testng.SuiteRunner.runTest(SuiteRunner.java:348)
+        at org.testng.SuiteRunner.runSequentially(SuiteRunner.java:343)
+        at org.testng.SuiteRunner.privateRun(SuiteRunner.java:305)
+        at org.testng.SuiteRunner.run(SuiteRunner.java:254)
+        at org.testng.SuiteRunnerWorker.runSuite(SuiteRunnerWorker.java:52)
+        at org.testng.SuiteRunnerWorker.run(SuiteRunnerWorker.java:86)
+        at org.testng.TestNG.runSuitesSequentially(TestNG.java:1224)
+        at org.testng.TestNG.runSuitesLocally(TestNG.java:1149)
+        at org.testng.TestNG.run(TestNG.java:1057)
+        at org.apache.maven.surefire.testng.TestNGExecutor.run(TestNGExecutor.java:115)
+        at org.apache.maven.surefire.testng.TestNGDirectoryTestSuite.executeMulti(TestNGDirectoryTestSuite.java:205)
+        at org.apache.maven.surefire.testng.TestNGDirectoryTestSuite.execute(TestNGDirectoryTestSuite.java:108)
+        at org.apache.maven.surefire.testng.TestNGProvider.invoke(TestNGProvider.java:111)
+        at org.apache.maven.surefire.booter.ForkedBooter.invokeProviderInSameClassLoader(ForkedBooter.java:203)
+        at org.apache.maven.surefire.booter.ForkedBooter.runSuitesInProcess(ForkedBooter.java:155)
+        at org.apache.maven.surefire.booter.ForkedBooter.main(ForkedBooter.java:103)
+        Caused by: java.io.IOException: error=2, No such file or directory
+        at java.lang.UNIXProcess.forkAndExec(Native Method)
+        at java.lang.UNIXProcess.<init>(UNIXProcess.java:186)
+        at java.lang.ProcessImpl.start(ProcessImpl.java:130)
+        at java.lang.ProcessBuilder.start(ProcessBuilder.java:1028)
+        ... 30 more
+     */
+    /**
+     * Checks if a correct error and help message is given if using incorrect command.
+     */
+    @Test(groups = "Integration")
+    public void testLaunchCliAppCommandError() throws Throwable {
+        final Process brooklyn = startBrooklyn("biscuit");
+
+        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
+            @Override
+            public void checkConsole() {
+                assertConsoleError("Parse error: No command specified");
+                assertConsoleError("NAME", "SYNOPSIS", "OPTIONS", "COMMANDS");
+                assertConsoleOutputEmpty();
+            }
+        };
+
+        testBrooklyn(brooklyn, test, 1);
+    }
+
+    /**
+     * Checks if a correct error and help message is given if using incorrect application.
+     */
+    @Test(groups = {"Integration","Broken"})
+    public void testLaunchCliAppLaunchError() throws Throwable {
+        final String app = "org.eample.DoesNotExist";
+        final Process brooklyn = startBrooklyn("launch", "--app", app, "--location", "nowhere");
+
+        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
+            @Override
+            public void checkConsole() {
+                assertConsoleOutput(app, "not found");
+                assertConsoleError("ERROR", "Fatal", "getting resource", app);
+            }
+        };
+
+        testBrooklyn(brooklyn, test, 2);
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/downstream-parent/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/downstream-parent/pom.xml b/brooklyn-dist/downstream-parent/pom.xml
new file mode 100644
index 0000000..6580281
--- /dev/null
+++ b/brooklyn-dist/downstream-parent/pom.xml
@@ -0,0 +1,506 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+  <modelVersion>4.0.0</modelVersion>
+
+  <parent>
+    <groupId>org.apache.brooklyn</groupId>
+    <artifactId>brooklyn</artifactId>
+    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+    <relativePath>../../pom.xml</relativePath>
+  </parent>
+
+  <artifactId>brooklyn-downstream-parent</artifactId>
+  <packaging>pom</packaging>
+  <name>Brooklyn Downstream Project Parent</name>
+  <description>
+      Parent pom that can be used by downstream projects that use Brooklyn,
+      or that contribute additional functionality to Brooklyn.
+  </description>
+
+  <properties>
+    <!-- Compilation -->
+    <java.version>1.7</java.version>
+    <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>
+    <project.reporting.outputEncoding>UTF-8</project.reporting.outputEncoding>
+
+    <!-- Testing -->
+    <testng.version>6.8.8</testng.version>
+    <surefire.version>2.18.1</surefire.version>
+    <includedTestGroups />
+    <excludedTestGroups>Integration,Acceptance,Live,Live-sanity,WIP</excludedTestGroups>
+
+    <!-- Dependencies -->
+    <brooklyn.version>0.9.0-SNAPSHOT</brooklyn.version>  <!-- BROOKLYN_VERSION -->
+    <jclouds.groupId>org.apache.jclouds</jclouds.groupId> <!-- JCLOUDS_GROUPID_VERSION -->
+
+    <!-- versions should match those used by Brooklyn, to avoid conflicts -->
+    <jclouds.version>1.9.1</jclouds.version> <!-- JCLOUDS_VERSION -->
+    <logback.version>1.0.7</logback.version>
+    <slf4j.version>1.6.6</slf4j.version>  <!-- used for java.util.logging jul-to-slf4j interception -->
+    <guava.version>17.0</guava.version>
+    <xstream.version>1.4.7</xstream.version>
+    <jackson.version>1.9.13</jackson.version>  <!-- codehaus jackson, used by brooklyn rest server -->
+    <fasterxml.jackson.version>2.4.5</fasterxml.jackson.version>  <!-- more recent jackson, but not compatible with old annotations! -->
+    <jersey.version>1.19</jersey.version>
+    <httpclient.version>4.4.1</httpclient.version>
+    <commons-lang3.version>3.1</commons-lang3.version>
+    <groovy.version>2.3.7</groovy.version> <!-- Version supported by https://github.com/groovy/groovy-eclipse/wiki/Groovy-Eclipse-2.9.1-Release-Notes -->
+    <jsr305.version>2.0.1</jsr305.version>
+    <snakeyaml.version>1.11</snakeyaml.version>
+  </properties>
+
+  <dependencyManagement>
+    <dependencies>
+      <dependency>
+        <!-- this would pull in all brooklyn entities and clouds;
+             you can cherry pick selected ones instead (for a smaller build) -->
+        <groupId>org.apache.brooklyn</groupId>
+        <artifactId>brooklyn-all</artifactId>
+        <version>${brooklyn.version}</version>
+      </dependency>
+    </dependencies>
+  </dependencyManagement>
+
+  <dependencies>
+    <dependency>
+      <!-- this gives us flexible and easy-to-use logging; just edit logback-custom.xml! -->
+      <groupId>org.apache.brooklyn</groupId>
+      <artifactId>brooklyn-logback-xml</artifactId>
+      <version>${brooklyn.version}</version>
+      <!-- optional so that this project has logging; dependencies may redeclare or supply their own;
+           provided so that it isn't put into the assembly (as it supplies its own explicit logback.xml);
+           see Logging in the Brooklyn website/userguide for more info -->
+      <optional>true</optional>
+      <scope>provided</scope>
+    </dependency>
+    <dependency>
+      <!-- includes testng and useful logging for tests -->
+      <groupId>org.apache.brooklyn</groupId>
+      <artifactId>brooklyn-test-support</artifactId>
+      <version>${brooklyn.version}</version>
+      <scope>test</scope>
+    </dependency>
+    <dependency>
+      <!-- includes org.apache.brooklyn.test.support.LoggingVerboseReporter -->
+      <groupId>org.apache.brooklyn</groupId>
+      <artifactId>brooklyn-utils-test-support</artifactId>
+      <version>${brooklyn.version}</version>
+      <scope>test</scope>
+    </dependency>
+  </dependencies>
+
+  <build>
+    <testSourceDirectory>src/test/java</testSourceDirectory>
+    <testResources>
+      <testResource>
+        <directory>src/test/resources</directory>
+      </testResource>
+    </testResources>
+
+    <pluginManagement>
+      <plugins>
+        <plugin>
+          <artifactId>maven-assembly-plugin</artifactId>
+          <version>2.5.4</version>
+          <configuration>
+            <tarLongFileMode>gnu</tarLongFileMode>
+          </configuration>
+        </plugin>
+        <plugin>
+          <artifactId>maven-clean-plugin</artifactId>
+          <version>2.6.1</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-compiler-plugin</artifactId>
+          <version>3.3</version>
+          <configuration>
+            <source>${java.version}</source>
+            <target>${java.version}</target>
+          </configuration>
+        </plugin>
+        <plugin>
+          <artifactId>maven-deploy-plugin</artifactId>
+          <version>2.8.2</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-eclipse-plugin</artifactId>
+          <version>2.10</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-enforcer-plugin</artifactId>
+          <version>1.4</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-failsafe-plugin</artifactId>
+          <version>2.18.1</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-gpg-plugin</artifactId>
+          <version>1.6</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-jar-plugin</artifactId>
+          <version>2.6</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-javadoc-plugin</artifactId>
+          <version>2.10.3</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-resources-plugin</artifactId>
+          <version>2.7</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-source-plugin</artifactId>
+          <version>2.4</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-surefire-plugin</artifactId>
+          <version>2.18.1</version>
+        </plugin>
+        <plugin>
+          <groupId>org.apache.felix</groupId>
+          <artifactId>maven-bundle-plugin</artifactId>
+          <version>2.3.4</version>
+        </plugin>
+        <!--This plugin's configuration is used to store Eclipse m2e settings only. It has no influence on the Maven build itself.-->
+        <plugin>
+          <groupId>org.eclipse.m2e</groupId>
+          <artifactId>lifecycle-mapping</artifactId>
+          <version>1.0.0</version>
+          <configuration>
+            <lifecycleMappingMetadata>
+              <pluginExecutions>
+                <pluginExecution>
+                  <pluginExecutionFilter>
+                    <groupId>org.apache.maven.plugins</groupId>
+                    <artifactId>maven-assembly-plugin</artifactId>
+                    <versionRange>[2.4.1,)</versionRange>
+                    <goals>
+                      <goal>single</goal>
+                    </goals>
+                  </pluginExecutionFilter>
+                  <action>
+                    <ignore />
+                  </action>
+                </pluginExecution>
+                <pluginExecution>
+                  <pluginExecutionFilter>
+                    <groupId>org.codehaus.mojo</groupId>
+                    <artifactId>build-helper-maven-plugin</artifactId>
+                    <versionRange>[1.7,)</versionRange>
+                    <goals>
+                      <goal>attach-artifact</goal>
+                    </goals>
+                  </pluginExecutionFilter>
+                  <action>
+                    <ignore />
+                  </action>
+                </pluginExecution>
+                <pluginExecution>
+                  <pluginExecutionFilter>
+                    <groupId>org.apache.maven.plugins</groupId>
+                    <artifactId>maven-enforcer-plugin</artifactId>
+                    <versionRange>[1.3.1,)</versionRange>
+                    <goals>
+                      <goal>enforce</goal>
+                    </goals>
+                  </pluginExecutionFilter>
+                  <action>
+                    <ignore />
+                  </action>
+                </pluginExecution>
+                <pluginExecution>
+                  <pluginExecutionFilter>
+                    <groupId>org.apache.maven.plugins</groupId>
+                    <artifactId>maven-remote-resources-plugin</artifactId>
+                    <versionRange>[1.5,)</versionRange>
+                    <goals>
+                      <goal>process</goal>
+                    </goals>
+                  </pluginExecutionFilter>
+                  <action>
+                    <ignore />
+                  </action>
+                </pluginExecution>
+                <pluginExecution>
+                  <pluginExecutionFilter>
+                    <groupId>org.apache.maven.plugins</groupId>
+                    <artifactId>maven-dependency-plugin</artifactId>
+                    <versionRange>[2.8,)</versionRange>
+                    <goals>
+                      <goal>unpack</goal>
+                      <goal>copy</goal>
+                    </goals>
+                  </pluginExecutionFilter>
+                  <action>
+                    <ignore />
+                  </action>
+                </pluginExecution>
+                <pluginExecution>
+                  <pluginExecutionFilter>
+                    <groupId>com.github.skwakman.nodejs-maven-plugin</groupId>
+                    <artifactId>nodejs-maven-plugin</artifactId>
+                    <versionRange>[1.0.3,)</versionRange>
+                    <goals>
+                      <goal>extract</goal>
+                    </goals>
+                  </pluginExecutionFilter>
+                  <action>
+                    <ignore />
+                  </action>
+                </pluginExecution>
+                <pluginExecution>
+                  <pluginExecutionFilter>
+                    <groupId>org.apache.maven.plugins</groupId>
+                    <artifactId>maven-war-plugin</artifactId>
+                    <versionRange>[2.4,)</versionRange>
+                    <goals>
+                      <goal>exploded</goal>
+                    </goals>
+                  </pluginExecutionFilter>
+                  <action>
+                    <ignore />
+                  </action>
+                </pluginExecution>
+              </pluginExecutions>
+             </lifecycleMappingMetadata>
+           </configuration>
+        </plugin>
+      </plugins>
+    </pluginManagement>
+
+    <plugins>
+      <plugin>
+        <artifactId>maven-clean-plugin</artifactId>
+        <configuration>
+          <filesets>
+            <fileset>
+              <directory>.</directory>
+              <includes>
+                <include>brooklyn*.log</include>
+                <include>brooklyn*.log.*</include>
+                <include>stacktrace.log</include>
+                <include>test-output</include>
+                <include>prodDb.*</include>
+              </includes>
+            </fileset>
+          </filesets>
+        </configuration>
+      </plugin>
+
+      <plugin>
+        <artifactId>maven-resources-plugin</artifactId>
+      </plugin>
+
+      <plugin>
+        <artifactId>maven-eclipse-plugin</artifactId>
+        <configuration>
+          <additionalProjectnatures>
+            <projectnature>org.maven.ide.eclipse.maven2Nature</projectnature>
+          </additionalProjectnatures>
+        </configuration>
+      </plugin>
+
+      <plugin>
+        <artifactId>maven-surefire-plugin</artifactId>
+        <configuration>
+          <argLine>-Xms256m -Xmx512m -XX:MaxPermSize=512m</argLine>
+          <properties>
+            <property>
+              <name>listener</name>
+              <value>org.apache.brooklyn.test.support.LoggingVerboseReporter</value>
+            </property>
+          </properties>
+          <enableAssertions>true</enableAssertions>
+          <groups>${includedTestGroups}</groups>
+          <excludedGroups>${excludedTestGroups}</excludedGroups>
+          <testFailureIgnore>false</testFailureIgnore>
+          <systemPropertyVariables>
+            <verbose>-1</verbose>
+            <net.sourceforge.cobertura.datafile>${project.build.directory}/cobertura/cobertura.ser</net.sourceforge.cobertura.datafile>
+            <cobertura.user.java.nio>false</cobertura.user.java.nio>
+          </systemPropertyVariables>
+          <printSummary>true</printSummary>
+        </configuration>
+      </plugin>
+    </plugins>
+  </build>
+
+  <profiles>
+
+    <profile>
+      <id>Tests</id>
+      <activation>
+        <file> <exists>${basedir}/src/test</exists> </file>
+      </activation>
+      <build>
+        <plugins>
+          <plugin>
+            <artifactId>maven-jar-plugin</artifactId>
+            <inherited>true</inherited>
+            <executions>
+              <execution>
+                <id>test-jar-creation</id>
+                <goals>
+                  <goal>test-jar</goal>
+                </goals>
+                <configuration>
+                  <forceCreation>true</forceCreation>
+                  <archive combine.self="override" />
+                </configuration>
+              </execution>
+            </executions>
+          </plugin>
+        </plugins>
+      </build>
+    </profile>
+
+    <!-- run Integration tests with -PIntegration -->
+    <profile>
+      <id>Integration</id>
+      <properties>
+        <includedTestGroups>Integration</includedTestGroups>
+        <excludedTestGroups>Acceptance,Live,Live-sanity,WIP</excludedTestGroups>
+      </properties>
+    </profile>
+
+    <!-- run Live tests with -PLive -->
+    <profile>
+      <id>Live</id>
+      <properties>
+        <includedTestGroups>Live,Live-sanity</includedTestGroups>
+        <excludedTestGroups>Acceptance,WIP</excludedTestGroups>
+      </properties>
+    </profile>
+
+    <!-- run Live-sanity tests with -PLive-sanity -->
+    <profile>
+      <id>Live-sanity</id>
+      <properties>
+        <includedTestGroups>Live-sanity</includedTestGroups>
+        <excludedTestGroups>Acceptance,WIP</excludedTestGroups>
+      </properties>
+      <build>
+        <plugins>
+          <plugin>
+            <artifactId>maven-jar-plugin</artifactId>
+            <executions>
+              <execution>
+                <id>test-jar-creation</id>
+                <configuration>
+                  <skip>true</skip>
+                </configuration>
+              </execution>
+            </executions>
+          </plugin>
+        </plugins>
+      </build>
+    </profile>
+
+    <profile>
+      <id>Bundle</id>
+      <activation>
+        <file>
+          <!-- NB - this is all the leaf projects, including logback-* (with no src);
+               the archetype project neatly ignores this however -->
+          <exists>${basedir}/src</exists>
+        </file>
+      </activation>
+      <build>
+        <plugins>
+          <plugin>
+            <groupId>org.apache.felix</groupId>
+            <artifactId>maven-bundle-plugin</artifactId>
+            <extensions>true</extensions>
+            <!-- configure plugin to generate MANIFEST.MF
+                 adapted from http://blog.knowhowlab.org/2010/06/osgi-tutorial-from-project-structure-to.html -->
+            <executions>
+              <execution>
+                <id>bundle-manifest</id>
+                <phase>process-classes</phase>
+                <goals>
+                  <goal>manifest</goal>
+                </goals>
+              </execution>
+            </executions>
+            <configuration>
+              <supportedProjectTypes>
+                <supportedProjectType>jar</supportedProjectType>
+              </supportedProjectTypes>
+              <instructions>
+                <!-- OSGi specific instruction -->
+                <!--
+                    By default packages containing impl and internal
+                    are not included in the export list. Setting an
+                    explicit wildcard will include all packages
+                    regardless of name.
+                    In time we should minimize our export lists to
+                    what is really needed.
+                -->
+                <Export-Package>brooklyn.*,org.apache.brooklyn.*</Export-Package>
+                <!-- Brooklyn-Feature prefix triggers inclusion of the project's metadata in the server's features list. -->
+                <Brooklyn-Feature-Name>${project.name}</Brooklyn-Feature-Name>
+              </instructions>
+            </configuration>
+          </plugin>
+          <plugin>
+            <groupId>org.apache.maven.plugins</groupId>
+            <artifactId>maven-jar-plugin</artifactId>
+            <configuration>
+              <archive>
+                <manifestFile>${project.build.outputDirectory}/META-INF/MANIFEST.MF</manifestFile>
+              </archive>
+            </configuration>
+          </plugin>
+        </plugins>
+      </build>
+    </profile>
+
+    <!-- different properties used to deploy to different locations depending on profiles;
+         default is cloudsoft filesystem repo, but some sources still use cloudsoft artifactory as source
+         and soon we will support artifactory. use this profile for the ASF repositories and
+         sonatype-oss-release profile for the Sonatype OSS repositories.
+    -->
+    <!-- profile>
+      <id>apache-release</id>
+      <activation>
+        <property>
+          <name>brooklyn.deployTo</name>
+          <value>apache</value>
+        </property>
+      </activation>
+      <distributionManagement>
+        <repository>
+          <id>apache.releases.https</id>
+          <name>Apache Release Distribution Repository</name>
+          <url>https://repository.apache.org/service/local/staging/deploy/maven2</url>
+        </repository>
+        <snapshotRepository>
+          <id>apache.snapshots.https</id>
+          <name>Apache Development Snapshot Repository</name>
+          <url>https://repository.apache.org/content/repositories/snapshots</url>
+        </snapshotRepository>
+      </distributionManagement>
+    </profile -->
+  </profiles>
+
+</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/release/.gitignore
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/.gitignore b/brooklyn-dist/release/.gitignore
new file mode 100644
index 0000000..16d63d3
--- /dev/null
+++ b/brooklyn-dist/release/.gitignore
@@ -0,0 +1,2 @@
+.vagrant
+tmp

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/release/README.md
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/README.md b/brooklyn-dist/release/README.md
new file mode 100644
index 0000000..325b165
--- /dev/null
+++ b/brooklyn-dist/release/README.md
@@ -0,0 +1,50 @@
+Release Scripts and Helpers
+===========================
+
+This folder contains a number of items that will assist in the production of Brooklyn releases.
+
+
+Release scripts - change-version.sh and make-release-artifacts.sh
+-----------------------------------------------------------------
+
+`change-version.sh` will update version numbers across the whole distribution.  It is recommended to use this script
+rather than "rolling your own" or using a manual process, as you risk missing out some version numbers (and
+accidentally changing some that should not be changed).
+
+`make-release-artifacts.sh` will produce the release artifacts with appropriate signatures. It is recommended to use
+this script rather than "rolling your own" or using a manual process, as this script codifies several Apache
+requirements about the release artifacts.
+
+These scripts are fully documented in **Release Process** pages on the website.
+
+
+Vagrant configuration
+---------------------
+
+The `Vagrantfile` and associated files `settings.xml` and `gpg-agent.conf` are for setting up a virtual machine hosting
+a complete and clean development environment. You may benefit from using this environment when making the release, but
+it is not required that you do so.
+
+The environment is a single VM that configured with all the tools needed to make the release. It also configures GnuPG
+by copying your `gpg.conf`, `secring.gpg` and `pubring.gpg` into the VM; also copied is your `.gitconfig`. The
+GnuPG agent is configured to assist with the release signing by caching your passphrase, so you will only need to enter
+it once during the build process. A Maven `settings.xml` is provided to assist with the upload to Apache's Nexus server.
+Finally the canonical Git repository for Apache Brooklyn is cloned into the home directory.
+
+You should edit `settings.xml` before deployment, or `~/.m2/settings.xml` inside the VM after deployment, to include
+your Apache credentials.
+
+Assuming you have VirtualBox and Vagrant already installed, you should simply be able to run `vagrant up` to create the
+VM, and then `vagrant ssh` to get a shell prompt inside the VM. Finally run `vagrant destroy` to clean up afterwards.
+
+This folder is mounted at `/vagrant` inside the VM - this means the release helpers are close to hand, so you can
+run for example `/vagrant/make-release/artifacts.sh`.
+
+
+Pull request reporting
+----------------------
+
+The files in `pull-request-reports`, mainly `pr_report.rb` 
+(and associated files `Gemfile` and `Gemfile.lock`) uses the GitHub API to extract a list of open pull
+requests, and writes a summary into `pr_report.tsv`. This could then be imported into Google Sheets to provide a handy
+way of classifying and managing outstanding PRs ahead of making a release.

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/release/Vagrantfile
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/Vagrantfile b/brooklyn-dist/release/Vagrantfile
new file mode 100644
index 0000000..016c48f
--- /dev/null
+++ b/brooklyn-dist/release/Vagrantfile
@@ -0,0 +1,66 @@
+# -*- mode: ruby -*-
+# vi: set ft=ruby :
+#
+# 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.
+#
+
+# Vagrantfile that creates a basic workstation for compiling Brooklyn and
+# running tests. Particularly useful for running integration tests, as you
+# can clean up any failed tests simply by destroying and rebuilding the
+# Vagrant instance.
+
+# All Vagrant configuration is done below. The "2" in Vagrant.configure
+# configures the configuration version (we support older styles for
+# backwards compatibility). Please don't change it unless you know what
+# you're doing.
+Vagrant.configure(2) do |config|
+
+  # Base on Ubuntu 14.04 LTS
+  config.vm.box = "ubuntu/trusty64"
+
+  # Provider-specific configuration so you can fine-tune various
+  # backing providers for Vagrant. These expose provider-specific options.
+  config.vm.provider "virtualbox" do |vb|
+    vb.memory = "2048"
+  end
+
+  config.vm.network "forwarded_port", guest: 8008, host: 8008
+
+  config.vm.provision "file", source: "~/.gitconfig", destination: ".gitconfig"
+  config.vm.provision "file", source: "~/.gnupg/gpg.conf", destination: ".gnupg/gpg.conf"
+  config.vm.provision "file", source: "~/.gnupg/pubring.gpg", destination: ".gnupg/pubring.gpg"
+  config.vm.provision "file", source: "~/.gnupg/secring.gpg", destination: ".gnupg/secring.gpg"
+  config.vm.provision "file", source: "gpg-agent.conf", destination: ".gnupg/gpg-agent.conf"
+  config.vm.provision "file", source: "settings.xml", destination: ".m2/settings.xml"
+
+  # Update the VM, install Java and Maven, enable passwordless-ssh-to-localhost,
+  # clone the canonical repository
+  config.vm.provision "shell", inline: <<-SHELL
+    apt-get update
+    apt-get upgrade -y
+    apt-get install -y default-jdk maven git xmlstarlet zip unzip language-pack-en vim-nox gnupg2 gnupg-agent pinentry-curses
+    wget -q -O /tmp/artifactory.zip http://bit.ly/Hqv9aj
+    mkdir -p /opt
+    unzip /tmp/artifactory.zip -d /opt
+    sudo sed -i -e '/Connector port=/ s/=\".*\"/=\"'"8008"'\"/' /opt/artifactory*/tomcat/conf/server.xml
+    /opt/artifactory*/bin/installService.sh
+    service artifactory start
+    chmod -R go= ~vagrant/.gnupg
+    cat /etc/ssh/ssh_host_*_key.pub | awk '{print "localhost,127.0.0.1 "$0}' >> /etc/ssh/ssh_known_hosts
+    su -c 'ssh-keygen -t rsa -b 2048 -N "" -f ~/.ssh/id_rsa; cat ~/.ssh/*.pub >> ~/.ssh/authorized_keys' vagrant
+    su -c 'git clone https://git-wip-us.apache.org/repos/asf/incubator-brooklyn.git apache-brooklyn-git' vagrant
+  SHELL
+end

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/release/change-version.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/change-version.sh b/brooklyn-dist/release/change-version.sh
new file mode 100755
index 0000000..280c245
--- /dev/null
+++ b/brooklyn-dist/release/change-version.sh
@@ -0,0 +1,70 @@
+#!/usr/bin/env bash
+#
+# 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.
+#
+
+set -e
+
+# changes the version everywhere
+# usage, e.g.:  change-version.sh 0.3.0-SNAPSHOT 0.3.0-RC1
+#          or:  change-version.sh MARKER 0.3.0-SNAPSHOT 0.3.0-RC1
+
+[ -d .git ] || {
+  echo "Must run in brooklyn project root directory"
+  exit 1
+}
+
+if [ "$#" -eq 2 ]; then
+  VERSION_MARKER=BROOKLYN_VERSION
+elif [ "$#" -eq 3 ]; then
+  VERSION_MARKER=$1_VERSION
+  shift;
+else
+  echo "Usage:  "$0" [VERSION_MARKER] CURRENT_VERSION NEW_VERSION"
+  echo " e.g.:  "$0" BROOKLYN 0.3.0-SNAPSHOT 0.3.0-RC1"
+  exit 1
+fi
+
+# remove binaries and stuff
+if [ -f pom.xml ] && [ -d target ] ; then mvn clean ; fi
+
+VERSION_MARKER_NL=${VERSION_MARKER}_BELOW
+CURRENT_VERSION=$1
+NEW_VERSION=$2
+
+# grep --exclude-dir working only in recent versions, not on all platforms, replace with find;
+# skip folders named "ignored" or .xxx (but not the current folder ".");
+# exclude log, war, etc. files;
+# use null delimiters so files containing spaces are supported;
+# pass /dev/null as the first file to search in, so the command doesn't fail if find doesn't match any files;
+# add || true for the case where grep doesn't have matches, so the script doesn't halt
+# If there's an error "Argument list too long" add -n20 to xargs arguments and loop over $FILE around sed
+FILES=`find . -type d \( -name ignored -or -name .?\* \) -prune \
+       -o -type f -not \( -name \*.log -or -name '*.war' -or -name '*.min.js' -or -name '*.min.css' \) -print0 | \
+       xargs -0 grep -l "${VERSION_MARKER}\|${VERSION_MARKER_NL}" /dev/null || true`
+
+FILES_COUNT=`echo $FILES | wc | awk '{print $2}'`
+
+if [ ${FILES_COUNT} -ne 0 ]; then
+    # search for files containing version markers
+    sed -i.bak -e "/${VERSION_MARKER}/s/${CURRENT_VERSION}/${NEW_VERSION}/g" $FILES
+    sed -i.bak -e "/${VERSION_MARKER_NL}/{n;s/${CURRENT_VERSION}/${NEW_VERSION}/g;}" $FILES
+fi
+
+echo "Changed ${CURRENT_VERSION} to ${NEW_VERSION} for "${FILES_COUNT}" files"
+echo "(Do a \`find . -name \"*.bak\" -delete\`  to delete the backup files.)"

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/release/gpg-agent.conf
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/gpg-agent.conf b/brooklyn-dist/release/gpg-agent.conf
new file mode 100644
index 0000000..3cd0291
--- /dev/null
+++ b/brooklyn-dist/release/gpg-agent.conf
@@ -0,0 +1,2 @@
+default-cache-ttl 7200
+max-cache-ttl 86400

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/release/make-release-artifacts.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/make-release-artifacts.sh b/brooklyn-dist/release/make-release-artifacts.sh
new file mode 100755
index 0000000..476a6e3
--- /dev/null
+++ b/brooklyn-dist/release/make-release-artifacts.sh
@@ -0,0 +1,257 @@
+#!/bin/bash
+#
+# 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.
+#
+
+# creates a source release - this is a .tar.gz file containing all the source code files that are permitted to be released.
+
+set -e
+
+###############################################################################
+fail() {
+    echo >&2 "$@"
+    exit 1
+}
+
+###############################################################################
+show_help() {
+    cat >&2 <<END
+Usage: make-release-artifacts.sh [-v version] [-r rc_number]
+Prepares and builds the source and binary distribution artifacts of a Brooklyn
+release.
+
+  -vVERSION                  overrides the name of this version, if detection
+                             from pom.xml is not accurate for any reason.
+  -rRC_NUMBER                specifies the release candidate number. The
+                             produced artifact names include the 'rc' suffix,
+                             but the contents of the archive artifact do *not*
+                             include the suffix. Therefore, turning a release
+                             candidate into a release requires only renaming
+                             the artifacts.
+  -y                         answers "y" to all questions automatically, to
+                             use defaults and make this suitable for batch mode
+
+Specifying the RC number is required. Specifying the version number is
+discouraged; if auto detection is not working, then this script is buggy.
+
+Additionally if APACHE_DIST_SVN_DIR is set, this will transfer artifacts to
+that directory and svn commit them.
+END
+# ruler                      --------------------------------------------------
+}
+
+###############################################################################
+confirm() {
+    # call with a prompt string or use a default
+    if [ "${batch_confirm_y}" == "true" ] ; then
+        true
+    else
+      read -r -p "${1:-Are you sure? [y/N]} " response
+      case $response in
+        [yY][eE][sS]|[yY]) 
+            true
+            ;;
+        *)
+            false
+            ;;
+      esac
+    fi
+}
+
+###############################################################################
+detect_version() {
+    if [ \! -z "${current_version}" ]; then
+        return
+    fi
+
+    set +e
+    current_version=$( xmlstarlet select -t -v '/_:project/_:version/text()' pom.xml 2>/dev/null )
+    success=$?
+    set -e
+    if [ "${success}" -ne 0 -o -z "${current_version}" ]; then
+        fail Could not detect version number
+    fi
+}
+
+###############################################################################
+# Argument parsing
+rc_suffix=
+OPTIND=1
+while getopts "h?v:r:y?" opt; do
+    case "$opt" in
+        h|\?)
+            show_help
+            exit 0
+            ;;
+        v)
+            current_version=$OPTARG
+            ;;
+        r)
+            rc_suffix=$OPTARG
+            ;;
+        y)
+            batch_confirm_y=true
+            ;;
+        *)
+            show_help
+            exit 1
+    esac
+done
+
+shift $((OPTIND-1))
+[ "$1" = "--" ] && shift
+
+###############################################################################
+# Prerequisite checks
+[ -d .git ] || fail Must run in brooklyn project root directory
+
+detect_version
+
+###############################################################################
+# Determine all filenames and paths, and confirm
+
+release_name=apache-brooklyn-${current_version}
+if [ -z "$rc_suffix" ]; then
+    fail Specifying the RC number is required
+else
+    artifact_name=${release_name}-rc${rc_suffix}
+fi
+
+release_script_dir=$( cd $( dirname $0 ) && pwd )
+brooklyn_dir=$( pwd )
+rm -rf ${release_script_dir}/tmp
+staging_dir="${release_script_dir}/tmp/source/"
+src_staging_dir="${release_script_dir}/tmp/source/${release_name}-src"
+bin_staging_dir="${release_script_dir}/tmp/bin/"
+artifact_dir="${release_script_dir}/tmp/${artifact_name}"
+
+echo "The version is ${current_version}"
+echo "The rc suffix is rc${rc_suffix}"
+echo "The release name is ${release_name}"
+echo "The artifact name is ${artifact_name}"
+echo "The artifact directory is ${artifact_dir}"
+if [ ! -z "${APACHE_DIST_SVN_DIR}" ] ; then
+  echo "The artifacts will be copied and uploaded via ${APACHE_DIST_SVN_DIR}"
+else
+  echo "The artifacts will not be copied and uploaded to the svn repo"
+fi
+echo ""
+confirm "Is this information correct? [y/N]" || exit
+echo ""
+echo "WARNING! This script will run 'git clean -dxf' to remove ALL files that are not under Git source control."
+echo "This includes build artifacts and all uncommitted local files and directories."
+echo "If you want to check what will happen, answer no and run 'git clean -dxn' to dry run."
+echo ""
+confirm || exit
+echo ""
+echo "This script will cause uploads to be made to a staging repository on the Apache Nexus server."
+echo ""
+confirm "Shall I continue?  [y/N]" || exit
+
+###############################################################################
+# Clean the workspace
+git clean -dxf
+
+###############################################################################
+# Source release
+echo "Creating source release folder ${release_name}"
+set -x
+mkdir -p ${src_staging_dir}
+mkdir -p ${bin_staging_dir}
+# exclude: 
+# * docs (which isn't part of the release, and adding license headers to js files is cumbersome)
+# * sandbox (which hasn't been vetted so thoroughly)
+# * release (where this is running, and people who *have* the release don't need to make it)
+# * jars and friends (these are sometimes included for tests, but those are marked as skippable,
+#     and apache convention does not allow them in source builds; see PR #365
+rsync -rtp --exclude .git\* --exclude docs/ --exclude sandbox/ --exclude release/ --exclude '**/*.[ejw]ar' . ${staging_dir}/${release_name}-src
+
+rm -rf ${artifact_dir}
+mkdir -p ${artifact_dir}
+set +x
+echo "Creating artifact ${artifact_dir}/${artifact_name}-src.tar.gz and .zip"
+set -x
+( cd ${staging_dir} && tar czf ${artifact_dir}/${artifact_name}-src.tar.gz ${release_name}-src )
+( cd ${staging_dir} && zip -qr ${artifact_dir}/${artifact_name}-src.zip ${release_name}-src )
+
+###############################################################################
+# Binary release
+set +x
+echo "Proceeding to build binary release"
+set -x
+
+# Set up GPG agent
+if ps x | grep [g]pg-agent ; then
+  echo "gpg-agent already running; assuming it is set up and exported correctly."
+else
+  eval $(gpg-agent --daemon --no-grab --write-env-file $HOME/.gpg-agent-info)
+  GPG_TTY=$(tty)
+  export GPG_TTY GPG_AGENT_INFO
+fi
+
+# Workaround for bug BROOKLYN-1
+( cd ${src_staging_dir} && mvn clean --projects :brooklyn-archetype-quickstart )
+
+# Perform the build and deploy to Nexus staging repository
+( cd ${src_staging_dir} && mvn deploy -Papache-release )
+## To test the script without a big deploy, use the line below instead of above
+#( cd ${src_staging_dir} && cd usage/dist && mvn clean install )
+
+# Re-pack the archive with the correct names
+tar xzf ${src_staging_dir}/usage/dist/target/brooklyn-dist-${current_version}-dist.tar.gz -C ${bin_staging_dir}
+mv ${bin_staging_dir}/brooklyn-dist-${current_version} ${bin_staging_dir}/${release_name}-bin
+
+( cd ${bin_staging_dir} && tar czf ${artifact_dir}/${artifact_name}-bin.tar.gz ${release_name}-bin )
+( cd ${bin_staging_dir} && zip -qr ${artifact_dir}/${artifact_name}-bin.zip ${release_name}-bin )
+
+###############################################################################
+# Signatures and checksums
+
+# OSX doesn't have sha256sum, even if MacPorts md5sha1sum package is installed.
+# Easy to fake it though.
+which sha256sum >/dev/null || alias sha256sum='shasum -a 256' && shopt -s expand_aliases
+
+( cd ${artifact_dir} &&
+    for a in *.tar.gz *.zip; do
+        md5sum -b ${a} > ${a}.md5
+        sha1sum -b ${a} > ${a}.sha1
+        sha256sum -b ${a} > ${a}.sha256
+        gpg2 --armor --output ${a}.asc --detach-sig ${a}
+    done
+)
+
+###############################################################################
+
+if [ ! -z "${APACHE_DIST_SVN_DIR}" ] ; then
+  pushd ${APACHE_DIST_SVN_DIR}
+  rm -rf ${artifact_name}
+  cp -r ${artifact_dir} ${artifact_name}
+  svn add ${artifact_name}
+  svn commit --message "Add ${artifact_name} artifacts for incubator/brooklyn"
+  artifact_dir=${APACHE_DIST_SVN_DIR}/${artifact_name}
+  popd
+fi
+
+###############################################################################
+# Conclusion
+
+set +x
+echo "The release is done - here is what has been created:"
+ls ${artifact_dir}
+echo "You can find these files in: ${artifact_dir}"
+echo "The git commit ID for the voting emails is: $( git rev-parse HEAD )"

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/release/print-vote-email.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/print-vote-email.sh b/brooklyn-dist/release/print-vote-email.sh
new file mode 100755
index 0000000..5fd2256
--- /dev/null
+++ b/brooklyn-dist/release/print-vote-email.sh
@@ -0,0 +1,130 @@
+#!/bin/bash
+#
+# 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.
+#
+
+# prints a sample email with all the correct information
+
+set +x
+
+fail() {
+    echo >&2 "$@"
+    exit 1
+}
+
+if [ -z "${VERSION_NAME}" ] ; then fail VERSION_NAME must be set ; fi
+if [ -z "${RC_NUMBER}" ] ; then fail RC_NUMBER must be set ; fi
+
+base=apache-brooklyn-${VERSION_NAME}-rc${RC_NUMBER}
+
+if [ -z "$1" ] ; then fail "A single argument being the staging repo ID must be supplied, e.g. orgapachebrooklyn-1234" ; fi
+
+staging_repo_id=$1
+archetype_check=`curl https://repository.apache.org/content/repositories/${staging_repo_id}/archetype-catalog.xml 2> /dev/null`
+if ! echo $archetype_check | grep brooklyn-archetype-quickstart > /dev/null ; then
+  fail staging repo looks wrong at https://repository.apache.org/content/repositories/${staging_repo_id}
+fi
+if ! echo $archetype_check | grep ${VERSION_NAME} > /dev/null ; then
+  fail wrong version at https://repository.apache.org/content/repositories/${staging_repo_id}
+fi
+
+artifact=release/tmp/${base}/${base}-bin.tar.gz
+if [ ! -f $artifact ] ; then
+  fail could not find artifact $artifact
+fi
+if [ -z "$APACHE_ID" ] ; then
+  APACHE_ID=`gpg2 --verify ${artifact}.asc ${artifact} 2>&1 | egrep -o '[^<]*...@apache.org>' | cut -d @ -f 1`
+fi
+if [ -z "$APACHE_ID" ] ; then
+  fail "could not deduce APACHE_ID (your apache username); are files signed correctly?"
+fi
+if ! ( gpg2 --verify ${artifact}.asc ${artifact} 2>&1 | grep ${APACHE_ID}@apache.org > /dev/null ) ; then
+  fail "could not verify signature; are files signed correctly and ID ${APACHE_ID} correct?"
+fi
+
+cat <<EOF
+
+Subject: [VOTE] Release Apache Brooklyn ${VERSION_NAME} [rc${RC_NUMBER}]
+
+
+This is to call for a vote for the release of Apache Brooklyn ${VERSION_NAME}.
+
+This release comprises of a source code distribution, and a corresponding
+binary distribution, and Maven artifacts.
+
+The source and binary distributions, including signatures, digests, etc. can
+be found at:
+
+  https://dist.apache.org/repos/dist/dev/incubator/brooklyn/${base}
+
+The artifact SHA-256 checksums are as follows:
+
+EOF
+
+cat release/tmp/${base}/*.sha256 | awk '{print "  "$0}'
+
+cat <<EOF
+
+The Nexus staging repository for the Maven artifacts is located at:
+
+    https://repository.apache.org/content/repositories/${staging_repo_id}
+
+All release artifacts are signed with the following key:
+
+    https://people.apache.org/keys/committer/${APACHE_ID}.asc
+
+KEYS file available here:
+
+    https://dist.apache.org/repos/dist/release/incubator/brooklyn/KEYS
+
+
+The artifacts were built from git commit ID $( git rev-parse HEAD ):
+
+    https://git-wip-us.apache.org/repos/asf?p=incubator-brooklyn.git;a=commit;h=$( git rev-parse HEAD )
+
+
+Please vote on releasing this package as Apache Brooklyn ${VERSION_NAME}.
+
+The vote will be open for at least 72 hours.
+[ ] +1 Release this package as Apache Brooklyn ${VERSION_NAME}
+[ ] +0 no opinion
+[ ] -1 Do not release this package because ...
+
+
+Thanks!
+EOF
+
+cat <<EOF
+
+
+
+CHECKLIST for reference
+
+[ ] Download links work.
+[ ] Binaries work.
+[ ] Checksums and PGP signatures are valid.
+[ ] Expanded source archive matches contents of RC tag.
+[ ] Expanded source archive builds and passes tests.
+[ ] LICENSE is present and correct.
+[ ] NOTICE is present and correct, including copyright date.
+[ ] All files have license headers where appropriate.
+[ ] All dependencies have compatible licenses.
+[ ] No compiled archives bundled in source archive.
+[ ] I follow this project’s commits list.
+
+EOF

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/release/pull-request-reports/Gemfile
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/pull-request-reports/Gemfile b/brooklyn-dist/release/pull-request-reports/Gemfile
new file mode 100644
index 0000000..8ab84b5
--- /dev/null
+++ b/brooklyn-dist/release/pull-request-reports/Gemfile
@@ -0,0 +1,5 @@
+#ruby=ruby-2.1.2
+#ruby-gemset=brooklyn-release-helpers
+
+source 'https://rubygems.org'
+gem 'github_api'

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/release/pull-request-reports/Gemfile.lock
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/pull-request-reports/Gemfile.lock b/brooklyn-dist/release/pull-request-reports/Gemfile.lock
new file mode 100644
index 0000000..859202a
--- /dev/null
+++ b/brooklyn-dist/release/pull-request-reports/Gemfile.lock
@@ -0,0 +1,38 @@
+GEM
+  remote: https://rubygems.org/
+  specs:
+    addressable (2.3.8)
+    descendants_tracker (0.0.4)
+      thread_safe (~> 0.3, >= 0.3.1)
+    faraday (0.9.1)
+      multipart-post (>= 1.2, < 3)
+    github_api (0.12.3)
+      addressable (~> 2.3)
+      descendants_tracker (~> 0.0.4)
+      faraday (~> 0.8, < 0.10)
+      hashie (>= 3.3)
+      multi_json (>= 1.7.5, < 2.0)
+      nokogiri (~> 1.6.3)
+      oauth2
+    hashie (3.4.2)
+    jwt (1.5.1)
+    mini_portile (0.6.2)
+    multi_json (1.11.1)
+    multi_xml (0.5.5)
+    multipart-post (2.0.0)
+    nokogiri (1.6.6.2)
+      mini_portile (~> 0.6.0)
+    oauth2 (1.0.0)
+      faraday (>= 0.8, < 0.10)
+      jwt (~> 1.0)
+      multi_json (~> 1.3)
+      multi_xml (~> 0.5)
+      rack (~> 1.2)
+    rack (1.6.4)
+    thread_safe (0.3.5)
+
+PLATFORMS
+  ruby
+
+DEPENDENCIES
+  github_api

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/release/pull-request-reports/pr_report.rb
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/pull-request-reports/pr_report.rb b/brooklyn-dist/release/pull-request-reports/pr_report.rb
new file mode 100644
index 0000000..95b6317
--- /dev/null
+++ b/brooklyn-dist/release/pull-request-reports/pr_report.rb
@@ -0,0 +1,12 @@
+#ruby
+
+require 'CSV'
+require 'github_api'
+
+gh = Github.new
+
+CSV.open("pr_report.tsv", "wb", { :col_sep => "\t" }) do |csv|
+  gh.pull_requests.list('apache', 'incubator-brooklyn').
+      select { |pr| pr.state == "open" }.
+      each { |pr| csv << [ pr.number, pr.title, pr.created_at, pr.user.login ] }
+end

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/release/settings.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/settings.xml b/brooklyn-dist/release/settings.xml
new file mode 100644
index 0000000..2b03994
--- /dev/null
+++ b/brooklyn-dist/release/settings.xml
@@ -0,0 +1,29 @@
+<?xml version="1.0"?>
+<settings xsi:schemaLocation="http://maven.apache.org/SETTINGS/1.1.0 http://maven.apache.org/xsd/settings-1.1.0.xsd"
+          xmlns="http://maven.apache.org/SETTINGS/1.1.0"
+          xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
+
+    <servers>
+        <!-- Required for uploads to Apache's Nexus instance. These are LDAP credentials - the same credentials you
+           - would use to log in to Git and Jenkins (but not JIRA) -->
+        <server>
+            <id>apache.snapshots.https</id>
+            <username>xxx</username>
+            <password>xxx</password>
+        </server>
+        <server>
+            <id>apache.releases.https</id>
+            <username>xxx</username>
+            <password>xxx</password>
+        </server>
+
+        <!-- This is used for deployments to the play Artifactory instance that is provisioned by the Vagrant scripts.
+           - It may be safely ignored. -->
+        <server>
+            <id>vagrant-ubuntu-trusty-64</id>
+            <username>admin</username>
+            <password>password</password>
+        </server>
+    </servers>
+
+</settings>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/scripts/buildAndTest
----------------------------------------------------------------------
diff --git a/brooklyn-dist/scripts/buildAndTest b/brooklyn-dist/scripts/buildAndTest
new file mode 100755
index 0000000..45c1a26
--- /dev/null
+++ b/brooklyn-dist/scripts/buildAndTest
@@ -0,0 +1,102 @@
+#!/bin/bash
+#
+# 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.
+#
+# Convenience script to clean, build, install and run unit and/or integration tests.
+# Recommend you run this prior to pushing to Github to reduce the chances of breaking
+# the continuous integration (unit tests) or overnight builds (integration tests.)
+#
+# Also very useful when using "git bisect" to find out which commit was responsible
+# for breaking the overnight build - invoke as "git bisect run ./buildAndRun"
+#
+# Run "./buildAndRun --help" to see the usage.
+#
+
+# Has an integration test left a Java process running? See if there is any running
+# Java processes and offer to kill them/
+cleanup(){
+    PROCS=$(ps ax | grep '[j]ava' | grep -v set_tab_title)
+    if [ ! -z "${PROCS}" ]; then
+	echo "These Java processes are running:"
+	echo ${PROCS}
+	echo -n "Kill them? y=yes, n=no, x=abort: "
+	read $RESPONSE
+	[ "${RESPONSE}" = "y" ] && killall java && sleep 1s
+	[ "${RESPONSE}" = "x" ] && exit 50
+    fi
+}
+
+# Check a return value, and bail if its non-zero - invoke as "assert $? 'Unit tests'"
+assert(){
+    [ $1 -eq 0 ] && return
+    echo '*** Command returned '$1' on '$2
+    exit $1
+}
+
+# The defaults
+unit=1
+integration=1
+
+if [ ! -z "$1" ]; then
+    case "$1" in
+	u)
+	    unit=1
+	    integration=0
+	    ;;
+	i)
+	    unit=0
+	    integration=1
+	    ;;
+	ui)
+	    unit=1
+	    integration=1
+	    ;;
+	b)
+	    unit=0
+	    integration=0
+	    ;;
+	*)
+	    echo >&2 Usage: buildAndTest [action]
+	    echo >&2 where action is:
+	    echo >&2 u - build from clean and run unit tests
+	    echo >&2 i - build from clean and run integration tests
+	    echo >&2 ui - build from clean and run unit and integration tests \(default\)
+	    echo >&2 b - build from clean and do not run any tests
+	    exit 1
+	    ;;
+    esac
+fi
+
+echo '*** BUILD'
+mvn clean install -DskipTests -PConsole
+assert $? 'BUILD'
+cleanup
+if [ $unit -eq 1 ]; then
+    echo '*** UNIT TEST'
+    mvn integration-test -PConsole
+    assert $? 'UNIT TEST'
+    cleanup
+fi
+if [ $integration -eq 1 ]; then
+    echo '*** INTEGRATION TEST'
+    mvn integration-test -PConsole,Integration
+    assert $? 'INTEGRATION TEST'
+    cleanup
+fi
+
+exit 0

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/scripts/grep-in-poms.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/scripts/grep-in-poms.sh b/brooklyn-dist/scripts/grep-in-poms.sh
new file mode 100755
index 0000000..aca9258
--- /dev/null
+++ b/brooklyn-dist/scripts/grep-in-poms.sh
@@ -0,0 +1,25 @@
+#!/usr/bin/env bash
+#
+# 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.
+#
+
+# usage: run in the root dir of a project, it will grep in poms up to 3 levels deep
+# e.g. where are shaded jars defined?
+# brooklyn% grep-in-poms -i slf4j
+
+grep $* {.,*,*/*,*/*/*}/pom.xml

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/scripts/release-branch-from-master
----------------------------------------------------------------------
diff --git a/brooklyn-dist/scripts/release-branch-from-master b/brooklyn-dist/scripts/release-branch-from-master
new file mode 100755
index 0000000..8d7befa
--- /dev/null
+++ b/brooklyn-dist/scripts/release-branch-from-master
@@ -0,0 +1,114 @@
+#!/bin/bash -e
+#
+# 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.
+#
+
+usage(){
+	echo >&2 'Usage: release-branch-from-master --release <version> [ --release-suffix <suffix> ]'
+	echo >&2 '                                  --master <version>  [ --master-suffix <suffix> ]'
+	echo >&2 'Creates a release branch, and updates the version number in both the branch and master.'
+	echo >&2 '<version> should be a two-part version number, such as 3.6 or 4.0.'
+	echo >&2 '<suffix> will normally be of the form ".patchlevel", plus "-RC1" or similar if required,'
+	echo >&2 'plus "-SNAPSHOT". Example: ".0.RC1-SNAPSHOT". The defaults for the suffix are normally sensible.'
+	echo >&2 'This command will preview what it is going to do and require confirmation before it makes changes.'
+}
+
+release_ver=
+release_ver_suffix=.0-RC1-SNAPSHOT
+master_ver=
+master_ver_suffix=.0-SNAPSHOT
+
+[ $# -eq 0 ] && echo >&2 "No arguments given, so I'm going to try and figure it out myself. Invoke with the --help option if you want to find how to invoke this script."
+
+while [ $# -gt 0 ]; do
+	case $1 in
+		--release)			shift; release_ver=$1;;
+		--release-suffix)	shift; release_ver_suffix=$1;;
+		--master)			shift; master_ver=$1;;
+		--master-suffix)	shift; master_ver_suffix=$1;;
+		*)					usage; exit 1;;
+	esac
+	shift
+done
+
+# Use xpath to query the current version number in the pom
+xpath='xpath'
+type -P $xpath &>/dev/null && {
+	set +e
+	current_version=$( xpath pom.xml '/project/version/text()' 2>/dev/null )
+	( echo ${current_version} | grep -qE '^([0-9]+).([0-9]+).0-SNAPSHOT$' )
+	current_version_valid=$?
+	set -e 
+} || { 
+	echo "Cannot guess version number as $xpath command not found."
+	current_version_valid=1
+}
+
+if [ "${current_version_valid}" -ne 0 -a -z "${release_ver}" -a -z "${master_ver}" ]; then
+	echo >&2 "Detected current version as '${current_version}', but I can't parse this. Please supply --release and --master parameters."
+	exit 1
+fi
+
+[ -z "${release_ver}" ] && {
+	release_ver=${current_version%-SNAPSHOT}
+	release_ver=${release_ver%.0}
+	[ -z "${release_ver}" ] && { echo >&2 Could not determine the version of the release branch. Please use the --release parameter. ; exit 1 ; }
+}
+
+[ -z "${master_ver}" ] && {
+	master_ver=$( echo ${current_version} | perl -n -e 'if (/^(\d+).(\d+)(.*)$/) { printf "%s.%s\n", $1, $2+1 }' )
+	[ -z "${master_ver}" ] && { echo >&2 Could not determine the version of the master branch. Please use the --master parameter. ; exit 1 ; }
+}
+
+version_on_branch=${release_ver}${release_ver_suffix}
+version_on_master=${master_ver}${master_ver_suffix}
+branch_name=${version_on_branch}
+
+# Show the details and get confirmation
+echo "The current version is:                                  ${current_version}"
+echo "The release branch will be named:                        ${branch_name}"
+echo "The version number on the release branch will be set to: ${version_on_branch}"
+echo "The version number on 'master' will be set to:           ${version_on_master}"
+echo "If you proceed, the new branch and version number changes will be pushed to GitHub."
+echo -n 'Enter "y" if this is correct, anything else to abort: '
+read input
+[ "$input" == "y" ] || { echo >&2 Aborted. ; exit 1 ; }
+
+# Fail if not in a Git repository
+[ -d .git ] || {
+	echo >&2 Error: this directory is not a git repository root. Nothing happened.
+	exit 1
+}
+
+# Warn if the current branch isn't master
+current_branch=$( git name-rev --name-only HEAD )
+[ ${current_branch} == "master" ] || {
+	echo Current branch is ${current_branch}. Usually, release branches are made from master.
+	echo -n 'Enter "y" if this is correct, anything else to abort: '
+	read input
+	[ "$input" == "y" ] || { echo >&2 Aborted. ; exit 1 ; }
+}
+
+# Get Maven to make the branch
+set -x
+mvn release:clean release:branch -P Brooklyn,Console,Example,Launcher,Acceptance,Documentation --batch-mode -DautoVersionSubmodules=true -DbranchName=${branch_name} -DupdateBranchVersions=true -DreleaseVersion=${version_on_branch} -DdevelopmentVersion=${version_on_master}
+set +x
+
+# Done!
+echo Completed. Your repository is still looking at ${current_branch}. To switch to the release branch, enter:
+echo git checkout ${branch_name}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/scripts/release-make
----------------------------------------------------------------------
diff --git a/brooklyn-dist/scripts/release-make b/brooklyn-dist/scripts/release-make
new file mode 100755
index 0000000..df46ea1
--- /dev/null
+++ b/brooklyn-dist/scripts/release-make
@@ -0,0 +1,83 @@
+#!/bin/bash -e -u
+#
+# 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.
+#
+
+usage(){
+	echo >&2 'Usage: release-make [ --release <version> ] [ --next <version> ]'
+	echo >&2 'Creates and tags a release based on the current branch.'
+	echo >&2 'Arguments are optional - if omitted, the script tries to work out the correct versions.'
+	echo >&2 'release <version> should be a full version number, such as 3.6.0-RC1'
+	echo >&2 'next <version> should be a snapshot version number, such as 3.6.0-RC2-SNAPSHOT'
+	echo >&2 'This command will preview what it is going to do and require confirmation before it makes changes.'
+}
+
+[ $# -eq 0 ] && echo >&2 "No arguments given, so I'm going to try and figure it out myself. Invoke with the --help option if you want to find how to invoke this script."
+
+release_tag_ver=
+release_branch_ver=
+
+while [ $# -gt 0 ]; do
+	case $1 in
+		--release)	shift; release_tag_ver=$1;;
+		--next)		shift; release_branch_ver=$1;;
+		*)					usage; exit 1;;
+	esac
+	shift
+done
+
+# Some magic to derive the anticipated version of the release.
+# Use xpath to query the version number in the pom
+xpath='xpath'
+type -P $xpath &>/dev/null && {
+	set +e
+	current_version=$( xpath pom.xml '/project/version/text()' 2>/dev/null )
+	set -e
+} || {
+        echo "Cannot guess version number as $xpath command not found."
+}
+# If the user didn't supply the release version, strip -SNAPSHOT off the current version and use that
+[ -z "$release_tag_ver" ] && release_tag_ver=${current_version%-SNAPSHOT}
+
+# More magic, this time to guess the next version.
+# If the user didn't supply the next version, modify the digits off the end of the release to increment by one and append -SNAPSHOT
+[ -z "$release_branch_ver" ] && release_branch_ver=$( echo ${release_tag_ver} | perl -n -e 'if (/^(.*)(\d+)$/) { print $1.($2+1)."-SNAPSHOT\n" }' )
+
+current_branch=$( git name-rev --name-only HEAD )
+
+echo "The release is on the branch:                             ${current_branch}"
+echo "The current version (detected) is:                        ${current_version}"
+echo "The release version is:                                   ${release_tag_ver}"
+echo "Development on the release branch continues with version: ${release_branch_ver}"
+echo -n 'Enter "y" if this is correct, anything else to abort: '
+read input
+[ "$input" == "y" ] || { echo >&2 Aborted. ; exit 1 ; }
+
+# Warn if the current branch is master
+[ ${current_branch} == "master" ] && {
+	echo Current branch is ${current_branch}. Usually, releases are made from a release branch.
+	echo -n 'Enter "y" if this is correct, anything else to abort: '
+	read input
+	[ "$input" == "y" ] || { echo >&2 Aborted. ; exit 1 ; }
+}
+
+# Release prepare
+mvn release:clean release:prepare -PExample,Launcher,Four,Three --batch-mode -DautoVersionSubmodules=true -DreleaseVersion=${release_tag_ver} -DdevelopmentVersion=${release_branch_ver}
+
+# Release perform
+mvn release:perform -PExample,Launcher,Four,Three --batch-mode

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/release/.gitignore
----------------------------------------------------------------------
diff --git a/release/.gitignore b/release/.gitignore
deleted file mode 100644
index 16d63d3..0000000
--- a/release/.gitignore
+++ /dev/null
@@ -1,2 +0,0 @@
-.vagrant
-tmp

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/release/README.md
----------------------------------------------------------------------
diff --git a/release/README.md b/release/README.md
deleted file mode 100644
index 325b165..0000000
--- a/release/README.md
+++ /dev/null
@@ -1,50 +0,0 @@
-Release Scripts and Helpers
-===========================
-
-This folder contains a number of items that will assist in the production of Brooklyn releases.
-
-
-Release scripts - change-version.sh and make-release-artifacts.sh
------------------------------------------------------------------
-
-`change-version.sh` will update version numbers across the whole distribution.  It is recommended to use this script
-rather than "rolling your own" or using a manual process, as you risk missing out some version numbers (and
-accidentally changing some that should not be changed).
-
-`make-release-artifacts.sh` will produce the release artifacts with appropriate signatures. It is recommended to use
-this script rather than "rolling your own" or using a manual process, as this script codifies several Apache
-requirements about the release artifacts.
-
-These scripts are fully documented in **Release Process** pages on the website.
-
-
-Vagrant configuration
----------------------
-
-The `Vagrantfile` and associated files `settings.xml` and `gpg-agent.conf` are for setting up a virtual machine hosting
-a complete and clean development environment. You may benefit from using this environment when making the release, but
-it is not required that you do so.
-
-The environment is a single VM that configured with all the tools needed to make the release. It also configures GnuPG
-by copying your `gpg.conf`, `secring.gpg` and `pubring.gpg` into the VM; also copied is your `.gitconfig`. The
-GnuPG agent is configured to assist with the release signing by caching your passphrase, so you will only need to enter
-it once during the build process. A Maven `settings.xml` is provided to assist with the upload to Apache's Nexus server.
-Finally the canonical Git repository for Apache Brooklyn is cloned into the home directory.
-
-You should edit `settings.xml` before deployment, or `~/.m2/settings.xml` inside the VM after deployment, to include
-your Apache credentials.
-
-Assuming you have VirtualBox and Vagrant already installed, you should simply be able to run `vagrant up` to create the
-VM, and then `vagrant ssh` to get a shell prompt inside the VM. Finally run `vagrant destroy` to clean up afterwards.
-
-This folder is mounted at `/vagrant` inside the VM - this means the release helpers are close to hand, so you can
-run for example `/vagrant/make-release/artifacts.sh`.
-
-
-Pull request reporting
-----------------------
-
-The files in `pull-request-reports`, mainly `pr_report.rb` 
-(and associated files `Gemfile` and `Gemfile.lock`) uses the GitHub API to extract a list of open pull
-requests, and writes a summary into `pr_report.tsv`. This could then be imported into Google Sheets to provide a handy
-way of classifying and managing outstanding PRs ahead of making a release.


[20/51] [abbrv] brooklyn-dist git commit: [DIST] put a minimal README in the dist (instead of the "historical repo" readme!)

Posted by he...@apache.org.
[DIST]  put a minimal README in the dist (instead of the "historical repo" readme!)


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

Branch: refs/heads/master
Commit: 682632678312bd683722050e8b3255858cf03b2f
Parents: 501bfe3
Author: Alex Heneveld <al...@cloudsoftcorp.com>
Authored: Tue Dec 22 15:34:47 2015 +0000
Committer: Alex Heneveld <al...@cloudsoftcorp.com>
Committed: Tue Dec 22 16:09:13 2015 +0000

----------------------------------------------------------------------
 .../dist/src/main/config/build-distribution.xml    |  1 -
 brooklyn-dist/dist/src/main/dist/README.md         | 17 +++++++++++++++++
 2 files changed, 17 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/68263267/brooklyn-dist/dist/src/main/config/build-distribution.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/config/build-distribution.xml b/brooklyn-dist/dist/src/main/config/build-distribution.xml
index fc2264d..f543292 100644
--- a/brooklyn-dist/dist/src/main/config/build-distribution.xml
+++ b/brooklyn-dist/dist/src/main/config/build-distribution.xml
@@ -29,7 +29,6 @@
             <fileMode>0644</fileMode>
             <directoryMode>0755</directoryMode>
             <includes>
-                <include>README*</include>
                 <include>DISCLAIMER*</include>
             </includes>
         </fileSet>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/68263267/brooklyn-dist/dist/src/main/dist/README.md
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/dist/README.md b/brooklyn-dist/dist/src/main/dist/README.md
new file mode 100644
index 0000000..3c7e46f
--- /dev/null
+++ b/brooklyn-dist/dist/src/main/dist/README.md
@@ -0,0 +1,17 @@
+
+# [![**Brooklyn**](https://brooklyn.apache.org/style/img/apache-brooklyn-logo-244px-wide.png)](http://brooklyn.apache.org/)
+
+### Apache Brooklyn
+
+This is the distribution of Apache Brooklyn.
+
+As a quick start, run:
+
+    ./bin/brooklyn launch
+
+For server CLI info, use:
+
+    ./bin/brooklyn help
+
+And to learn more, including the full user's guide, visit [http://github.com/apache/brooklyn/].
+


[04/51] [abbrv] brooklyn-dist git commit: [SPLITPREP] rearranged to have structure of new repositories

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/main/resources/META-INF/maven/archetype-metadata.xml
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/main/resources/META-INF/maven/archetype-metadata.xml b/usage/archetypes/quickstart/src/main/resources/META-INF/maven/archetype-metadata.xml
deleted file mode 100644
index 4768945..0000000
--- a/usage/archetypes/quickstart/src/main/resources/META-INF/maven/archetype-metadata.xml
+++ /dev/null
@@ -1,65 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-    
-     http://www.apache.org/licenses/LICENSE-2.0
-    
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-<archetype xmlns="http://maven.apache.org/plugins/maven-archetype-plugin/archetype/1.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-  xsi:schemaLocation="http://maven.apache.org/plugins/maven-archetype-plugin/archetype/1.0.0 http://maven.apache.org/xsd/archetype-1.0.0.xsd">
-
-  <fileSets>
-    <fileSet filtered="true" packaged="true">
-      <directory>src/main/java</directory>
-      <includes>
-        <include>**/*.java</include>
-      </includes>
-    </fileSet>
-    
-    <fileSet filtered="true" packaged="true">
-      <directory>src/test/java</directory>
-      <includes>
-        <include>**/*.java</include>
-      </includes>
-    </fileSet>
-    
-    <!-- we cannot have src/main/resources/** be "packaged" (package dirs prepended) and non-packaged;
-         so we put everything non-packaged here.
-         (also note for src/main/java, the root pom uses google-replacer to drop the "package" directory) -->
-           
-    <fileSet filtered="false" packaged="false">
-      <directory></directory>
-      <includes>
-        <include>**/*.png</include>
-        <include>**/*.sh</include>
-      </includes>
-    </fileSet>
-    <fileSet filtered="true" packaged="false">
-      <directory></directory>
-      <includes>
-        <include>**/*</include>
-        <include>*</include>
-      </includes>
-      <excludes>
-        <exclude>src/main/java/**</exclude> 
-        <exclude>src/test/java/**</exclude> 
-        <exclude>pom.xml</exclude>
-        <exclude>**.png</exclude>
-        <exclude>**.sh</exclude>
-      </excludes>
-    </fileSet>
-  </fileSets>
-
-</archetype>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/test/resources/projects/integration-test-1/.gitignore
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/test/resources/projects/integration-test-1/.gitignore b/usage/archetypes/quickstart/src/test/resources/projects/integration-test-1/.gitignore
deleted file mode 100644
index 25d80f5..0000000
--- a/usage/archetypes/quickstart/src/test/resources/projects/integration-test-1/.gitignore
+++ /dev/null
@@ -1 +0,0 @@
-reference

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/test/resources/projects/integration-test-1/archetype.properties
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/test/resources/projects/integration-test-1/archetype.properties b/usage/archetypes/quickstart/src/test/resources/projects/integration-test-1/archetype.properties
deleted file mode 100644
index d1f4da4..0000000
--- a/usage/archetypes/quickstart/src/test/resources/projects/integration-test-1/archetype.properties
+++ /dev/null
@@ -1,22 +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.
-#
-groupId=com.acme.sample
-artifactId=brooklyn-sample
-version=0.1.0-SNAPSHOT
-package=com.acme.sample.brooklyn

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/test/resources/projects/integration-test-1/goal.txt
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/test/resources/projects/integration-test-1/goal.txt b/usage/archetypes/quickstart/src/test/resources/projects/integration-test-1/goal.txt
deleted file mode 100644
index f7ffc47..0000000
--- a/usage/archetypes/quickstart/src/test/resources/projects/integration-test-1/goal.txt
+++ /dev/null
@@ -1 +0,0 @@
-install
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/.gitignore
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/.gitignore b/usage/dist/licensing/.gitignore
deleted file mode 100644
index 2d17061..0000000
--- a/usage/dist/licensing/.gitignore
+++ /dev/null
@@ -1,2 +0,0 @@
-LICENSE.autogenerated
-notices.autogenerated

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/MAIN_LICENSE_ASL2
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/MAIN_LICENSE_ASL2 b/usage/dist/licensing/MAIN_LICENSE_ASL2
deleted file mode 100644
index 68c771a..0000000
--- a/usage/dist/licensing/MAIN_LICENSE_ASL2
+++ /dev/null
@@ -1,176 +0,0 @@
-
-                                 Apache License
-                           Version 2.0, January 2004
-                        http://www.apache.org/licenses/
-
-   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
-
-   1. Definitions.
-
-      "License" shall mean the terms and conditions for use, reproduction,
-      and distribution as defined by Sections 1 through 9 of this document.
-
-      "Licensor" shall mean the copyright owner or entity authorized by
-      the copyright owner that is granting the License.
-
-      "Legal Entity" shall mean the union of the acting entity and all
-      other entities that control, are controlled by, or are under common
-      control with that entity. For the purposes of this definition,
-      "control" means (i) the power, direct or indirect, to cause the
-      direction or management of such entity, whether by contract or
-      otherwise, or (ii) ownership of fifty percent (50%) or more of the
-      outstanding shares, or (iii) beneficial ownership of such entity.
-
-      "You" (or "Your") shall mean an individual or Legal Entity
-      exercising permissions granted by this License.
-
-      "Source" form shall mean the preferred form for making modifications,
-      including but not limited to software source code, documentation
-      source, and configuration files.
-
-      "Object" form shall mean any form resulting from mechanical
-      transformation or translation of a Source form, including but
-      not limited to compiled object code, generated documentation,
-      and conversions to other media types.
-
-      "Work" shall mean the work of authorship, whether in Source or
-      Object form, made available under the License, as indicated by a
-      copyright notice that is included in or attached to the work
-      (an example is provided in the Appendix below).
-
-      "Derivative Works" shall mean any work, whether in Source or Object
-      form, that is based on (or derived from) the Work and for which the
-      editorial revisions, annotations, elaborations, or other modifications
-      represent, as a whole, an original work of authorship. For the purposes
-      of this License, Derivative Works shall not include works that remain
-      separable from, or merely link (or bind by name) to the interfaces of,
-      the Work and Derivative Works thereof.
-
-      "Contribution" shall mean any work of authorship, including
-      the original version of the Work and any modifications or additions
-      to that Work or Derivative Works thereof, that is intentionally
-      submitted to Licensor for inclusion in the Work by the copyright owner
-      or by an individual or Legal Entity authorized to submit on behalf of
-      the copyright owner. For the purposes of this definition, "submitted"
-      means any form of electronic, verbal, or written communication sent
-      to the Licensor or its representatives, including but not limited to
-      communication on electronic mailing lists, source code control systems,
-      and issue tracking systems that are managed by, or on behalf of, the
-      Licensor for the purpose of discussing and improving the Work, but
-      excluding communication that is conspicuously marked or otherwise
-      designated in writing by the copyright owner as "Not a Contribution."
-
-      "Contributor" shall mean Licensor and any individual or Legal Entity
-      on behalf of whom a Contribution has been received by Licensor and
-      subsequently incorporated within the Work.
-
-   2. Grant of Copyright License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      copyright license to reproduce, prepare Derivative Works of,
-      publicly display, publicly perform, sublicense, and distribute the
-      Work and such Derivative Works in Source or Object form.
-
-   3. Grant of Patent License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      (except as stated in this section) patent license to make, have made,
-      use, offer to sell, sell, import, and otherwise transfer the Work,
-      where such license applies only to those patent claims licensable
-      by such Contributor that are necessarily infringed by their
-      Contribution(s) alone or by combination of their Contribution(s)
-      with the Work to which such Contribution(s) was submitted. If You
-      institute patent litigation against any entity (including a
-      cross-claim or counterclaim in a lawsuit) alleging that the Work
-      or a Contribution incorporated within the Work constitutes direct
-      or contributory patent infringement, then any patent licenses
-      granted to You under this License for that Work shall terminate
-      as of the date such litigation is filed.
-
-   4. Redistribution. You may reproduce and distribute copies of the
-      Work or Derivative Works thereof in any medium, with or without
-      modifications, and in Source or Object form, provided that You
-      meet the following conditions:
-
-      (a) You must give any other recipients of the Work or
-          Derivative Works a copy of this License; and
-
-      (b) You must cause any modified files to carry prominent notices
-          stating that You changed the files; and
-
-      (c) You must retain, in the Source form of any Derivative Works
-          that You distribute, all copyright, patent, trademark, and
-          attribution notices from the Source form of the Work,
-          excluding those notices that do not pertain to any part of
-          the Derivative Works; and
-
-      (d) If the Work includes a "NOTICE" text file as part of its
-          distribution, then any Derivative Works that You distribute must
-          include a readable copy of the attribution notices contained
-          within such NOTICE file, excluding those notices that do not
-          pertain to any part of the Derivative Works, in at least one
-          of the following places: within a NOTICE text file distributed
-          as part of the Derivative Works; within the Source form or
-          documentation, if provided along with the Derivative Works; or,
-          within a display generated by the Derivative Works, if and
-          wherever such third-party notices normally appear. The contents
-          of the NOTICE file are for informational purposes only and
-          do not modify the License. You may add Your own attribution
-          notices within Derivative Works that You distribute, alongside
-          or as an addendum to the NOTICE text from the Work, provided
-          that such additional attribution notices cannot be construed
-          as modifying the License.
-
-      You may add Your own copyright statement to Your modifications and
-      may provide additional or different license terms and conditions
-      for use, reproduction, or distribution of Your modifications, or
-      for any such Derivative Works as a whole, provided Your use,
-      reproduction, and distribution of the Work otherwise complies with
-      the conditions stated in this License.
-
-   5. Submission of Contributions. Unless You explicitly state otherwise,
-      any Contribution intentionally submitted for inclusion in the Work
-      by You to the Licensor shall be under the terms and conditions of
-      this License, without any additional terms or conditions.
-      Notwithstanding the above, nothing herein shall supersede or modify
-      the terms of any separate license agreement you may have executed
-      with Licensor regarding such Contributions.
-
-   6. Trademarks. This License does not grant permission to use the trade
-      names, trademarks, service marks, or product names of the Licensor,
-      except as required for reasonable and customary use in describing the
-      origin of the Work and reproducing the content of the NOTICE file.
-
-   7. Disclaimer of Warranty. Unless required by applicable law or
-      agreed to in writing, Licensor provides the Work (and each
-      Contributor provides its Contributions) on an "AS IS" BASIS,
-      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-      implied, including, without limitation, any warranties or conditions
-      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-      PARTICULAR PURPOSE. You are solely responsible for determining the
-      appropriateness of using or redistributing the Work and assume any
-      risks associated with Your exercise of permissions under this License.
-
-   8. Limitation of Liability. In no event and under no legal theory,
-      whether in tort (including negligence), contract, or otherwise,
-      unless required by applicable law (such as deliberate and grossly
-      negligent acts) or agreed to in writing, shall any Contributor be
-      liable to You for damages, including any direct, indirect, special,
-      incidental, or consequential damages of any character arising as a
-      result of this License or out of the use or inability to use the
-      Work (including but not limited to damages for loss of goodwill,
-      work stoppage, computer failure or malfunction, or any and all
-      other commercial damages or losses), even if such Contributor
-      has been advised of the possibility of such damages.
-
-   9. Accepting Warranty or Additional Liability. While redistributing
-      the Work or Derivative Works thereof, You may choose to offer,
-      and charge a fee for, acceptance of support, warranty, indemnity,
-      or other liability obligations and/or rights consistent with this
-      License. However, in accepting such obligations, You may act only
-      on Your own behalf and on Your sole responsibility, not on behalf
-      of any other Contributor, and only if You agree to indemnify,
-      defend, and hold each Contributor harmless for any liability
-      incurred by, or claims asserted against, such Contributor by reason
-      of your accepting any such warranty or additional liability.
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/README.md
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/README.md b/usage/dist/licensing/README.md
deleted file mode 100644
index 94ae070..0000000
--- a/usage/dist/licensing/README.md
+++ /dev/null
@@ -1,78 +0,0 @@
-
-We use a special maven plugin and scripts to automatically create the LICENSE
-files, including all notices, based on metadata in overrides.yaml and **/source-inclusions.yaml.
-
-First install  https://github.com/ahgittin/license-audit-maven-plugin 
-and then, in the usage/dist/ project of Brooklyn...
-
-
-# Quick Usage
-
-To see a tree of license info:
-
-    mvn org.heneveld.maven:license-audit-maven-plugin:report \
-        -Dformat=summary \
-        -DlicensesPreferred=ASL2,ASL,EPL1,BSD-2-Clause,BSD-3-Clause,CDDL1.1,CDDL1,CDDL \
-        -DoverridesFile=licensing/overrides.yaml \
-        -DextrasFiles=`cat licensing/extras-files`
-
-
-To create the LICENSE files needed for Apache Brooklyn
-(consisting of: one in the root for the source build, in the dist project for the binary build,
-and in `projects-with-custom-licenses` for those JARs which include other source code):
-
-    pushd licensing
-    ./make-all-licenses.sh || ( echo 'FAILED!!!' && rm LICENSE.autogenerated )
-    popd
-
-This combines the relevant `source-inclusions.yaml` files to create `extrasFile` files
-for `license-audit-maven-plugin` then runs the `notices` target for the various dists we make.
-If you need to add a new project to those which require custom LICENSE files, see below.
-
-
-# CSV License Report
-
-If you need to generate a CSV report of license usage, e.g. for use in a spreadsheet:
-
-    mvn org.heneveld.maven:license-audit-maven-plugin:report \
-        -Dformat=csv \
-        -DlistDependencyIdOnly=true \
-        -DsuppressExcludedDependencies=true \
-        -DlicensesPreferred=ASL2,ASL,EPL1,BSD-2-Clause,BSD-3-Clause,CDDL1.1,CDDL1,CDDL \
-        -DoverridesFile=licensing/overrides.yaml \
-        -DextrasFiles=`cat licensing/extras-files` \
-        -DoutputFile=dependencies-licenses.csv
-
-
-# When Projects Need Custom Licenses
-
-If a JAR includes 3rd party source code (as opposed to binary dependencies), it will typically 
-require a custom LICENSE file.
-
-To support this: 
-
-1. Add the relative path to that project to `projects-with-custom-licenses`,
-
-2. Create the necessary file structure and maven instructions:
-
-* in `src/main/license/` put a `README.md` pointing here
-* in `src/main/license/` put a `source-inclusion.yaml` listing the included 3rd-party projects by an `id:`
-  (you may need to choose an ID; this should be a meaningful name, e.g. `typeahead.js` or `Swagger UI`)
-* in `src/main/license/files` put the relevant non-LICENSE license files you want included (e.g. NOTICE)
-* in `src/test/license/files` put the standard files *including* LICENSE to include in the test JAR
-  (NB: these scripts don't generate custom licenses for test JARs, as so far that has not been needed)
-* in `pom.xml` add instructions to include `src/{main,test}/license/files` in the main and test JARs
-
-You can follow the pattern done for `cli` and `jsgui`.
-
-3. In `licensing/overrides.yaml` in this directory, add the metadata for the included projects.
-
-4. In `licensing/licenses/<your_project>/` include the relevant licenses for any included 3rd-party projects;
-   look in `licensing/licenses/binary` for samples.
-
-5. Run `make-all-licenses.sh` to auto-generate required config files and license copies,
-   and to generate the LICENSE for your project.
-
-Confirm that a LICENSE file for your project was generated, and that it is present in the JAR,
-and then open a pull-request, and confirm the changes there are appropriate.
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/extras-files
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/extras-files b/usage/dist/licensing/extras-files
deleted file mode 100644
index bb4a3b3..0000000
--- a/usage/dist/licensing/extras-files
+++ /dev/null
@@ -1 +0,0 @@
-../jsgui/src/main/license/source-inclusions.yaml:../cli/src/main/license/source-inclusions.yaml

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/binary/ASL2
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/binary/ASL2 b/usage/dist/licensing/licenses/binary/ASL2
deleted file mode 100644
index eccbc6a..0000000
--- a/usage/dist/licensing/licenses/binary/ASL2
+++ /dev/null
@@ -1,177 +0,0 @@
-Apache License, Version 2.0
-
-  Apache License
-  Version 2.0, January 2004
-  http://www.apache.org/licenses/
-  
-  TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
-  
-  1. Definitions.
-  
-  "License" shall mean the terms and conditions for use, reproduction,
-  and distribution as defined by Sections 1 through 9 of this document.
-  
-  "Licensor" shall mean the copyright owner or entity authorized by
-  the copyright owner that is granting the License.
-  
-  "Legal Entity" shall mean the union of the acting entity and all
-  other entities that control, are controlled by, or are under common
-  control with that entity. For the purposes of this definition,
-  "control" means (i) the power, direct or indirect, to cause the
-  direction or management of such entity, whether by contract or
-  otherwise, or (ii) ownership of fifty percent (50%) or more of the
-  outstanding shares, or (iii) beneficial ownership of such entity.
-  
-  "You" (or "Your") shall mean an individual or Legal Entity
-  exercising permissions granted by this License.
-  
-  "Source" form shall mean the preferred form for making modifications,
-  including but not limited to software source code, documentation
-  source, and configuration files.
-  
-  "Object" form shall mean any form resulting from mechanical
-  transformation or translation of a Source form, including but
-  not limited to compiled object code, generated documentation,
-  and conversions to other media types.
-  
-  "Work" shall mean the work of authorship, whether in Source or
-  Object form, made available under the License, as indicated by a
-  copyright notice that is included in or attached to the work
-  (an example is provided in the Appendix below).
-  
-  "Derivative Works" shall mean any work, whether in Source or Object
-  form, that is based on (or derived from) the Work and for which the
-  editorial revisions, annotations, elaborations, or other modifications
-  represent, as a whole, an original work of authorship. For the purposes
-  of this License, Derivative Works shall not include works that remain
-  separable from, or merely link (or bind by name) to the interfaces of,
-  the Work and Derivative Works thereof.
-  
-  "Contribution" shall mean any work of authorship, including
-  the original version of the Work and any modifications or additions
-  to that Work or Derivative Works thereof, that is intentionally
-  submitted to Licensor for inclusion in the Work by the copyright owner
-  or by an individual or Legal Entity authorized to submit on behalf of
-  the copyright owner. For the purposes of this definition, "submitted"
-  means any form of electronic, verbal, or written communication sent
-  to the Licensor or its representatives, including but not limited to
-  communication on electronic mailing lists, source code control systems,
-  and issue tracking systems that are managed by, or on behalf of, the
-  Licensor for the purpose of discussing and improving the Work, but
-  excluding communication that is conspicuously marked or otherwise
-  designated in writing by the copyright owner as "Not a Contribution."
-  
-  "Contributor" shall mean Licensor and any individual or Legal Entity
-  on behalf of whom a Contribution has been received by Licensor and
-  subsequently incorporated within the Work.
-  
-  2. Grant of Copyright License. Subject to the terms and conditions of
-  this License, each Contributor hereby grants to You a perpetual,
-  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-  copyright license to reproduce, prepare Derivative Works of,
-  publicly display, publicly perform, sublicense, and distribute the
-  Work and such Derivative Works in Source or Object form.
-  
-  3. Grant of Patent License. Subject to the terms and conditions of
-  this License, each Contributor hereby grants to You a perpetual,
-  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-  (except as stated in this section) patent license to make, have made,
-  use, offer to sell, sell, import, and otherwise transfer the Work,
-  where such license applies only to those patent claims licensable
-  by such Contributor that are necessarily infringed by their
-  Contribution(s) alone or by combination of their Contribution(s)
-  with the Work to which such Contribution(s) was submitted. If You
-  institute patent litigation against any entity (including a
-  cross-claim or counterclaim in a lawsuit) alleging that the Work
-  or a Contribution incorporated within the Work constitutes direct
-  or contributory patent infringement, then any patent licenses
-  granted to You under this License for that Work shall terminate
-  as of the date such litigation is filed.
-  
-  4. Redistribution. You may reproduce and distribute copies of the
-  Work or Derivative Works thereof in any medium, with or without
-  modifications, and in Source or Object form, provided that You
-  meet the following conditions:
-  
-  (a) You must give any other recipients of the Work or
-  Derivative Works a copy of this License; and
-  
-  (b) You must cause any modified files to carry prominent notices
-  stating that You changed the files; and
-  
-  (c) You must retain, in the Source form of any Derivative Works
-  that You distribute, all copyright, patent, trademark, and
-  attribution notices from the Source form of the Work,
-  excluding those notices that do not pertain to any part of
-  the Derivative Works; and
-  
-  (d) If the Work includes a "NOTICE" text file as part of its
-  distribution, then any Derivative Works that You distribute must
-  include a readable copy of the attribution notices contained
-  within such NOTICE file, excluding those notices that do not
-  pertain to any part of the Derivative Works, in at least one
-  of the following places: within a NOTICE text file distributed
-  as part of the Derivative Works; within the Source form or
-  documentation, if provided along with the Derivative Works; or,
-  within a display generated by the Derivative Works, if and
-  wherever such third-party notices normally appear. The contents
-  of the NOTICE file are for informational purposes only and
-  do not modify the License. You may add Your own attribution
-  notices within Derivative Works that You distribute, alongside
-  or as an addendum to the NOTICE text from the Work, provided
-  that such additional attribution notices cannot be construed
-  as modifying the License.
-  
-  You may add Your own copyright statement to Your modifications and
-  may provide additional or different license terms and conditions
-  for use, reproduction, or distribution of Your modifications, or
-  for any such Derivative Works as a whole, provided Your use,
-  reproduction, and distribution of the Work otherwise complies with
-  the conditions stated in this License.
-  
-  5. Submission of Contributions. Unless You explicitly state otherwise,
-  any Contribution intentionally submitted for inclusion in the Work
-  by You to the Licensor shall be under the terms and conditions of
-  this License, without any additional terms or conditions.
-  Notwithstanding the above, nothing herein shall supersede or modify
-  the terms of any separate license agreement you may have executed
-  with Licensor regarding such Contributions.
-  
-  6. Trademarks. This License does not grant permission to use the trade
-  names, trademarks, service marks, or product names of the Licensor,
-  except as required for reasonable and customary use in describing the
-  origin of the Work and reproducing the content of the NOTICE file.
-  
-  7. Disclaimer of Warranty. Unless required by applicable law or
-  agreed to in writing, Licensor provides the Work (and each
-  Contributor provides its Contributions) on an "AS IS" BASIS,
-  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-  implied, including, without limitation, any warranties or conditions
-  of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-  PARTICULAR PURPOSE. You are solely responsible for determining the
-  appropriateness of using or redistributing the Work and assume any
-  risks associated with Your exercise of permissions under this License.
-  
-  8. Limitation of Liability. In no event and under no legal theory,
-  whether in tort (including negligence), contract, or otherwise,
-  unless required by applicable law (such as deliberate and grossly
-  negligent acts) or agreed to in writing, shall any Contributor be
-  liable to You for damages, including any direct, indirect, special,
-  incidental, or consequential damages of any character arising as a
-  result of this License or out of the use or inability to use the
-  Work (including but not limited to damages for loss of goodwill,
-  work stoppage, computer failure or malfunction, or any and all
-  other commercial damages or losses), even if such Contributor
-  has been advised of the possibility of such damages.
-  
-  9. Accepting Warranty or Additional Liability. While redistributing
-  the Work or Derivative Works thereof, You may choose to offer,
-  and charge a fee for, acceptance of support, warranty, indemnity,
-  or other liability obligations and/or rights consistent with this
-  License. However, in accepting such obligations, You may act only
-  on Your own behalf and on Your sole responsibility, not on behalf
-  of any other Contributor, and only if You agree to indemnify,
-  defend, and hold each Contributor harmless for any liability
-  incurred by, or claims asserted against, such Contributor by reason
-  of your accepting any such warranty or additional liability.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/binary/BSD-2-Clause
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/binary/BSD-2-Clause b/usage/dist/licensing/licenses/binary/BSD-2-Clause
deleted file mode 100644
index 832c10e..0000000
--- a/usage/dist/licensing/licenses/binary/BSD-2-Clause
+++ /dev/null
@@ -1,23 +0,0 @@
-The BSD 2-Clause License
-
-  Redistribution and use in source and binary forms, with or without
-  modification, are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, this
-  list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice,
-  this list of conditions and the following disclaimer in the documentation
-  and/or other materials provided with the distribution.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
-  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
-  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
-  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
-  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
-  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
-  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
-  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/binary/BSD-3-Clause
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/binary/BSD-3-Clause b/usage/dist/licensing/licenses/binary/BSD-3-Clause
deleted file mode 100644
index be2692c..0000000
--- a/usage/dist/licensing/licenses/binary/BSD-3-Clause
+++ /dev/null
@@ -1,27 +0,0 @@
-The BSD 3-Clause License ("New BSD")
-
-  Redistribution and use in source and binary forms, with or without modification,
-  are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, 
-  this list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice, 
-  this list of conditions and the following disclaimer in the documentation 
-  and/or other materials provided with the distribution.
-  
-  3. Neither the name of the copyright holder nor the names of its contributors 
-  may be used to endorse or promote products derived from this software without 
-  specific prior written permission.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
-  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
-  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
-  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
-  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
-  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
-  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
-  POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/binary/CDDL1
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/binary/CDDL1 b/usage/dist/licensing/licenses/binary/CDDL1
deleted file mode 100644
index 611d916..0000000
--- a/usage/dist/licensing/licenses/binary/CDDL1
+++ /dev/null
@@ -1,381 +0,0 @@
-COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.0
-
-  1. Definitions.
-  
-  1.1. "Contributor" means each individual or entity that
-  creates or contributes to the creation of Modifications.
-  
-  1.2. "Contributor Version" means the combination of the
-  Original Software, prior Modifications used by a
-  Contributor (if any), and the Modifications made by that
-  particular Contributor.
-  
-  1.3. "Covered Software" means (a) the Original Software, or
-  (b) Modifications, or (c) the combination of files
-  containing Original Software with files containing
-  Modifications, in each case including portions thereof.
-  
-  1.4. "Executable" means the Covered Software in any form
-  other than Source Code. 
-  
-  1.5. "Initial Developer" means the individual or entity
-  that first makes Original Software available under this
-  License. 
-  
-  1.6. "Larger Work" means a work which combines Covered
-  Software or portions thereof with code not governed by the
-  terms of this License.
-  
-  1.7. "License" means this document.
-  
-  1.8. "Licensable" means having the right to grant, to the
-  maximum extent possible, whether at the time of the initial
-  grant or subsequently acquired, any and all of the rights
-  conveyed herein.
-  
-  1.9. "Modifications" means the Source Code and Executable
-  form of any of the following: 
-  
-  A. Any file that results from an addition to,
-  deletion from or modification of the contents of a
-  file containing Original Software or previous
-  Modifications; 
-  
-  B. Any new file that contains any part of the
-  Original Software or previous Modification; or 
-  
-  C. Any new file that is contributed or otherwise made
-  available under the terms of this License.
-  
-  1.10. "Original Software" means the Source Code and
-  Executable form of computer software code that is
-  originally released under this License. 
-  
-  1.11. "Patent Claims" means any patent claim(s), now owned
-  or hereafter acquired, including without limitation,
-  method, process, and apparatus claims, in any patent
-  Licensable by grantor. 
-  
-  1.12. "Source Code" means (a) the common form of computer
-  software code in which modifications are made and (b)
-  associated documentation included in or with such code.
-  
-  1.13. "You" (or "Your") means an individual or a legal
-  entity exercising rights under, and complying with all of
-  the terms of, this License. For legal entities, "You"
-  includes any entity which controls, is controlled by, or is
-  under common control with You. For purposes of this
-  definition, "control" means (a) the power, direct or
-  indirect, to cause the direction or management of such
-  entity, whether by contract or otherwise, or (b) ownership
-  of more than fifty percent (50%) of the outstanding shares
-  or beneficial ownership of such entity.
-  
-  2. License Grants. 
-  
-  2.1. The Initial Developer Grant.
-  
-  Conditioned upon Your compliance with Section 3.1 below and
-  subject to third party intellectual property claims, the
-  Initial Developer hereby grants You a world-wide,
-  royalty-free, non-exclusive license: 
-  
-  (a) under intellectual property rights (other than
-  patent or trademark) Licensable by Initial Developer,
-  to use, reproduce, modify, display, perform,
-  sublicense and distribute the Original Software (or
-  portions thereof), with or without Modifications,
-  and/or as part of a Larger Work; and 
-  
-  (b) under Patent Claims infringed by the making,
-  using or selling of Original Software, to make, have
-  made, use, practice, sell, and offer for sale, and/or
-  otherwise dispose of the Original Software (or
-  portions thereof). 
-  
-  (c) The licenses granted in Sections 2.1(a) and (b)
-  are effective on the date Initial Developer first
-  distributes or otherwise makes the Original Software
-  available to a third party under the terms of this
-  License. 
-  
-  (d) Notwithstanding Section 2.1(b) above, no patent
-  license is granted: (1) for code that You delete from
-  the Original Software, or (2) for infringements
-  caused by: (i) the modification of the Original
-  Software, or (ii) the combination of the Original
-  Software with other software or devices. 
-  
-  2.2. Contributor Grant.
-  
-  Conditioned upon Your compliance with Section 3.1 below and
-  subject to third party intellectual property claims, each
-  Contributor hereby grants You a world-wide, royalty-free,
-  non-exclusive license:
-  
-  (a) under intellectual property rights (other than
-  patent or trademark) Licensable by Contributor to
-  use, reproduce, modify, display, perform, sublicense
-  and distribute the Modifications created by such
-  Contributor (or portions thereof), either on an
-  unmodified basis, with other Modifications, as
-  Covered Software and/or as part of a Larger Work; and
-  
-  (b) under Patent Claims infringed by the making,
-  using, or selling of Modifications made by that
-  Contributor either alone and/or in combination with
-  its Contributor Version (or portions of such
-  combination), to make, use, sell, offer for sale,
-  have made, and/or otherwise dispose of: (1)
-  Modifications made by that Contributor (or portions
-  thereof); and (2) the combination of Modifications
-  made by that Contributor with its Contributor Version
-  (or portions of such combination). 
-  
-  (c) The licenses granted in Sections 2.2(a) and
-  2.2(b) are effective on the date Contributor first
-  distributes or otherwise makes the Modifications
-  available to a third party. 
-  
-  (d) Notwithstanding Section 2.2(b) above, no patent
-  license is granted: (1) for any code that Contributor
-  has deleted from the Contributor Version; (2) for
-  infringements caused by: (i) third party
-  modifications of Contributor Version, or (ii) the
-  combination of Modifications made by that Contributor
-  with other software (except as part of the
-  Contributor Version) or other devices; or (3) under
-  Patent Claims infringed by Covered Software in the
-  absence of Modifications made by that Contributor. 
-  
-  3. Distribution Obligations.
-  
-  3.1. Availability of Source Code.
-  
-  Any Covered Software that You distribute or otherwise make
-  available in Executable form must also be made available in
-  Source Code form and that Source Code form must be
-  distributed only under the terms of this License. You must
-  include a copy of this License with every copy of the
-  Source Code form of the Covered Software You distribute or
-  otherwise make available. You must inform recipients of any
-  such Covered Software in Executable form as to how they can
-  obtain such Covered Software in Source Code form in a
-  reasonable manner on or through a medium customarily used
-  for software exchange.
-  
-  3.2. Modifications.
-  
-  The Modifications that You create or to which You
-  contribute are governed by the terms of this License. You
-  represent that You believe Your Modifications are Your
-  original creation(s) and/or You have sufficient rights to
-  grant the rights conveyed by this License.
-  
-  3.3. Required Notices.
-  
-  You must include a notice in each of Your Modifications
-  that identifies You as the Contributor of the Modification.
-  You may not remove or alter any copyright, patent or
-  trademark notices contained within the Covered Software, or
-  any notices of licensing or any descriptive text giving
-  attribution to any Contributor or the Initial Developer.
-  
-  3.4. Application of Additional Terms.
-  
-  You may not offer or impose any terms on any Covered
-  Software in Source Code form that alters or restricts the
-  applicable version of this License or the recipients"
-  rights hereunder. You may choose to offer, and to charge a
-  fee for, warranty, support, indemnity or liability
-  obligations to one or more recipients of Covered Software.
-  However, you may do so only on Your own behalf, and not on
-  behalf of the Initial Developer or any Contributor. You
-  must make it absolutely clear that any such warranty,
-  support, indemnity or liability obligation is offered by
-  You alone, and You hereby agree to indemnify the Initial
-  Developer and every Contributor for any liability incurred
-  by the Initial Developer or such Contributor as a result of
-  warranty, support, indemnity or liability terms You offer.
-      
-  3.5. Distribution of Executable Versions.
-  
-  You may distribute the Executable form of the Covered
-  Software under the terms of this License or under the terms
-  of a license of Your choice, which may contain terms
-  different from this License, provided that You are in
-  compliance with the terms of this License and that the
-  license for the Executable form does not attempt to limit
-  or alter the recipient"s rights in the Source Code form
-  from the rights set forth in this License. If You
-  distribute the Covered Software in Executable form under a
-  different license, You must make it absolutely clear that
-  any terms which differ from this License are offered by You
-  alone, not by the Initial Developer or Contributor. You
-  hereby agree to indemnify the Initial Developer and every
-  Contributor for any liability incurred by the Initial
-  Developer or such Contributor as a result of any such terms
-  You offer.
-  
-  3.6. Larger Works.
-  
-  You may create a Larger Work by combining Covered Software
-  with other code not governed by the terms of this License
-  and distribute the Larger Work as a single product. In such
-  a case, You must make sure the requirements of this License
-  are fulfilled for the Covered Software. 
-  
-  4. Versions of the License. 
-  
-  4.1. New Versions.
-  
-  Sun Microsystems, Inc. is the initial license steward and
-  may publish revised and/or new versions of this License
-  from time to time. Each version will be given a
-  distinguishing version number. Except as provided in
-  Section 4.3, no one other than the license steward has the
-  right to modify this License. 
-  
-  4.2. Effect of New Versions.
-  
-  You may always continue to use, distribute or otherwise
-  make the Covered Software available under the terms of the
-  version of the License under which You originally received
-  the Covered Software. If the Initial Developer includes a
-  notice in the Original Software prohibiting it from being
-  distributed or otherwise made available under any
-  subsequent version of the License, You must distribute and
-  make the Covered Software available under the terms of the
-  version of the License under which You originally received
-  the Covered Software. Otherwise, You may also choose to
-  use, distribute or otherwise make the Covered Software
-  available under the terms of any subsequent version of the
-  License published by the license steward. 
-  
-  4.3. Modified Versions.
-  
-  When You are an Initial Developer and You want to create a
-  new license for Your Original Software, You may create and
-  use a modified version of this License if You: (a) rename
-  the license and remove any references to the name of the
-  license steward (except to note that the license differs
-  from this License); and (b) otherwise make it clear that
-  the license contains terms which differ from this License.
-  
-  5. DISCLAIMER OF WARRANTY.
-  
-  COVERED SOFTWARE IS PROVIDED UNDER THIS LICENSE ON AN "AS IS"
-  BASIS, WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED,
-  INCLUDING, WITHOUT LIMITATION, WARRANTIES THAT THE COVERED
-  SOFTWARE IS FREE OF DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR
-  PURPOSE OR NON-INFRINGING. THE ENTIRE RISK AS TO THE QUALITY AND
-  PERFORMANCE OF THE COVERED SOFTWARE IS WITH YOU. SHOULD ANY
-  COVERED SOFTWARE PROVE DEFECTIVE IN ANY RESPECT, YOU (NOT THE
-  INITIAL DEVELOPER OR ANY OTHER CONTRIBUTOR) ASSUME THE COST OF
-  ANY NECESSARY SERVICING, REPAIR OR CORRECTION. THIS DISCLAIMER OF
-  WARRANTY CONSTITUTES AN ESSENTIAL PART OF THIS LICENSE. NO USE OF
-  ANY COVERED SOFTWARE IS AUTHORIZED HEREUNDER EXCEPT UNDER THIS
-  DISCLAIMER. 
-  
-  6. TERMINATION. 
-  
-  6.1. This License and the rights granted hereunder will
-  terminate automatically if You fail to comply with terms
-  herein and fail to cure such breach within 30 days of
-  becoming aware of the breach. Provisions which, by their
-  nature, must remain in effect beyond the termination of
-  this License shall survive.
-  
-  6.2. If You assert a patent infringement claim (excluding
-  declaratory judgment actions) against Initial Developer or
-  a Contributor (the Initial Developer or Contributor against
-  whom You assert such claim is referred to as "Participant")
-  alleging that the Participant Software (meaning the
-  Contributor Version where the Participant is a Contributor
-  or the Original Software where the Participant is the
-  Initial Developer) directly or indirectly infringes any
-  patent, then any and all rights granted directly or
-  indirectly to You by such Participant, the Initial
-  Developer (if the Initial Developer is not the Participant)
-  and all Contributors under Sections 2.1 and/or 2.2 of this
-  License shall, upon 60 days notice from Participant
-  terminate prospectively and automatically at the expiration
-  of such 60 day notice period, unless if within such 60 day
-  period You withdraw Your claim with respect to the
-  Participant Software against such Participant either
-  unilaterally or pursuant to a written agreement with
-  Participant.
-  
-  6.3. In the event of termination under Sections 6.1 or 6.2
-  above, all end user licenses that have been validly granted
-  by You or any distributor hereunder prior to termination
-  (excluding licenses granted to You by any distributor)
-  shall survive termination.
-  
-  7. LIMITATION OF LIABILITY.
-  
-  UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT
-  (INCLUDING NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE
-  INITIAL DEVELOPER, ANY OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF
-  COVERED SOFTWARE, OR ANY SUPPLIER OF ANY OF SUCH PARTIES, BE
-  LIABLE TO ANY PERSON FOR ANY INDIRECT, SPECIAL, INCIDENTAL, OR
-  CONSEQUENTIAL DAMAGES OF ANY CHARACTER INCLUDING, WITHOUT
-  LIMITATION, DAMAGES FOR LOST PROFITS, LOSS OF GOODWILL, WORK
-  STOPPAGE, COMPUTER FAILURE OR MALFUNCTION, OR ANY AND ALL OTHER
-  COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH PARTY SHALL HAVE BEEN
-  INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS LIMITATION OF
-  LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL
-  INJURY RESULTING FROM SUCH PARTY"S NEGLIGENCE TO THE EXTENT
-  APPLICABLE LAW PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO
-  NOT ALLOW THE EXCLUSION OR LIMITATION OF INCIDENTAL OR
-  CONSEQUENTIAL DAMAGES, SO THIS EXCLUSION AND LIMITATION MAY NOT
-  APPLY TO YOU.
-  
-  8. U.S. GOVERNMENT END USERS.
-  
-  The Covered Software is a "commercial item," as that term is
-  defined in 48 C.F.R. 2.101 (Oct. 1995), consisting of "commercial
-  computer software" (as that term is defined at 48 C.F.R. "
-  252.227-7014(a)(1)) and "commercial computer software
-  documentation" as such terms are used in 48 C.F.R. 12.212 (Sept.
-  1995). Consistent with 48 C.F.R. 12.212 and 48 C.F.R. 227.7202-1
-  through 227.7202-4 (June 1995), all U.S. Government End Users
-  acquire Covered Software with only those rights set forth herein.
-  This U.S. Government Rights clause is in lieu of, and supersedes,
-  any other FAR, DFAR, or other clause or provision that addresses
-  Government rights in computer software under this License.
-  
-  9. MISCELLANEOUS.
-  
-  This License represents the complete agreement concerning subject
-  matter hereof. If any provision of this License is held to be
-  unenforceable, such provision shall be reformed only to the
-  extent necessary to make it enforceable. This License shall be
-  governed by the law of the jurisdiction specified in a notice
-  contained within the Original Software (except to the extent
-  applicable law, if any, provides otherwise), excluding such
-  jurisdiction"s conflict-of-law provisions. Any litigation
-  relating to this License shall be subject to the jurisdiction of
-  the courts located in the jurisdiction and venue specified in a
-  notice contained within the Original Software, with the losing
-  party responsible for costs, including, without limitation, court
-  costs and reasonable attorneys" fees and expenses. The
-  application of the United Nations Convention on Contracts for the
-  International Sale of Goods is expressly excluded. Any law or
-  regulation which provides that the language of a contract shall
-  be construed against the drafter shall not apply to this License.
-  You agree that You alone are responsible for compliance with the
-  United States export administration regulations (and the export
-  control laws and regulation of any other countries) when You use,
-  distribute or otherwise make available any Covered Software.
-  
-  10. RESPONSIBILITY FOR CLAIMS.
-  
-  As between Initial Developer and the Contributors, each party is
-  responsible for claims and damages arising, directly or
-  indirectly, out of its utilization of rights under this License
-  and You agree to work with Initial Developer and Contributors to
-  distribute such responsibility on an equitable basis. Nothing
-  herein is intended or shall be deemed to constitute any admission
-  of liability.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/binary/CDDL1.1
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/binary/CDDL1.1 b/usage/dist/licensing/licenses/binary/CDDL1.1
deleted file mode 100644
index def9b35..0000000
--- a/usage/dist/licensing/licenses/binary/CDDL1.1
+++ /dev/null
@@ -1,304 +0,0 @@
-COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.1
-
-  1. Definitions.
-  
-  1.1. “Contributor” means each individual or entity that creates or contributes
-  to the creation of Modifications.
-  
-  1.2. “Contributor Version” means the combination of the Original Software,
-  prior Modifications used by a Contributor (if any), and the Modifications made
-  by that particular Contributor.
-  
-  1.3. “Covered Software” means (a) the Original Software, or (b) Modifications,
-  or (c) the combination of files containing Original Software with files
-  containing Modifications, in each case including portions thereof.
-  
-  1.4. “Executable” means the Covered Software in any form other than Source
-  Code.
-  
-  1.5. “Initial Developer” means the individual or entity that first makes
-  Original Software available under this License.
-  
-  1.6. “Larger Work” means a work which combines Covered Software or portions
-  thereof with code not governed by the terms of this License.
-  
-  1.7. “License” means this document.
-  
-  1.8. “Licensable” means having the right to grant, to the maximum extent
-  possible, whether at the time of the initial grant or subsequently acquired,
-  any and all of the rights conveyed herein.
-  
-  1.9. “Modifications” means the Source Code and Executable form of any of the
-  following:
-  
-  A. Any file that results from an addition to, deletion from or modification of
-  the contents of a file containing Original Software or previous Modifications;
-  
-  B. Any new file that contains any part of the Original Software or previous
-  Modification; or
-  
-  C. Any new file that is contributed or otherwise made available under the terms
-  of this License.
-  
-  1.10. “Original Software” means the Source Code and Executable form of computer
-  software code that is originally released under this License.
-  
-  1.11. “Patent Claims” means any patent claim(s), now owned or hereafter
-  acquired, including without limitation, method, process, and apparatus claims,
-  in any patent Licensable by grantor.
-  
-  1.12. “Source Code” means (a) the common form of computer software code in
-  which modifications are made and (b) associated documentation included in or
-  with such code.
-  
-  1.13. “You” (or “Your”) means an individual or a legal entity exercising rights
-  under, and complying with all of the terms of, this License. For legal
-  entities, “You” includes any entity which controls, is controlled by, or is
-  under common control with You. For purposes of this definition, “control” means
-  (a) the power, direct or indirect, to cause the direction or management of such
-  entity, whether by contract or otherwise, or (b) ownership of more than fifty
-  percent (50%) of the outstanding shares or beneficial ownership of such entity.
-  
-  2. License Grants.
-  
-  2.1. The Initial Developer Grant.  Conditioned upon Your compliance with
-  Section 3.1 below and subject to third party intellectual property claims, the
-  Initial Developer hereby grants You a world-wide, royalty-free, non-exclusive
-  license:
-  
-  (a) under intellectual property rights (other than patent or trademark)
-  Licensable by Initial Developer, to use, reproduce, modify, display, perform,
-  sublicense and distribute the Original Software (or portions thereof), with or
-  without Modifications, and/or as part of a Larger Work; and
-  
-  (b) under Patent Claims infringed by the making, using or selling of Original
-  Software, to make, have made, use, practice, sell, and offer for sale, and/or
-  otherwise dispose of the Original Software (or portions thereof).
-  
-  (c) The licenses granted in Sections 2.1(a) and (b) are effective on the date
-  Initial Developer first distributes or otherwise makes the Original Software
-  available to a third party under the terms of this License.
-  
-  (d) Notwithstanding Section 2.1(b) above, no patent license is granted: (1) for
-  code that You delete from the Original Software, or (2) for infringements
-  caused by: (i) the modification of the Original Software, or (ii) the
-  combination of the Original Software with other software or devices.
-  
-  2.2. Contributor Grant.  Conditioned upon Your compliance with Section 3.1
-  below and subject to third party intellectual property claims, each Contributor
-  hereby grants You a world-wide, royalty-free, non-exclusive license:
-  
-  (a) under intellectual property rights (other than patent or trademark)
-  Licensable by Contributor to use, reproduce, modify, display, perform,
-  sublicense and distribute the Modifications created by such Contributor (or
-  portions thereof), either on an unmodified basis, with other Modifications, as
-  Covered Software and/or as part of a Larger Work; and
-  
-  (b) under Patent Claims infringed by the making, using, or selling of
-  Modifications made by that Contributor either alone and/or in combination with
-  its Contributor Version (or portions of such combination), to make, use, sell,
-  offer for sale, have made, and/or otherwise dispose of: (1) Modifications made
-  by that Contributor (or portions thereof); and (2) the combination of
-  Modifications made by that Contributor with its Contributor Version (or
-  portions of such combination).
-  
-  (c) The licenses granted in Sections 2.2(a) and 2.2(b) are effective on the
-  date Contributor first distributes or otherwise makes the Modifications
-  available to a third party.
-  
-  (d) Notwithstanding Section 2.2(b) above, no patent license is granted: (1) for
-  any code that Contributor has deleted from the Contributor Version; (2) for
-  infringements caused by: (i) third party modifications of Contributor Version,
-  or (ii) the combination of Modifications made by that Contributor with other
-  software (except as part of the Contributor Version) or other devices; or (3)
-  under Patent Claims infringed by Covered Software in the absence of
-  Modifications made by that Contributor.
-  
-  3. Distribution Obligations.
-  
-  3.1. Availability of Source Code.  Any Covered Software that You distribute or
-  otherwise make available in Executable form must also be made available in
-  Source Code form and that Source Code form must be distributed only under the
-  terms of this License. You must include a copy of this License with every copy
-  of the Source Code form of the Covered Software You distribute or otherwise
-  make available. You must inform recipients of any such Covered Software in
-  Executable form as to how they can obtain such Covered Software in Source Code
-  form in a reasonable manner on or through a medium customarily used for
-  software exchange.
-  
-  3.2. Modifications.  The Modifications that You create or to which You
-  contribute are governed by the terms of this License. You represent that You
-  believe Your Modifications are Your original creation(s) and/or You have
-  sufficient rights to grant the rights conveyed by this License.
-  
-  3.3. Required Notices.  You must include a notice in each of Your Modifications
-  that identifies You as the Contributor of the Modification. You may not remove
-  or alter any copyright, patent or trademark notices contained within the
-  Covered Software, or any notices of licensing or any descriptive text giving
-  attribution to any Contributor or the Initial Developer.
-  
-  3.4. Application of Additional Terms.  You may not offer or impose any terms on
-  any Covered Software in Source Code form that alters or restricts the
-  applicable version of this License or the recipients' rights hereunder. You may
-  choose to offer, and to charge a fee for, warranty, support, indemnity or
-  liability obligations to one or more recipients of Covered Software. However,
-  you may do so only on Your own behalf, and not on behalf of the Initial
-  Developer or any Contributor. You must make it absolutely clear that any such
-  warranty, support, indemnity or liability obligation is offered by You alone,
-  and You hereby agree to indemnify the Initial Developer and every Contributor
-  for any liability incurred by the Initial Developer or such Contributor as a
-  result of warranty, support, indemnity or liability terms You offer.
-  
-  3.5. Distribution of Executable Versions.  You may distribute the Executable
-  form of the Covered Software under the terms of this License or under the terms
-  of a license of Your choice, which may contain terms different from this
-  License, provided that You are in compliance with the terms of this License and
-  that the license for the Executable form does not attempt to limit or alter the
-  recipient's rights in the Source Code form from the rights set forth in this
-  License. If You distribute the Covered Software in Executable form under a
-  different license, You must make it absolutely clear that any terms which
-  differ from this License are offered by You alone, not by the Initial Developer
-  or Contributor. You hereby agree to indemnify the Initial Developer and every
-  Contributor for any liability incurred by the Initial Developer or such
-  Contributor as a result of any such terms You offer.
-  
-  3.6. Larger Works.  You may create a Larger Work by combining Covered Software
-  with other code not governed by the terms of this License and distribute the
-  Larger Work as a single product. In such a case, You must make sure the
-  requirements of this License are fulfilled for the Covered Software.
-  
-  4. Versions of the License.
-  
-  4.1. New Versions.  Oracle is the initial license steward and may publish
-  revised and/or new versions of this License from time to time. Each version
-  will be given a distinguishing version number. Except as provided in Section
-  4.3, no one other than the license steward has the right to modify this
-  License.
-  
-  4.2. Effect of New Versions.  You may always continue to use, distribute or
-  otherwise make the Covered Software available under the terms of the version of
-  the License under which You originally received the Covered Software. If the
-  Initial Developer includes a notice in the Original Software prohibiting it
-  from being distributed or otherwise made available under any subsequent version
-  of the License, You must distribute and make the Covered Software available
-  under the terms of the version of the License under which You originally
-  received the Covered Software. Otherwise, You may also choose to use,
-  distribute or otherwise make the Covered Software available under the terms of
-  any subsequent version of the License published by the license steward.
-  
-  4.3. Modified Versions.  When You are an Initial Developer and You want to
-  create a new license for Your Original Software, You may create and use a
-  modified version of this License if You: (a) rename the license and remove any
-  references to the name of the license steward (except to note that the license
-  differs from this License); and (b) otherwise make it clear that the license
-  contains terms which differ from this License.
-  
-  5. DISCLAIMER OF WARRANTY.  COVERED SOFTWARE IS PROVIDED UNDER THIS LICENSE ON
-  AN “AS IS” BASIS, WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED,
-  INCLUDING, WITHOUT LIMITATION, WARRANTIES THAT THE COVERED SOFTWARE IS FREE OF
-  DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR PURPOSE OR NON-INFRINGING. THE
-  ENTIRE RISK AS TO THE QUALITY AND PERFORMANCE OF THE COVERED SOFTWARE IS WITH
-  YOU. SHOULD ANY COVERED SOFTWARE PROVE DEFECTIVE IN ANY RESPECT, YOU (NOT THE
-  INITIAL DEVELOPER OR ANY OTHER CONTRIBUTOR) ASSUME THE COST OF ANY NECESSARY
-  SERVICING, REPAIR OR CORRECTION. THIS DISCLAIMER OF WARRANTY CONSTITUTES AN
-  ESSENTIAL PART OF THIS LICENSE. NO USE OF ANY COVERED SOFTWARE IS AUTHORIZED
-  HEREUNDER EXCEPT UNDER THIS DISCLAIMER.
-  
-  6. TERMINATION.
-  
-  6.1. This License and the rights granted hereunder will terminate automatically
-  if You fail to comply with terms herein and fail to cure such breach within 30
-  days of becoming aware of the breach. Provisions which, by their nature, must
-  remain in effect beyond the termination of this License shall survive.
-  
-  6.2. If You assert a patent infringement claim (excluding declaratory judgment
-  actions) against Initial Developer or a Contributor (the Initial Developer or
-  Contributor against whom You assert such claim is referred to as “Participant”)
-  alleging that the Participant Software (meaning the Contributor Version where
-  the Participant is a Contributor or the Original Software where the Participant
-  is the Initial Developer) directly or indirectly infringes any patent, then any
-  and all rights granted directly or indirectly to You by such Participant, the
-  Initial Developer (if the Initial Developer is not the Participant) and all
-  Contributors under Sections 2.1 and/or 2.2 of this License shall, upon 60 days
-  notice from Participant terminate prospectively and automatically at the
-  expiration of such 60 day notice period, unless if within such 60 day period
-  You withdraw Your claim with respect to the Participant Software against such
-  Participant either unilaterally or pursuant to a written agreement with
-  Participant.
-  
-  6.3. If You assert a patent infringement claim against Participant alleging
-  that the Participant Software directly or indirectly infringes any patent where
-  such claim is resolved (such as by license or settlement) prior to the
-  initiation of patent infringement litigation, then the reasonable value of the
-  licenses granted by such Participant under Sections 2.1 or 2.2 shall be taken
-  into account in determining the amount or value of any payment or license.
-  
-  6.4. In the event of termination under Sections 6.1 or 6.2 above, all end user
-  licenses that have been validly granted by You or any distributor hereunder
-  prior to termination (excluding licenses granted to You by any distributor)
-  shall survive termination.
-  
-  7. LIMITATION OF LIABILITY.
-  
-  UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT (INCLUDING
-  NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE INITIAL DEVELOPER, ANY
-  OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF COVERED SOFTWARE, OR ANY SUPPLIER OF
-  ANY OF SUCH PARTIES, BE LIABLE TO ANY PERSON FOR ANY INDIRECT, SPECIAL,
-  INCIDENTAL, OR CONSEQUENTIAL DAMAGES OF ANY CHARACTER INCLUDING, WITHOUT
-  LIMITATION, DAMAGES FOR LOSS OF GOODWILL, WORK STOPPAGE, COMPUTER FAILURE OR
-  MALFUNCTION, OR ANY AND ALL OTHER COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH
-  PARTY SHALL HAVE BEEN INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS
-  LIMITATION OF LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL
-  INJURY RESULTING FROM SUCH PARTY'S NEGLIGENCE TO THE EXTENT APPLICABLE LAW
-  PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO NOT ALLOW THE EXCLUSION OR
-  LIMITATION OF INCIDENTAL OR CONSEQUENTIAL DAMAGES, SO THIS EXCLUSION AND
-  LIMITATION MAY NOT APPLY TO YOU.
-  
-  8. U.S. GOVERNMENT END USERS.
-  
-  The Covered Software is a “commercial item,” as that term is defined in 48
-  C.F.R. 2.101 (Oct. 1995), consisting of “commercial computer software” (as that
-  term is defined at 48 C.F.R. § 252.227-7014(a)(1)) and “commercial computer
-  software documentation” as such terms are used in 48 C.F.R. 12.212 (Sept.
-  1995). Consistent with 48 C.F.R. 12.212 and 48 C.F.R. 227.7202-1 through
-  227.7202-4 (June 1995), all U.S. Government End Users acquire Covered Software
-  with only those rights set forth herein. This U.S. Government Rights clause is
-  in lieu of, and supersedes, any other FAR, DFAR, or other clause or provision
-  that addresses Government rights in computer software under this License.
-  
-  9. MISCELLANEOUS.
-  
-  This License represents the complete agreement concerning subject matter
-  hereof. If any provision of this License is held to be unenforceable, such
-  provision shall be reformed only to the extent necessary to make it
-  enforceable. This License shall be governed by the law of the jurisdiction
-  specified in a notice contained within the Original Software (except to the
-  extent applicable law, if any, provides otherwise), excluding such
-  jurisdiction's conflict-of-law provisions. Any litigation relating to this
-  License shall be subject to the jurisdiction of the courts located in the
-  jurisdiction and venue specified in a notice contained within the Original
-  Software, with the losing party responsible for costs, including, without
-  limitation, court costs and reasonable attorneys' fees and expenses. The
-  application of the United Nations Convention on Contracts for the International
-  Sale of Goods is expressly excluded. Any law or regulation which provides that
-  the language of a contract shall be construed against the drafter shall not
-  apply to this License. You agree that You alone are responsible for compliance
-  with the United States export administration regulations (and the export
-  control laws and regulation of any other countries) when You use, distribute or
-  otherwise make available any Covered Software.
-  
-  10. RESPONSIBILITY FOR CLAIMS.
-  
-  As between Initial Developer and the Contributors, each party is responsible
-  for claims and damages arising, directly or indirectly, out of its utilization
-  of rights under this License and You agree to work with Initial Developer and
-  Contributors to distribute such responsibility on an equitable basis. Nothing
-  herein is intended or shall be deemed to constitute any admission of liability.
-  
-  NOTICE PURSUANT TO SECTION 9 OF THE COMMON DEVELOPMENT AND DISTRIBUTION LICENSE
-  (CDDL) The code released under the CDDL shall be governed by the laws of the
-  State of California (excluding conflict-of-law provisions). Any litigation
-  relating to this License shall be subject to the jurisdiction of the Federal
-  Courts of the Northern District of California and the state courts of the State
-  of California, with venue lying in Santa Clara County, California.
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/binary/EPL1
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/binary/EPL1 b/usage/dist/licensing/licenses/binary/EPL1
deleted file mode 100644
index 6891076..0000000
--- a/usage/dist/licensing/licenses/binary/EPL1
+++ /dev/null
@@ -1,212 +0,0 @@
-Eclipse Public License, version 1.0
-
-  THE ACCOMPANYING PROGRAM IS PROVIDED UNDER THE TERMS OF THIS ECLIPSE PUBLIC
-  LICENSE ("AGREEMENT"). ANY USE, REPRODUCTION OR DISTRIBUTION OF THE PROGRAM
-  CONSTITUTES RECIPIENT'S ACCEPTANCE OF THIS AGREEMENT.
-  
-  1. DEFINITIONS
-  
-  "Contribution" means:
-  
-  a) in the case of the initial Contributor, the initial code and documentation
-  distributed under this Agreement, and b) in the case of each subsequent
-  Contributor:
-  
-  i) changes to the Program, and
-  
-  ii) additions to the Program;
-  
-  where such changes and/or additions to the Program originate from and are
-  distributed by that particular Contributor. A Contribution 'originates' from a
-  Contributor if it was added to the Program by such Contributor itself or anyone
-  acting on such Contributor's behalf. Contributions do not include additions to
-  the Program which: (i) are separate modules of software distributed in
-  conjunction with the Program under their own license agreement, and (ii) are
-  not derivative works of the Program.
-  
-  "Contributor" means any person or entity that distributes the Program.
-  
-  "Licensed Patents " mean patent claims licensable by a Contributor which are
-  necessarily infringed by the use or sale of its Contribution alone or when
-  combined with the Program.
-  
-  "Program" means the Contributions distributed in accordance with this
-  Agreement.
-  
-  "Recipient" means anyone who receives the Program under this Agreement,
-  including all Contributors.
-  
-  2. GRANT OF RIGHTS
-  
-  a) Subject to the terms of this Agreement, each Contributor hereby grants
-  Recipient a non-exclusive, worldwide, royalty-free copyright license to
-  reproduce, prepare derivative works of, publicly display, publicly perform,
-  distribute and sublicense the Contribution of such Contributor, if any, and
-  such derivative works, in source code and object code form.
-  
-  b) Subject to the terms of this Agreement, each Contributor hereby grants
-  Recipient a non-exclusive, worldwide, royalty-free patent license under
-  Licensed Patents to make, use, sell, offer to sell, import and otherwise
-  transfer the Contribution of such Contributor, if any, in source code and
-  object code form. This patent license shall apply to the combination of the
-  Contribution and the Program if, at the time the Contribution is added by the
-  Contributor, such addition of the Contribution causes such combination to be
-  covered by the Licensed Patents. The patent license shall not apply to any
-  other combinations which include the Contribution. No hardware per se is
-  licensed hereunder.
-  
-  c) Recipient understands that although each Contributor grants the licenses to
-  its Contributions set forth herein, no assurances are provided by any
-  Contributor that the Program does not infringe the patent or other intellectual
-  property rights of any other entity. Each Contributor disclaims any liability
-  to Recipient for claims brought by any other entity based on infringement of
-  intellectual property rights or otherwise. As a condition to exercising the
-  rights and licenses granted hereunder, each Recipient hereby assumes sole
-  responsibility to secure any other intellectual property rights needed, if any.
-  For example, if a third party patent license is required to allow Recipient to
-  distribute the Program, it is Recipient's responsibility to acquire that
-  license before distributing the Program.
-  
-  d) Each Contributor represents that to its knowledge it has sufficient
-  copyright rights in its Contribution, if any, to grant the copyright license
-  set forth in this Agreement.
-  
-  3. REQUIREMENTS
-  
-  A Contributor may choose to distribute the Program in object code form under
-  its own license agreement, provided that:
-  
-  a) it complies with the terms and conditions of this Agreement; and
-  
-  b) its license agreement:
-  
-  i) effectively disclaims on behalf of all Contributors all warranties and
-  conditions, express and implied, including warranties or conditions of title
-  and non-infringement, and implied warranties or conditions of merchantability
-  and fitness for a particular purpose;
-  
-  ii) effectively excludes on behalf of all Contributors all liability for
-  damages, including direct, indirect, special, incidental and consequential
-  damages, such as lost profits;
-  
-  iii) states that any provisions which differ from this Agreement are offered by
-  that Contributor alone and not by any other party; and
-  
-  iv) states that source code for the Program is available from such Contributor,
-  and informs licensees how to obtain it in a reasonable manner on or through a
-  medium customarily used for software exchange.
-  
-  When the Program is made available in source code form:
-  
-  a) it must be made available under this Agreement; and
-  
-  b) a copy of this Agreement must be included with each copy of the Program.
-  
-  Contributors may not remove or alter any copyright notices contained within the
-  Program.
-  
-  Each Contributor must identify itself as the originator of its Contribution, if
-  any, in a manner that reasonably allows subsequent Recipients to identify the
-  originator of the Contribution.
-  
-  4. COMMERCIAL DISTRIBUTION
-  
-  Commercial distributors of software may accept certain responsibilities with
-  respect to end users, business partners and the like. While this license is
-  intended to facilitate the commercial use of the Program, the Contributor who
-  includes the Program in a commercial product offering should do so in a manner
-  which does not create potential liability for other Contributors. Therefore, if
-  a Contributor includes the Program in a commercial product offering, such
-  Contributor ("Commercial Contributor") hereby agrees to defend and indemnify
-  every other Contributor ("Indemnified Contributor") against any losses, damages
-  and costs (collectively "Losses") arising from claims, lawsuits and other legal
-  actions brought by a third party against the Indemnified Contributor to the
-  extent caused by the acts or omissions of such Commercial Contributor in
-  connection with its distribution of the Program in a commercial product
-  offering. The obligations in this section do not apply to any claims or Losses
-  relating to any actual or alleged intellectual property infringement. In order
-  to qualify, an Indemnified Contributor must: a) promptly notify the Commercial
-  Contributor in writing of such claim, and b) allow the Commercial Contributor
-  to control, and cooperate with the Commercial Contributor in, the defense and
-  any related settlement negotiations. The Indemnified Contributor may
-  participate in any such claim at its own expense.
-  
-  For example, a Contributor might include the Program in a commercial product
-  offering, Product X. That Contributor is then a Commercial Contributor. If that
-  Commercial Contributor then makes performance claims, or offers warranties
-  related to Product X, those performance claims and warranties are such
-  Commercial Contributor's responsibility alone. Under this section, the
-  Commercial Contributor would have to defend claims against the other
-  Contributors related to those performance claims and warranties, and if a court
-  requires any other Contributor to pay any damages as a result, the Commercial
-  Contributor must pay those damages.
-  
-  5. NO WARRANTY
-  
-  EXCEPT AS EXPRESSLY SET FORTH IN THIS AGREEMENT, THE PROGRAM IS PROVIDED ON AN
-  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, EITHER EXPRESS OR
-  IMPLIED INCLUDING, WITHOUT LIMITATION, ANY WARRANTIES OR CONDITIONS OF TITLE,
-  NON-INFRINGEMENT, MERCHANTABILITY OR FITNESS FOR A PARTICULAR PURPOSE. Each
-  Recipient is solely responsible for determining the appropriateness of using
-  and distributing the Program and assumes all risks associated with its exercise
-  of rights under this Agreement , including but not limited to the risks and
-  costs of program errors, compliance with applicable laws, damage to or loss of
-  data, programs or equipment, and unavailability or interruption of operations.
-  
-  6. DISCLAIMER OF LIABILITY
-  
-  EXCEPT AS EXPRESSLY SET FORTH IN THIS AGREEMENT, NEITHER RECIPIENT NOR ANY
-  CONTRIBUTORS SHALL HAVE ANY LIABILITY FOR ANY DIRECT, INDIRECT, INCIDENTAL,
-  SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING WITHOUT LIMITATION LOST
-  PROFITS), HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT,
-  STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY
-  WAY OUT OF THE USE OR DISTRIBUTION OF THE PROGRAM OR THE EXERCISE OF ANY RIGHTS
-  GRANTED HEREUNDER, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGES.
-  
-  7. GENERAL
-  
-  If any provision of this Agreement is invalid or unenforceable under applicable
-  law, it shall not affect the validity or enforceability of the remainder of the
-  terms of this Agreement, and without further action by the parties hereto, such
-  provision shall be reformed to the minimum extent necessary to make such
-  provision valid and enforceable.
-  
-  If Recipient institutes patent litigation against any entity (including a
-  cross-claim or counterclaim in a lawsuit) alleging that the Program itself
-  (excluding combinations of the Program with other software or hardware)
-  infringes such Recipient's patent(s), then such Recipient's rights granted
-  under Section 2(b) shall terminate as of the date such litigation is filed.
-  
-  All Recipient's rights under this Agreement shall terminate if it fails to
-  comply with any of the material terms or conditions of this Agreement and does
-  not cure such failure in a reasonable period of time after becoming aware of
-  such noncompliance. If all Recipient's rights under this Agreement terminate,
-  Recipient agrees to cease use and distribution of the Program as soon as
-  reasonably practicable. However, Recipient's obligations under this Agreement
-  and any licenses granted by Recipient relating to the Program shall continue
-  and survive.
-  
-  Everyone is permitted to copy and distribute copies of this Agreement, but in
-  order to avoid inconsistency the Agreement is copyrighted and may only be
-  modified in the following manner. The Agreement Steward reserves the right to
-  publish new versions (including revisions) of this Agreement from time to time.
-  No one other than the Agreement Steward has the right to modify this Agreement.
-  The Eclipse Foundation is the initial Agreement Steward. The Eclipse Foundation
-  may assign the responsibility to serve as the Agreement Steward to a suitable
-  separate entity. Each new version of the Agreement will be given a
-  distinguishing version number. The Program (including Contributions) may always
-  be distributed subject to the version of the Agreement under which it was
-  received. In addition, after a new version of the Agreement is published,
-  Contributor may elect to distribute the Program (including its Contributions)
-  under the new version. Except as expressly stated in Sections 2(a) and 2(b)
-  above, Recipient receives no rights or licenses to the intellectual property of
-  any Contributor under this Agreement, whether expressly, by implication,
-  estoppel or otherwise. All rights in the Program not expressly granted under
-  this Agreement are reserved.
-  
-  This Agreement is governed by the laws of the State of New York and the
-  intellectual property laws of the United States of America. No party to this
-  Agreement will bring a legal action under this Agreement more than one year
-  after the cause of action arose. Each party waives its rights to a jury trial
-  in any resulting litigation.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/binary/MIT
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/binary/MIT b/usage/dist/licensing/licenses/binary/MIT
deleted file mode 100644
index 71dfb45..0000000
--- a/usage/dist/licensing/licenses/binary/MIT
+++ /dev/null
@@ -1,20 +0,0 @@
-The MIT License ("MIT")
-
-  Permission is hereby granted, free of charge, to any person obtaining a copy
-  of this software and associated documentation files (the "Software"), to deal
-  in the Software without restriction, including without limitation the rights
-  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
-  copies of the Software, and to permit persons to whom the Software is
-  furnished to do so, subject to the following conditions:
-  
-  The above copyright notice and this permission notice shall be included in
-  all copies or substantial portions of the Software.
-  
-  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
-  THE SOFTWARE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/binary/WTFPL
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/binary/WTFPL b/usage/dist/licensing/licenses/binary/WTFPL
deleted file mode 100644
index 03c1695..0000000
--- a/usage/dist/licensing/licenses/binary/WTFPL
+++ /dev/null
@@ -1,15 +0,0 @@
-WTF Public License
-
-  DO WHAT THE FUCK YOU WANT TO PUBLIC LICENSE, Version 2, December 2004 
- 
-  Copyright (C) 2004 Sam Hocevar <sa...@hocevar.net> 
- 
-  Everyone is permitted to copy and distribute verbatim or modified 
-  copies of this license document, and changing it is allowed as long 
-  as the name is changed. 
- 
-             DO WHAT THE FUCK YOU WANT TO PUBLIC LICENSE 
-    TERMS AND CONDITIONS FOR COPYING, DISTRIBUTION AND MODIFICATION 
- 
-   0. You just DO WHAT THE FUCK YOU WANT TO.
- 

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/binary/bouncycastle
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/binary/bouncycastle b/usage/dist/licensing/licenses/binary/bouncycastle
deleted file mode 100644
index 8589a0b..0000000
--- a/usage/dist/licensing/licenses/binary/bouncycastle
+++ /dev/null
@@ -1,23 +0,0 @@
-Bouncy Castle License
-  
-  Copyright (c) 2000 - 2015 The Legion of the Bouncy Castle Inc.
-  (http://www.bouncycastle.org)
-  
-  Permission is hereby granted, free of charge, to any person obtaining a copy of
-  this software and associated documentation files (the "Software"), to deal in
-  the Software without restriction, including without limitation the rights to
-  use, copy, modify, merge, publish, distribute, sublicense, and/or sell copies
-  of the Software, and to permit persons to whom the Software is furnished to do
-  so, subject to the following conditions:
-  
-  The above copyright notice and this permission notice shall be included in all
-  copies or substantial portions of the Software.
-  
-  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE
-  SOFTWARE.
-  


[37/51] [abbrv] brooklyn-dist git commit: This closes #1144

Posted by he...@apache.org.
This closes #1144


Project: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/repo
Commit: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/commit/71b379cb
Tree: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/tree/71b379cb
Diff: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/diff/71b379cb

Branch: refs/heads/master
Commit: 71b379cb895ca22b5e25dfe8539d4ae92ba51188
Parents: 2e1e1ff 97df1e7
Author: Alex Heneveld <al...@cloudsoftcorp.com>
Authored: Sat Jan 30 02:55:20 2016 +0000
Committer: Alex Heneveld <al...@cloudsoftcorp.com>
Committed: Sat Jan 30 02:55:20 2016 +0000

----------------------------------------------------------------------
 LICENSE | 7 +++++++
 1 file changed, 7 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/71b379cb/LICENSE
----------------------------------------------------------------------


[02/51] [abbrv] brooklyn-dist git commit: [SPLITPREP] rearranged to have structure of new repositories

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/src/main/license/files/LICENSE
----------------------------------------------------------------------
diff --git a/usage/dist/src/main/license/files/LICENSE b/usage/dist/src/main/license/files/LICENSE
deleted file mode 100644
index b280a7d..0000000
--- a/usage/dist/src/main/license/files/LICENSE
+++ /dev/null
@@ -1,2149 +0,0 @@
-
-This software is distributed under the Apache License, version 2.0. See (1) below.
-This software is copyright (c) The Apache Software Foundation and contributors.
-
-Contents:
-
-  (1) This software license: Apache License, version 2.0
-  (2) Notices for bundled software
-  (3) Licenses for bundled software
-
-
----------------------------------------------------
-
-(1) This software license: Apache License, version 2.0
-
-
-                                 Apache License
-                           Version 2.0, January 2004
-                        http://www.apache.org/licenses/
-
-   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
-
-   1. Definitions.
-
-      "License" shall mean the terms and conditions for use, reproduction,
-      and distribution as defined by Sections 1 through 9 of this document.
-
-      "Licensor" shall mean the copyright owner or entity authorized by
-      the copyright owner that is granting the License.
-
-      "Legal Entity" shall mean the union of the acting entity and all
-      other entities that control, are controlled by, or are under common
-      control with that entity. For the purposes of this definition,
-      "control" means (i) the power, direct or indirect, to cause the
-      direction or management of such entity, whether by contract or
-      otherwise, or (ii) ownership of fifty percent (50%) or more of the
-      outstanding shares, or (iii) beneficial ownership of such entity.
-
-      "You" (or "Your") shall mean an individual or Legal Entity
-      exercising permissions granted by this License.
-
-      "Source" form shall mean the preferred form for making modifications,
-      including but not limited to software source code, documentation
-      source, and configuration files.
-
-      "Object" form shall mean any form resulting from mechanical
-      transformation or translation of a Source form, including but
-      not limited to compiled object code, generated documentation,
-      and conversions to other media types.
-
-      "Work" shall mean the work of authorship, whether in Source or
-      Object form, made available under the License, as indicated by a
-      copyright notice that is included in or attached to the work
-      (an example is provided in the Appendix below).
-
-      "Derivative Works" shall mean any work, whether in Source or Object
-      form, that is based on (or derived from) the Work and for which the
-      editorial revisions, annotations, elaborations, or other modifications
-      represent, as a whole, an original work of authorship. For the purposes
-      of this License, Derivative Works shall not include works that remain
-      separable from, or merely link (or bind by name) to the interfaces of,
-      the Work and Derivative Works thereof.
-
-      "Contribution" shall mean any work of authorship, including
-      the original version of the Work and any modifications or additions
-      to that Work or Derivative Works thereof, that is intentionally
-      submitted to Licensor for inclusion in the Work by the copyright owner
-      or by an individual or Legal Entity authorized to submit on behalf of
-      the copyright owner. For the purposes of this definition, "submitted"
-      means any form of electronic, verbal, or written communication sent
-      to the Licensor or its representatives, including but not limited to
-      communication on electronic mailing lists, source code control systems,
-      and issue tracking systems that are managed by, or on behalf of, the
-      Licensor for the purpose of discussing and improving the Work, but
-      excluding communication that is conspicuously marked or otherwise
-      designated in writing by the copyright owner as "Not a Contribution."
-
-      "Contributor" shall mean Licensor and any individual or Legal Entity
-      on behalf of whom a Contribution has been received by Licensor and
-      subsequently incorporated within the Work.
-
-   2. Grant of Copyright License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      copyright license to reproduce, prepare Derivative Works of,
-      publicly display, publicly perform, sublicense, and distribute the
-      Work and such Derivative Works in Source or Object form.
-
-   3. Grant of Patent License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      (except as stated in this section) patent license to make, have made,
-      use, offer to sell, sell, import, and otherwise transfer the Work,
-      where such license applies only to those patent claims licensable
-      by such Contributor that are necessarily infringed by their
-      Contribution(s) alone or by combination of their Contribution(s)
-      with the Work to which such Contribution(s) was submitted. If You
-      institute patent litigation against any entity (including a
-      cross-claim or counterclaim in a lawsuit) alleging that the Work
-      or a Contribution incorporated within the Work constitutes direct
-      or contributory patent infringement, then any patent licenses
-      granted to You under this License for that Work shall terminate
-      as of the date such litigation is filed.
-
-   4. Redistribution. You may reproduce and distribute copies of the
-      Work or Derivative Works thereof in any medium, with or without
-      modifications, and in Source or Object form, provided that You
-      meet the following conditions:
-
-      (a) You must give any other recipients of the Work or
-          Derivative Works a copy of this License; and
-
-      (b) You must cause any modified files to carry prominent notices
-          stating that You changed the files; and
-
-      (c) You must retain, in the Source form of any Derivative Works
-          that You distribute, all copyright, patent, trademark, and
-          attribution notices from the Source form of the Work,
-          excluding those notices that do not pertain to any part of
-          the Derivative Works; and
-
-      (d) If the Work includes a "NOTICE" text file as part of its
-          distribution, then any Derivative Works that You distribute must
-          include a readable copy of the attribution notices contained
-          within such NOTICE file, excluding those notices that do not
-          pertain to any part of the Derivative Works, in at least one
-          of the following places: within a NOTICE text file distributed
-          as part of the Derivative Works; within the Source form or
-          documentation, if provided along with the Derivative Works; or,
-          within a display generated by the Derivative Works, if and
-          wherever such third-party notices normally appear. The contents
-          of the NOTICE file are for informational purposes only and
-          do not modify the License. You may add Your own attribution
-          notices within Derivative Works that You distribute, alongside
-          or as an addendum to the NOTICE text from the Work, provided
-          that such additional attribution notices cannot be construed
-          as modifying the License.
-
-      You may add Your own copyright statement to Your modifications and
-      may provide additional or different license terms and conditions
-      for use, reproduction, or distribution of Your modifications, or
-      for any such Derivative Works as a whole, provided Your use,
-      reproduction, and distribution of the Work otherwise complies with
-      the conditions stated in this License.
-
-   5. Submission of Contributions. Unless You explicitly state otherwise,
-      any Contribution intentionally submitted for inclusion in the Work
-      by You to the Licensor shall be under the terms and conditions of
-      this License, without any additional terms or conditions.
-      Notwithstanding the above, nothing herein shall supersede or modify
-      the terms of any separate license agreement you may have executed
-      with Licensor regarding such Contributions.
-
-   6. Trademarks. This License does not grant permission to use the trade
-      names, trademarks, service marks, or product names of the Licensor,
-      except as required for reasonable and customary use in describing the
-      origin of the Work and reproducing the content of the NOTICE file.
-
-   7. Disclaimer of Warranty. Unless required by applicable law or
-      agreed to in writing, Licensor provides the Work (and each
-      Contributor provides its Contributions) on an "AS IS" BASIS,
-      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-      implied, including, without limitation, any warranties or conditions
-      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-      PARTICULAR PURPOSE. You are solely responsible for determining the
-      appropriateness of using or redistributing the Work and assume any
-      risks associated with Your exercise of permissions under this License.
-
-   8. Limitation of Liability. In no event and under no legal theory,
-      whether in tort (including negligence), contract, or otherwise,
-      unless required by applicable law (such as deliberate and grossly
-      negligent acts) or agreed to in writing, shall any Contributor be
-      liable to You for damages, including any direct, indirect, special,
-      incidental, or consequential damages of any character arising as a
-      result of this License or out of the use or inability to use the
-      Work (including but not limited to damages for loss of goodwill,
-      work stoppage, computer failure or malfunction, or any and all
-      other commercial damages or losses), even if such Contributor
-      has been advised of the possibility of such damages.
-
-   9. Accepting Warranty or Additional Liability. While redistributing
-      the Work or Derivative Works thereof, You may choose to offer,
-      and charge a fee for, acceptance of support, warranty, indemnity,
-      or other liability obligations and/or rights consistent with this
-      License. However, in accepting such obligations, You may act only
-      on Your own behalf and on Your sole responsibility, not on behalf
-      of any other Contributor, and only if You agree to indemnify,
-      defend, and hold each Contributor harmless for any liability
-      incurred by, or claims asserted against, such Contributor by reason
-      of your accepting any such warranty or additional liability.
-
-
----------------------------------------------------
-
-(2) Notices for bundled software
-
-This project includes the software: aopalliance
-  Available at: http://aopalliance.sourceforge.net
-  Version used: 1.0
-  Used under the following license: Public Domain
-
-This project includes the software: asm
-  Available at: http://asm.objectweb.org/
-  Developed by: ObjectWeb (http://www.objectweb.org/)
-  Version used: 3.3.1
-  Used under the following license: BSD License (http://asm.objectweb.org/license.html)
-
-This project includes the software: async.js
-  Available at: https://github.com/p15martin/google-maps-hello-world/blob/master/js/libs/async.js
-  Developed by: Miller Medeiros (https://github.com/millermedeiros/)
-  Version used: 0.1.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Miller Medeiros (2011)
-
-This project includes the software: backbone.js
-  Available at: http://backbonejs.org
-  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
-  Version used: 1.0.0
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2010-2013)
-
-This project includes the software: bootstrap.js
-  Available at: http://twitter.github.com/bootstrap/javascript.html#transitions
-  Version used: 2.0.4
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-  Copyright (c) Twitter, Inc. (2012)
-
-This project includes the software: ch.qos.logback
-  Available at: http://logback.qos.ch
-  Developed by: QOS.ch (http://www.qos.ch)
-  Version used: 1.0.7
-  Used under the following license: Eclipse Public License, version 1.0 (http://www.eclipse.org/legal/epl-v10.html)
-
-This project includes the software: com.fasterxml.jackson.core
-  Available at: http://wiki.fasterxml.com/JacksonHome
-  Developed by: FasterXML (http://fasterxml.com/)
-  Version used: 2.4.2; 2.4.0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.fasterxml.jackson.jaxrs
-  Available at: http://wiki.fasterxml.com/JacksonHome
-  Developed by: FasterXML (http://fasterxml.com/)
-  Version used: 2.4.2
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.fasterxml.jackson.module
-  Available at: http://wiki.fasterxml.com/JacksonJAXBAnnotations
-  Developed by: FasterXML (http://fasterxml.com/)
-  Version used: 2.4.2
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.google.code.findbugs
-  Available at: http://findbugs.sourceforge.net/
-  Version used: 2.0.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.google.code.gson
-  Available at: http://code.google.com/p/google-gson/
-  Developed by: Google, Inc. (http://www.google.com)
-  Version used: 2.3
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.google.guava
-  Available at: http://code.google.com/p/guava-libraries
-  Version used: 17.0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.google.http-client
-  Available at: http://code.google.com/p/google-http-java-client/
-  Developed by: Google (http://www.google.com/)
-  Version used: 1.18.0-rc
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.google.inject
-  Available at: http://code.google.com/p/google-guice/
-  Developed by: Google, Inc. (http://www.google.com)
-  Version used: 3.0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.google.inject.extensions
-  Available at: http://code.google.com/p/google-guice/
-  Developed by: Google, Inc. (http://www.google.com)
-  Version used: 3.0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.googlecode.concurrentlinkedhashmap
-  Available at: http://code.google.com/p/concurrentlinkedhashmap
-  Version used: 1.0_jdk5
-  Used under the following license: Apache License (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.jamesmurty.utils
-  Available at: https://github.com/jmurty/java-xmlbuilder
-  Version used: 1.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-
-This project includes the software: com.jayway.jsonpath
-  Available at: https://github.com/jayway/JsonPath
-  Version used: 2.0.0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.jcraft
-  Available at: http://www.jcraft.com/jsch-agent-proxy/
-  Developed by: JCraft,Inc. (http://www.jcraft.com/)
-  Version used: 0.0.8
-  Used under the following license: The BSD 3-Clause (New BSD) License (http://www.jcraft.com/jsch-agent-proxy/LICENSE.txt)
-
-This project includes the software: com.maxmind.db
-  Available at: http://dev.maxmind.com/
-  Developed by: MaxMind, Inc. (http://www.maxmind.com/)
-  Version used: 0.3.4
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.html)
-
-This project includes the software: com.maxmind.geoip2
-  Available at: http://dev.maxmind.com/geoip/geoip2/web-services
-  Developed by: MaxMind, Inc. (http://www.maxmind.com/)
-  Version used: 0.8.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.html)
-
-This project includes the software: com.squareup.okhttp
-  Available at: https://github.com/square/okhttp
-  Version used: 2.2.0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.squareup.okio
-  Available at: https://github.com/square/okio
-  Version used: 1.2.0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: com.sun.jersey
-  Available at: https://jersey.java.net/
-  Developed by: Oracle Corporation (http://www.oracle.com/)
-  Version used: 1.18.1
-  Used under the following license: Common Development and Distribution License, version 1.1 (http://glassfish.java.net/public/CDDL+GPL_1_1.html)
-
-This project includes the software: com.sun.jersey.contribs
-  Available at: https://jersey.java.net/
-  Developed by: Oracle Corporation (http://www.oracle.com/)
-  Version used: 1.18.1
-  Used under the following license: Common Development and Distribution License, version 1.1 (http://glassfish.java.net/public/CDDL+GPL_1_1.html)
-
-This project includes the software: com.thoughtworks.xstream
-  Available at: http://x-stream.github.io/
-  Developed by: XStream (http://xstream.codehaus.org)
-  Version used: 1.4.7
-  Used under the following license: BSD License (http://xstream.codehaus.org/license.html)
-
-This project includes the software: com.wordnik
-  Available at: https://github.com/wordnik/swagger-core
-  Version used: 1.0.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.html)
-
-This project includes the software: commons-beanutils
-  Available at: http://commons.apache.org/proper/commons-beanutils/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: commons-codec
-  Available at: http://commons.apache.org/proper/commons-codec/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: commons-collections
-  Available at: http://commons.apache.org/collections/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 3.2.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: commons-io
-  Available at: http://commons.apache.org/io/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 2.4
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: commons-lang
-  Available at: http://commons.apache.org/lang/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 2.4
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: commons-logging
-  Available at: http://commons.apache.org/proper/commons-logging/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.2
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: dom4j
-  Available at: http://dom4j.sourceforge.net/
-  Developed by: MetaStuff Ltd. (http://sourceforge.net/projects/dom4j)
-  Version used: 1.6.1
-  Used under the following license: MetaStuff BSD style license (3-clause) (http://dom4j.sourceforge.net/dom4j-1.6.1/license.html)
-
-This project includes the software: handlebars.js
-  Available at: https://github.com/wycats/handlebars.js
-  Developed by: Yehuda Katz (https://github.com/wycats/)
-  Inclusive of: handlebars*.js
-  Version used: 1.0-rc1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Yehuda Katz (2012)
-
-This project includes the software: io.airlift
-  Available at: https://github.com/airlift/airline
-  Version used: 0.6
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: io.cloudsoft.windows
-  Available at: http://github.com/cloudsoft/winrm4j
-  Version used: 0.1.0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: javax.annotation
-  Available at: https://jcp.org/en/jsr/detail?id=250
-  Version used: 1.0
-  Used under the following license: Common Development and Distribution License, version 1.0 (https://glassfish.dev.java.net/public/CDDLv1.0.html)
-
-This project includes the software: javax.inject
-  Available at: http://code.google.com/p/atinject/
-  Version used: 1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: javax.servlet
-  Available at: http://servlet-spec.java.net
-  Developed by: GlassFish Community (https://glassfish.dev.java.net)
-  Version used: 3.1.0
-  Used under the following license: CDDL + GPLv2 with classpath exception (https://glassfish.dev.java.net/nonav/public/CDDL+GPL.html)
-
-This project includes the software: javax.validation
-  Version used: 1.0.0.GA
-  Used under the following license: Apache License, version 2.0 (in-project reference: license.txt)
-
-This project includes the software: javax.ws.rs
-  Available at: https://jsr311.java.net/
-  Developed by: Sun Microsystems, Inc (http://www.sun.com/)
-  Version used: 1.1.1
-  Used under the following license: CDDL License (http://www.opensource.org/licenses/cddl1.php)
-
-This project includes the software: jQuery JavaScript Library
-  Available at: http://jquery.com/
-  Developed by: The jQuery Foundation (http://jquery.org/)
-  Inclusive of: jquery.js
-  Version used: 1.7.2
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) John Resig (2005-2011)
-  Includes code fragments from sizzle.js:
-    Copyright (c) The Dojo Foundation
-    Available at http://sizzlejs.com
-    Used under the MIT license
-
-This project includes the software: jQuery BBQ: Back Button & Query Library
-  Available at: http://benalman.com/projects/jquery-bbq-plugin/
-  Developed by: "Cowboy" Ben Alman (http://benalman.com/)
-  Inclusive of: jquery.ba-bbq*.js
-  Version used: 1.2.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) "Cowboy" Ben Alman (2010)"
-
-This project includes the software: DataTables Table plug-in for jQuery
-  Available at: http://www.datatables.net/
-  Developed by: SpryMedia Ltd (http://sprymedia.co.uk/)
-  Inclusive of: jquery.dataTables.{js,css}
-  Version used: 1.9.4
-  Used under the following license: The BSD 3-Clause (New BSD) License (http://opensource.org/licenses/BSD-3-Clause)
-  Copyright (c) Allan Jardine (2008-2012)
-
-This project includes the software: jQuery Form Plugin
-  Available at: https://github.com/malsup/form
-  Developed by: Mike Alsup (http://malsup.com/)
-  Inclusive of: jquery.form.js
-  Version used: 3.09
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) M. Alsup (2006-2013)
-
-This project includes the software: jQuery Wiggle
-  Available at: https://github.com/jordanthomas/jquery-wiggle
-  Inclusive of: jquery.wiggle.min.js
-  Version used: swagger-ui:1.0.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) WonderGroup and Jordan Thomas (2010)
-  Previously online at http://labs.wondergroup.com/demos/mini-ui/index.html.
-  The version included here is from the Swagger UI distribution.
-
-This project includes the software: js-uri
-  Available at: http://code.google.com/p/js-uri/
-  Developed by: js-uri contributors (https://code.google.com/js-uri)
-  Inclusive of: URI.js
-  Version used: 0.1
-  Used under the following license: The BSD 3-Clause (New BSD) License (http://opensource.org/licenses/BSD-3-Clause)
-  Copyright (c) js-uri contributors (2013)
-
-This project includes the software: js-yaml.js
-  Available at: https://github.com/nodeca/
-  Developed by: Vitaly Puzrin (https://github.com/nodeca/)
-  Version used: 3.2.7
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Vitaly Puzrin (2011-2015)
-
-This project includes the software: moment.js
-  Available at: http://momentjs.com
-  Developed by: Tim Wood (http://momentjs.com)
-  Version used: 2.1.0
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Tim Wood, Iskren Chernev, Moment.js contributors (2011-2014)
-
-This project includes the software: net.iharder
-  Available at: http://iharder.net/base64/
-  Version used: 2.3.8
-  Used under the following license: Public domain
-
-This project includes the software: net.java.dev.jna
-  Available at: https://github.com/twall/jna
-  Version used: 4.0.0
-  Used under the following license: Apache License, version 2.0 (http://www.gnu.org/licenses/licenses.html)
-
-This project includes the software: net.minidev
-  Available at: http://www.minidev.net/
-  Developed by: Chemouni Uriel (http://www.minidev.net/)
-  Version used: 2.1.1; 1.0.2
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: net.schmizz
-  Available at: http://github.com/shikhar/sshj
-  Version used: 0.8.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.99soft.guice
-  Available at: http://99soft.github.com/rocoto/
-  Developed by: 99 Software Foundation (http://www.99soft.org/)
-  Version used: 6.2
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.commons
-  Available at: http://commons.apache.org/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 3.1; 1.4
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.felix
-  Available at: http://felix.apache.org/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 4.4.0
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.httpcomponents
-  Available at: http://hc.apache.org/httpcomponents-client-ga http://hc.apache.org/httpcomponents-core-ga
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 4.4.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.jclouds
-  Available at: http://jclouds.apache.org/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.jclouds.api
-  Available at: http://jclouds.apache.org/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.jclouds.common
-  Available at: http://jclouds.apache.org/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.jclouds.driver
-  Available at: http://jclouds.apache.org/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.jclouds.labs
-  Available at: http://jclouds.apache.org/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.apache.jclouds.provider
-  Available at: http://jclouds.apache.org/
-  Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.bouncycastle
-  Available at: http://www.bouncycastle.org/java.html
-  Version used: 1.49
-  Used under the following license: Bouncy Castle Licence (http://www.bouncycastle.org/licence.html)
-
-This project includes the software: org.codehaus.groovy
-  Available at: http://groovy.codehaus.org/
-  Developed by: The Codehaus (http://codehaus.org)
-  Version used: 2.3.7
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.codehaus.jackson
-  Available at: http://jackson.codehaus.org
-  Developed by: FasterXML (http://fasterxml.com)
-  Version used: 1.9.13
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.codehaus.jettison
-  Version used: 1.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-
-This project includes the software: org.eclipse.jetty
-  Available at: http://www.eclipse.org/jetty
-  Developed by: Webtide (http://webtide.com)
-  Version used: 9.2.13.v20150730
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-
-This project includes the software: org.freemarker
-  Available at: http://freemarker.org/
-  Version used: 2.3.22
-  Used under the following license: Apache License, version 2.0 (http://freemarker.org/LICENSE.txt)
-
-This project includes the software: org.glassfish.external
-  Version used: 1.0-b01-ea
-  Used under the following license: Common Development and Distribution License (http://opensource.org/licenses/CDDL-1.0)
-
-This project includes the software: org.hibernate
-  Available at: http://jtidy.sourceforge.net
-  Version used: r8-20060801
-  Used under the following license: Java HTML Tidy License (http://sourceforge.net/p/jtidy/code/HEAD/tree/trunk/jtidy/LICENSE.txt?revision=95)
-
-This project includes the software: org.javassist
-  Available at: http://www.javassist.org/
-  Version used: 3.16.1-GA
-  Used under the following license: Apache License, version 2.0 (http://www.mozilla.org/MPL/MPL-1.1.html)
-
-This project includes the software: org.jvnet.mimepull
-  Available at: http://mimepull.java.net
-  Developed by: Oracle Corporation (http://www.oracle.com/)
-  Version used: 1.9.3
-  Used under the following license: Common Development and Distribution License, version 1.1 (https://glassfish.java.net/public/CDDL+GPL_1_1.html)
-
-This project includes the software: org.mongodb
-  Available at: http://www.mongodb.org
-  Version used: 3.0.3
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
-
-This project includes the software: org.python
-  Available at: http://www.jython.org/
-  Version used: 2.7-b3
-  Used under the following license: Jython Software License (http://www.jython.org/license.html)
-
-This project includes the software: org.reflections
-  Available at: http://code.google.com/p/reflections/
-  Version used: 0.9.9-RC1
-  Used under the following license: WTFPL (http://www.wtfpl.net/)
-
-This project includes the software: org.scala-lang
-  Available at: http://www.scala-lang.org/
-  Developed by: LAMP/EPFL (http://lamp.epfl.ch/)
-  Version used: 2.9.1-1
-  Used under the following license: BSD License (http://www.scala-lang.org/downloads/license.html)
-
-This project includes the software: org.slf4j
-  Available at: http://www.slf4j.org
-  Developed by: QOS.ch (http://www.qos.ch)
-  Version used: 1.6.6
-  Used under the following license: The MIT License (http://www.opensource.org/licenses/mit-license.php)
-
-This project includes the software: org.tukaani
-  Available at: http://tukaani.org/xz/java.html
-  Version used: 1.0
-  Used under the following license: Public Domain
-
-This project includes the software: org.yaml
-  Available at: http://www.snakeyaml.org
-  Version used: 1.11
-  Used under the following license: Apache License, version 2.0 (in-project reference: LICENSE.txt)
-
-This project includes the software: RequireJS
-  Available at: http://requirejs.org/
-  Developed by: The Dojo Foundation (http://dojofoundation.org/)
-  Inclusive of: require.js, text.js
-  Version used: 2.0.6
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) The Dojo Foundation (2010-2012)
-
-This project includes the software: RequireJS (r.js maven plugin)
-  Available at: http://github.com/jrburke/requirejs
-  Developed by: The Dojo Foundation (http://dojofoundation.org/)
-  Inclusive of: r.js
-  Version used: 2.1.6
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) The Dojo Foundation (2009-2013)
-  Includes code fragments for source-map and other functionality:
-    Copyright (c) The Mozilla Foundation and contributors (2011)
-    Used under the BSD 2-Clause license.
-  Includes code fragments for parse-js and other functionality:
-    Copyright (c) Mihai Bazon (2010, 2012)
-    Used under the BSD 2-Clause license.
-  Includes code fragments for uglifyjs/consolidator:
-    Copyright (c) Robert Gust-Bardon (2012)
-    Used under the BSD 2-Clause license.
-  Includes code fragments for the esprima parser:
-    Copyright (c):
-      Ariya Hidayat (2011, 2012)
-      Mathias Bynens (2012)
-      Joost-Wim Boekesteijn (2012)
-      Kris Kowal (2012)
-      Yusuke Suzuki (2012)
-      Arpad Borsos (2012)
-    Used under the BSD 2-Clause license.
-
-This project includes the software: Swagger JS
-  Available at: https://github.com/wordnik/swagger-js
-  Inclusive of: swagger.js
-  Version used: 1.0.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-  Copyright (c) SmartBear Software (2011-2015)
-
-This project includes the software: Swagger UI
-  Available at: https://github.com/wordnik/swagger-ui
-  Inclusive of: swagger-ui.js
-  Version used: 1.0.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-  Copyright (c) SmartBear Software (2011-2015)
-
-This project includes the software: typeahead.js
-  Available at: https://github.com/twitter/typeahead.js
-  Developed by: Twitter, Inc (http://twitter.com)
-  Version used: 0.10.5
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Twitter, Inc. and other contributors (2013-2014)
-
-This project includes the software: underscore.js
-  Available at: http://underscorejs.org
-  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
-  Inclusive of: underscore*.{js,map}
-  Version used: 1.4.4
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2009-2013)
-
-This project includes the software: underscore.js:1.7.0
-  Available at: http://underscorejs.org
-  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
-  Inclusive of: underscore*.{js,map}
-  Version used: 1.7.0
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Jeremy Ashkenas, DocumentCloud and Investigative Reporters & Editors (2009-2014)
-
-This project includes the software: xmlpull
-  Available at: http://www.xmlpull.org
-  Version used: 1.1.3.1
-  Used under the following license: Public Domain (http://www.xmlpull.org/v1/download/unpacked/LICENSE.txt)
-
-This project includes the software: xpp3
-  Available at: http://www.extreme.indiana.edu/xgws/xsoap/xpp/mxp1/
-  Developed by: Extreme! Lab, Indiana University (http://www.extreme.indiana.edu/)
-  Version used: 1.1.4c
-  Used under the following license: Indiana University Extreme! Lab Software License, vesion 1.1.1 (https://github.com/apache/openmeetings/blob/a95714ce3f7e587d13d3d0bb3b4f570be15c67a5/LICENSE#L1361)
-
-This project includes the software: ZeroClipboard
-  Available at: http://zeroclipboard.org/
-  Developed by: ZeroClipboard contributors (https://github.com/zeroclipboard)
-  Inclusive of: ZeroClipboard.*
-  Version used: 1.3.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Jon Rohan, James M. Greene (2014)
-
-
----------------------------------------------------
-
-(3) Licenses for bundled software
-
-Contents:
-
-  Apache License, Version 2.0
-  The BSD 2-Clause License
-  The BSD 3-Clause License ("New BSD")
-  COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.0
-  COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.1
-  Eclipse Public License, version 1.0
-  The MIT License ("MIT")
-  WTF Public License
-  Bouncy Castle License
-  JTidy License
-  Jython License
-  MetaStuff BSD Style License
-  Indiana University Extreme! Lab Software License, Version 1.1.1
-
-
-Apache License, Version 2.0
-
-  Apache License
-  Version 2.0, January 2004
-  http://www.apache.org/licenses/
-  
-  TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
-  
-  1. Definitions.
-  
-  "License" shall mean the terms and conditions for use, reproduction,
-  and distribution as defined by Sections 1 through 9 of this document.
-  
-  "Licensor" shall mean the copyright owner or entity authorized by
-  the copyright owner that is granting the License.
-  
-  "Legal Entity" shall mean the union of the acting entity and all
-  other entities that control, are controlled by, or are under common
-  control with that entity. For the purposes of this definition,
-  "control" means (i) the power, direct or indirect, to cause the
-  direction or management of such entity, whether by contract or
-  otherwise, or (ii) ownership of fifty percent (50%) or more of the
-  outstanding shares, or (iii) beneficial ownership of such entity.
-  
-  "You" (or "Your") shall mean an individual or Legal Entity
-  exercising permissions granted by this License.
-  
-  "Source" form shall mean the preferred form for making modifications,
-  including but not limited to software source code, documentation
-  source, and configuration files.
-  
-  "Object" form shall mean any form resulting from mechanical
-  transformation or translation of a Source form, including but
-  not limited to compiled object code, generated documentation,
-  and conversions to other media types.
-  
-  "Work" shall mean the work of authorship, whether in Source or
-  Object form, made available under the License, as indicated by a
-  copyright notice that is included in or attached to the work
-  (an example is provided in the Appendix below).
-  
-  "Derivative Works" shall mean any work, whether in Source or Object
-  form, that is based on (or derived from) the Work and for which the
-  editorial revisions, annotations, elaborations, or other modifications
-  represent, as a whole, an original work of authorship. For the purposes
-  of this License, Derivative Works shall not include works that remain
-  separable from, or merely link (or bind by name) to the interfaces of,
-  the Work and Derivative Works thereof.
-  
-  "Contribution" shall mean any work of authorship, including
-  the original version of the Work and any modifications or additions
-  to that Work or Derivative Works thereof, that is intentionally
-  submitted to Licensor for inclusion in the Work by the copyright owner
-  or by an individual or Legal Entity authorized to submit on behalf of
-  the copyright owner. For the purposes of this definition, "submitted"
-  means any form of electronic, verbal, or written communication sent
-  to the Licensor or its representatives, including but not limited to
-  communication on electronic mailing lists, source code control systems,
-  and issue tracking systems that are managed by, or on behalf of, the
-  Licensor for the purpose of discussing and improving the Work, but
-  excluding communication that is conspicuously marked or otherwise
-  designated in writing by the copyright owner as "Not a Contribution."
-  
-  "Contributor" shall mean Licensor and any individual or Legal Entity
-  on behalf of whom a Contribution has been received by Licensor and
-  subsequently incorporated within the Work.
-  
-  2. Grant of Copyright License. Subject to the terms and conditions of
-  this License, each Contributor hereby grants to You a perpetual,
-  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-  copyright license to reproduce, prepare Derivative Works of,
-  publicly display, publicly perform, sublicense, and distribute the
-  Work and such Derivative Works in Source or Object form.
-  
-  3. Grant of Patent License. Subject to the terms and conditions of
-  this License, each Contributor hereby grants to You a perpetual,
-  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-  (except as stated in this section) patent license to make, have made,
-  use, offer to sell, sell, import, and otherwise transfer the Work,
-  where such license applies only to those patent claims licensable
-  by such Contributor that are necessarily infringed by their
-  Contribution(s) alone or by combination of their Contribution(s)
-  with the Work to which such Contribution(s) was submitted. If You
-  institute patent litigation against any entity (including a
-  cross-claim or counterclaim in a lawsuit) alleging that the Work
-  or a Contribution incorporated within the Work constitutes direct
-  or contributory patent infringement, then any patent licenses
-  granted to You under this License for that Work shall terminate
-  as of the date such litigation is filed.
-  
-  4. Redistribution. You may reproduce and distribute copies of the
-  Work or Derivative Works thereof in any medium, with or without
-  modifications, and in Source or Object form, provided that You
-  meet the following conditions:
-  
-  (a) You must give any other recipients of the Work or
-  Derivative Works a copy of this License; and
-  
-  (b) You must cause any modified files to carry prominent notices
-  stating that You changed the files; and
-  
-  (c) You must retain, in the Source form of any Derivative Works
-  that You distribute, all copyright, patent, trademark, and
-  attribution notices from the Source form of the Work,
-  excluding those notices that do not pertain to any part of
-  the Derivative Works; and
-  
-  (d) If the Work includes a "NOTICE" text file as part of its
-  distribution, then any Derivative Works that You distribute must
-  include a readable copy of the attribution notices contained
-  within such NOTICE file, excluding those notices that do not
-  pertain to any part of the Derivative Works, in at least one
-  of the following places: within a NOTICE text file distributed
-  as part of the Derivative Works; within the Source form or
-  documentation, if provided along with the Derivative Works; or,
-  within a display generated by the Derivative Works, if and
-  wherever such third-party notices normally appear. The contents
-  of the NOTICE file are for informational purposes only and
-  do not modify the License. You may add Your own attribution
-  notices within Derivative Works that You distribute, alongside
-  or as an addendum to the NOTICE text from the Work, provided
-  that such additional attribution notices cannot be construed
-  as modifying the License.
-  
-  You may add Your own copyright statement to Your modifications and
-  may provide additional or different license terms and conditions
-  for use, reproduction, or distribution of Your modifications, or
-  for any such Derivative Works as a whole, provided Your use,
-  reproduction, and distribution of the Work otherwise complies with
-  the conditions stated in this License.
-  
-  5. Submission of Contributions. Unless You explicitly state otherwise,
-  any Contribution intentionally submitted for inclusion in the Work
-  by You to the Licensor shall be under the terms and conditions of
-  this License, without any additional terms or conditions.
-  Notwithstanding the above, nothing herein shall supersede or modify
-  the terms of any separate license agreement you may have executed
-  with Licensor regarding such Contributions.
-  
-  6. Trademarks. This License does not grant permission to use the trade
-  names, trademarks, service marks, or product names of the Licensor,
-  except as required for reasonable and customary use in describing the
-  origin of the Work and reproducing the content of the NOTICE file.
-  
-  7. Disclaimer of Warranty. Unless required by applicable law or
-  agreed to in writing, Licensor provides the Work (and each
-  Contributor provides its Contributions) on an "AS IS" BASIS,
-  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-  implied, including, without limitation, any warranties or conditions
-  of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-  PARTICULAR PURPOSE. You are solely responsible for determining the
-  appropriateness of using or redistributing the Work and assume any
-  risks associated with Your exercise of permissions under this License.
-  
-  8. Limitation of Liability. In no event and under no legal theory,
-  whether in tort (including negligence), contract, or otherwise,
-  unless required by applicable law (such as deliberate and grossly
-  negligent acts) or agreed to in writing, shall any Contributor be
-  liable to You for damages, including any direct, indirect, special,
-  incidental, or consequential damages of any character arising as a
-  result of this License or out of the use or inability to use the
-  Work (including but not limited to damages for loss of goodwill,
-  work stoppage, computer failure or malfunction, or any and all
-  other commercial damages or losses), even if such Contributor
-  has been advised of the possibility of such damages.
-  
-  9. Accepting Warranty or Additional Liability. While redistributing
-  the Work or Derivative Works thereof, You may choose to offer,
-  and charge a fee for, acceptance of support, warranty, indemnity,
-  or other liability obligations and/or rights consistent with this
-  License. However, in accepting such obligations, You may act only
-  on Your own behalf and on Your sole responsibility, not on behalf
-  of any other Contributor, and only if You agree to indemnify,
-  defend, and hold each Contributor harmless for any liability
-  incurred by, or claims asserted against, such Contributor by reason
-  of your accepting any such warranty or additional liability.
-  
-
-The BSD 2-Clause License
-
-  Redistribution and use in source and binary forms, with or without
-  modification, are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, this
-  list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice,
-  this list of conditions and the following disclaimer in the documentation
-  and/or other materials provided with the distribution.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
-  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
-  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
-  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
-  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
-  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
-  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
-  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
-  
-
-The BSD 3-Clause License ("New BSD")
-
-  Redistribution and use in source and binary forms, with or without modification,
-  are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, 
-  this list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice, 
-  this list of conditions and the following disclaimer in the documentation 
-  and/or other materials provided with the distribution.
-  
-  3. Neither the name of the copyright holder nor the names of its contributors 
-  may be used to endorse or promote products derived from this software without 
-  specific prior written permission.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
-  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
-  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
-  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
-  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
-  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
-  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
-  POSSIBILITY OF SUCH DAMAGE.
-  
-
-COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.0
-
-  1. Definitions.
-  
-  1.1. "Contributor" means each individual or entity that
-  creates or contributes to the creation of Modifications.
-  
-  1.2. "Contributor Version" means the combination of the
-  Original Software, prior Modifications used by a
-  Contributor (if any), and the Modifications made by that
-  particular Contributor.
-  
-  1.3. "Covered Software" means (a) the Original Software, or
-  (b) Modifications, or (c) the combination of files
-  containing Original Software with files containing
-  Modifications, in each case including portions thereof.
-  
-  1.4. "Executable" means the Covered Software in any form
-  other than Source Code. 
-  
-  1.5. "Initial Developer" means the individual or entity
-  that first makes Original Software available under this
-  License. 
-  
-  1.6. "Larger Work" means a work which combines Covered
-  Software or portions thereof with code not governed by the
-  terms of this License.
-  
-  1.7. "License" means this document.
-  
-  1.8. "Licensable" means having the right to grant, to the
-  maximum extent possible, whether at the time of the initial
-  grant or subsequently acquired, any and all of the rights
-  conveyed herein.
-  
-  1.9. "Modifications" means the Source Code and Executable
-  form of any of the following: 
-  
-  A. Any file that results from an addition to,
-  deletion from or modification of the contents of a
-  file containing Original Software or previous
-  Modifications; 
-  
-  B. Any new file that contains any part of the
-  Original Software or previous Modification; or 
-  
-  C. Any new file that is contributed or otherwise made
-  available under the terms of this License.
-  
-  1.10. "Original Software" means the Source Code and
-  Executable form of computer software code that is
-  originally released under this License. 
-  
-  1.11. "Patent Claims" means any patent claim(s), now owned
-  or hereafter acquired, including without limitation,
-  method, process, and apparatus claims, in any patent
-  Licensable by grantor. 
-  
-  1.12. "Source Code" means (a) the common form of computer
-  software code in which modifications are made and (b)
-  associated documentation included in or with such code.
-  
-  1.13. "You" (or "Your") means an individual or a legal
-  entity exercising rights under, and complying with all of
-  the terms of, this License. For legal entities, "You"
-  includes any entity which controls, is controlled by, or is
-  under common control with You. For purposes of this
-  definition, "control" means (a) the power, direct or
-  indirect, to cause the direction or management of such
-  entity, whether by contract or otherwise, or (b) ownership
-  of more than fifty percent (50%) of the outstanding shares
-  or beneficial ownership of such entity.
-  
-  2. License Grants. 
-  
-  2.1. The Initial Developer Grant.
-  
-  Conditioned upon Your compliance with Section 3.1 below and
-  subject to third party intellectual property claims, the
-  Initial Developer hereby grants You a world-wide,
-  royalty-free, non-exclusive license: 
-  
-  (a) under intellectual property rights (other than
-  patent or trademark) Licensable by Initial Developer,
-  to use, reproduce, modify, display, perform,
-  sublicense and distribute the Original Software (or
-  portions thereof), with or without Modifications,
-  and/or as part of a Larger Work; and 
-  
-  (b) under Patent Claims infringed by the making,
-  using or selling of Original Software, to make, have
-  made, use, practice, sell, and offer for sale, and/or
-  otherwise dispose of the Original Software (or
-  portions thereof). 
-  
-  (c) The licenses granted in Sections 2.1(a) and (b)
-  are effective on the date Initial Developer first
-  distributes or otherwise makes the Original Software
-  available to a third party under the terms of this
-  License. 
-  
-  (d) Notwithstanding Section 2.1(b) above, no patent
-  license is granted: (1) for code that You delete from
-  the Original Software, or (2) for infringements
-  caused by: (i) the modification of the Original
-  Software, or (ii) the combination of the Original
-  Software with other software or devices. 
-  
-  2.2. Contributor Grant.
-  
-  Conditioned upon Your compliance with Section 3.1 below and
-  subject to third party intellectual property claims, each
-  Contributor hereby grants You a world-wide, royalty-free,
-  non-exclusive license:
-  
-  (a) under intellectual property rights (other than
-  patent or trademark) Licensable by Contributor to
-  use, reproduce, modify, display, perform, sublicense
-  and distribute the Modifications created by such
-  Contributor (or portions thereof), either on an
-  unmodified basis, with other Modifications, as
-  Covered Software and/or as part of a Larger Work; and
-  
-  (b) under Patent Claims infringed by the making,
-  using, or selling of Modifications made by that
-  Contributor either alone and/or in combination with
-  its Contributor Version (or portions of such
-  combination), to make, use, sell, offer for sale,
-  have made, and/or otherwise dispose of: (1)
-  Modifications made by that Contributor (or portions
-  thereof); and (2) the combination of Modifications
-  made by that Contributor with its Contributor Version
-  (or portions of such combination). 
-  
-  (c) The licenses granted in Sections 2.2(a) and
-  2.2(b) are effective on the date Contributor first
-  distributes or otherwise makes the Modifications
-  available to a third party. 
-  
-  (d) Notwithstanding Section 2.2(b) above, no patent
-  license is granted: (1) for any code that Contributor
-  has deleted from the Contributor Version; (2) for
-  infringements caused by: (i) third party
-  modifications of Contributor Version, or (ii) the
-  combination of Modifications made by that Contributor
-  with other software (except as part of the
-  Contributor Version) or other devices; or (3) under
-  Patent Claims infringed by Covered Software in the
-  absence of Modifications made by that Contributor. 
-  
-  3. Distribution Obligations.
-  
-  3.1. Availability of Source Code.
-  
-  Any Covered Software that You distribute or otherwise make
-  available in Executable form must also be made available in
-  Source Code form and that Source Code form must be
-  distributed only under the terms of this License. You must
-  include a copy of this License with every copy of the
-  Source Code form of the Covered Software You distribute or
-  otherwise make available. You must inform recipients of any
-  such Covered Software in Executable form as to how they can
-  obtain such Covered Software in Source Code form in a
-  reasonable manner on or through a medium customarily used
-  for software exchange.
-  
-  3.2. Modifications.
-  
-  The Modifications that You create or to which You
-  contribute are governed by the terms of this License. You
-  represent that You believe Your Modifications are Your
-  original creation(s) and/or You have sufficient rights to
-  grant the rights conveyed by this License.
-  
-  3.3. Required Notices.
-  
-  You must include a notice in each of Your Modifications
-  that identifies You as the Contributor of the Modification.
-  You may not remove or alter any copyright, patent or
-  trademark notices contained within the Covered Software, or
-  any notices of licensing or any descriptive text giving
-  attribution to any Contributor or the Initial Developer.
-  
-  3.4. Application of Additional Terms.
-  
-  You may not offer or impose any terms on any Covered
-  Software in Source Code form that alters or restricts the
-  applicable version of this License or the recipients"
-  rights hereunder. You may choose to offer, and to charge a
-  fee for, warranty, support, indemnity or liability
-  obligations to one or more recipients of Covered Software.
-  However, you may do so only on Your own behalf, and not on
-  behalf of the Initial Developer or any Contributor. You
-  must make it absolutely clear that any such warranty,
-  support, indemnity or liability obligation is offered by
-  You alone, and You hereby agree to indemnify the Initial
-  Developer and every Contributor for any liability incurred
-  by the Initial Developer or such Contributor as a result of
-  warranty, support, indemnity or liability terms You offer.
-      
-  3.5. Distribution of Executable Versions.
-  
-  You may distribute the Executable form of the Covered
-  Software under the terms of this License or under the terms
-  of a license of Your choice, which may contain terms
-  different from this License, provided that You are in
-  compliance with the terms of this License and that the
-  license for the Executable form does not attempt to limit
-  or alter the recipient"s rights in the Source Code form
-  from the rights set forth in this License. If You
-  distribute the Covered Software in Executable form under a
-  different license, You must make it absolutely clear that
-  any terms which differ from this License are offered by You
-  alone, not by the Initial Developer or Contributor. You
-  hereby agree to indemnify the Initial Developer and every
-  Contributor for any liability incurred by the Initial
-  Developer or such Contributor as a result of any such terms
-  You offer.
-  
-  3.6. Larger Works.
-  
-  You may create a Larger Work by combining Covered Software
-  with other code not governed by the terms of this License
-  and distribute the Larger Work as a single product. In such
-  a case, You must make sure the requirements of this License
-  are fulfilled for the Covered Software. 
-  
-  4. Versions of the License. 
-  
-  4.1. New Versions.
-  
-  Sun Microsystems, Inc. is the initial license steward and
-  may publish revised and/or new versions of this License
-  from time to time. Each version will be given a
-  distinguishing version number. Except as provided in
-  Section 4.3, no one other than the license steward has the
-  right to modify this License. 
-  
-  4.2. Effect of New Versions.
-  
-  You may always continue to use, distribute or otherwise
-  make the Covered Software available under the terms of the
-  version of the License under which You originally received
-  the Covered Software. If the Initial Developer includes a
-  notice in the Original Software prohibiting it from being
-  distributed or otherwise made available under any
-  subsequent version of the License, You must distribute and
-  make the Covered Software available under the terms of the
-  version of the License under which You originally received
-  the Covered Software. Otherwise, You may also choose to
-  use, distribute or otherwise make the Covered Software
-  available under the terms of any subsequent version of the
-  License published by the license steward. 
-  
-  4.3. Modified Versions.
-  
-  When You are an Initial Developer and You want to create a
-  new license for Your Original Software, You may create and
-  use a modified version of this License if You: (a) rename
-  the license and remove any references to the name of the
-  license steward (except to note that the license differs
-  from this License); and (b) otherwise make it clear that
-  the license contains terms which differ from this License.
-  
-  5. DISCLAIMER OF WARRANTY.
-  
-  COVERED SOFTWARE IS PROVIDED UNDER THIS LICENSE ON AN "AS IS"
-  BASIS, WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED,
-  INCLUDING, WITHOUT LIMITATION, WARRANTIES THAT THE COVERED
-  SOFTWARE IS FREE OF DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR
-  PURPOSE OR NON-INFRINGING. THE ENTIRE RISK AS TO THE QUALITY AND
-  PERFORMANCE OF THE COVERED SOFTWARE IS WITH YOU. SHOULD ANY
-  COVERED SOFTWARE PROVE DEFECTIVE IN ANY RESPECT, YOU (NOT THE
-  INITIAL DEVELOPER OR ANY OTHER CONTRIBUTOR) ASSUME THE COST OF
-  ANY NECESSARY SERVICING, REPAIR OR CORRECTION. THIS DISCLAIMER OF
-  WARRANTY CONSTITUTES AN ESSENTIAL PART OF THIS LICENSE. NO USE OF
-  ANY COVERED SOFTWARE IS AUTHORIZED HEREUNDER EXCEPT UNDER THIS
-  DISCLAIMER. 
-  
-  6. TERMINATION. 
-  
-  6.1. This License and the rights granted hereunder will
-  terminate automatically if You fail to comply with terms
-  herein and fail to cure such breach within 30 days of
-  becoming aware of the breach. Provisions which, by their
-  nature, must remain in effect beyond the termination of
-  this License shall survive.
-  
-  6.2. If You assert a patent infringement claim (excluding
-  declaratory judgment actions) against Initial Developer or
-  a Contributor (the Initial Developer or Contributor against
-  whom You assert such claim is referred to as "Participant")
-  alleging that the Participant Software (meaning the
-  Contributor Version where the Participant is a Contributor
-  or the Original Software where the Participant is the
-  Initial Developer) directly or indirectly infringes any
-  patent, then any and all rights granted directly or
-  indirectly to You by such Participant, the Initial
-  Developer (if the Initial Developer is not the Participant)
-  and all Contributors under Sections 2.1 and/or 2.2 of this
-  License shall, upon 60 days notice from Participant
-  terminate prospectively and automatically at the expiration
-  of such 60 day notice period, unless if within such 60 day
-  period You withdraw Your claim with respect to the
-  Participant Software against such Participant either
-  unilaterally or pursuant to a written agreement with
-  Participant.
-  
-  6.3. In the event of termination under Sections 6.1 or 6.2
-  above, all end user licenses that have been validly granted
-  by You or any distributor hereunder prior to termination
-  (excluding licenses granted to You by any distributor)
-  shall survive termination.
-  
-  7. LIMITATION OF LIABILITY.
-  
-  UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT
-  (INCLUDING NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE
-  INITIAL DEVELOPER, ANY OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF
-  COVERED SOFTWARE, OR ANY SUPPLIER OF ANY OF SUCH PARTIES, BE
-  LIABLE TO ANY PERSON FOR ANY INDIRECT, SPECIAL, INCIDENTAL, OR
-  CONSEQUENTIAL DAMAGES OF ANY CHARACTER INCLUDING, WITHOUT
-  LIMITATION, DAMAGES FOR LOST PROFITS, LOSS OF GOODWILL, WORK
-  STOPPAGE, COMPUTER FAILURE OR MALFUNCTION, OR ANY AND ALL OTHER
-  COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH PARTY SHALL HAVE BEEN
-  INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS LIMITATION OF
-  LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL
-  INJURY RESULTING FROM SUCH PARTY"S NEGLIGENCE TO THE EXTENT
-  APPLICABLE LAW PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO
-  NOT ALLOW THE EXCLUSION OR LIMITATION OF INCIDENTAL OR
-  CONSEQUENTIAL DAMAGES, SO THIS EXCLUSION AND LIMITATION MAY NOT
-  APPLY TO YOU.
-  
-  8. U.S. GOVERNMENT END USERS.
-  
-  The Covered Software is a "commercial item," as that term is
-  defined in 48 C.F.R. 2.101 (Oct. 1995), consisting of "commercial
-  computer software" (as that term is defined at 48 C.F.R. "
-  252.227-7014(a)(1)) and "commercial computer software
-  documentation" as such terms are used in 48 C.F.R. 12.212 (Sept.
-  1995). Consistent with 48 C.F.R. 12.212 and 48 C.F.R. 227.7202-1
-  through 227.7202-4 (June 1995), all U.S. Government End Users
-  acquire Covered Software with only those rights set forth herein.
-  This U.S. Government Rights clause is in lieu of, and supersedes,
-  any other FAR, DFAR, or other clause or provision that addresses
-  Government rights in computer software under this License.
-  
-  9. MISCELLANEOUS.
-  
-  This License represents the complete agreement concerning subject
-  matter hereof. If any provision of this License is held to be
-  unenforceable, such provision shall be reformed only to the
-  extent necessary to make it enforceable. This License shall be
-  governed by the law of the jurisdiction specified in a notice
-  contained within the Original Software (except to the extent
-  applicable law, if any, provides otherwise), excluding such
-  jurisdiction"s conflict-of-law provisions. Any litigation
-  relating to this License shall be subject to the jurisdiction of
-  the courts located in the jurisdiction and venue specified in a
-  notice contained within the Original Software, with the losing
-  party responsible for costs, including, without limitation, court
-  costs and reasonable attorneys" fees and expenses. The
-  application of the United Nations Convention on Contracts for the
-  International Sale of Goods is expressly excluded. Any law or
-  regulation which provides that the language of a contract shall
-  be construed against the drafter shall not apply to this License.
-  You agree that You alone are responsible for compliance with the
-  United States export administration regulations (and the export
-  control laws and regulation of any other countries) when You use,
-  distribute or otherwise make available any Covered Software.
-  
-  10. RESPONSIBILITY FOR CLAIMS.
-  
-  As between Initial Developer and the Contributors, each party is
-  responsible for claims and damages arising, directly or
-  indirectly, out of its utilization of rights under this License
-  and You agree to work with Initial Developer and Contributors to
-  distribute such responsibility on an equitable basis. Nothing
-  herein is intended or shall be deemed to constitute any admission
-  of liability.
-  
-
-COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.1
-
-  1. Definitions.
-  
-  1.1. “Contributor” means each individual or entity that creates or contributes
-  to the creation of Modifications.
-  
-  1.2. “Contributor Version” means the combination of the Original Software,
-  prior Modifications used by a Contributor (if any), and the Modifications made
-  by that particular Contributor.
-  
-  1.3. “Covered Software” means (a) the Original Software, or (b) Modifications,
-  or (c) the combination of files containing Original Software with files
-  containing Modifications, in each case including portions thereof.
-  
-  1.4. “Executable” means the Covered Software in any form other than Source
-  Code.
-  
-  1.5. “Initial Developer” means the individual or entity that first makes
-  Original Software available under this License.
-  
-  1.6. “Larger Work” means a work which combines Covered Software or portions
-  thereof with code not governed by the terms of this License.
-  
-  1.7. “License” means this document.
-  
-  1.8. “Licensable” means having the right to grant, to the maximum extent
-  possible, whether at the time of the initial grant or subsequently acquired,
-  any and all of the rights conveyed herein.
-  
-  1.9. “Modifications” means the Source Code and Executable form of any of the
-  following:
-  
-  A. Any file that results from an addition to, deletion from or modification of
-  the contents of a file containing Original Software or previous Modifications;
-  
-  B. Any new file that contains any part of the Original Software or previous
-  Modification; or
-  
-  C. Any new file that is contributed or otherwise made available under the terms
-  of this License.
-  
-  1.10. “Original Software” means the Source Code and Executable form of computer
-  software code that is originally released under this License.
-  
-  1.11. “Patent Claims” means any patent claim(s), now owned or hereafter
-  acquired, including without limitation, method, process, and apparatus claims,
-  in any patent Licensable by grantor.
-  
-  1.12. “Source Code” means (a) the common form of computer software code in
-  which modifications are made and (b) associated documentation included in or
-  with such code.
-  
-  1.13. “You” (or “Your”) means an individual or a legal entity exercising rights
-  under, and complying with all of the terms of, this License. For legal
-  entities, “You” includes any entity which controls, is controlled by, or is
-  under common control with You. For purposes of this definition, “control” means
-  (a) the power, direct or indirect, to cause the direction or management of such
-  entity, whether by contract or otherwise, or (b) ownership of more than fifty
-  percent (50%) of the outstanding shares or beneficial ownership of such entity.
-  
-  2. License Grants.
-  
-  2.1. The Initial Developer Grant.  Conditioned upon Your compliance with
-  Section 3.1 below and subject to third party intellectual property claims, the
-  Initial Developer hereby grants You a world-wide, royalty-free, non-exclusive
-  license:
-  
-  (a) under intellectual property rights (other than patent or trademark)
-  Licensable by Initial Developer, to use, reproduce, modify, display, perform,
-  sublicense and distribute the Original Software (or portions thereof), with or
-  without Modifications, and/or as part of a Larger Work; and
-  
-  (b) under Patent Claims infringed by the making, using or selling of Original
-  Software, to make, have made, use, practice, sell, and offer for sale, and/or
-  otherwise dispose of the Original Software (or portions thereof).
-  
-  (c) The licenses granted in Sections 2.1(a) and (b) are effective on the date
-  Initial Developer first distributes or otherwise makes the Original Software
-  available to a third party under the terms of this License.
-  
-  (d) Notwithstanding Section 2.1(b) above, no patent license is granted: (1) for
-  code that You delete from the Original Software, or (2) for infringements
-  caused by: (i) the modification of the Original Software, or (ii) the
-  combination of the Original Software with other software or devices.
-  
-  2.2. Contributor Grant.  Conditioned upon Your compliance with Section 3.1
-  below and subject to third party intellectual property claims, each Contributor
-  hereby grants You a world-wide, royalty-free, non-exclusive license:
-  
-  (a) under intellectual property rights (other than patent or trademark)
-  Licensable by Contributor to use, reproduce, modify, display, perform,
-  sublicense and distribute the Modifications created by such Contributor (or
-  portions thereof), either on an unmodified basis, with other Modifications, as
-  Covered Software and/or as part of a Larger Work; and
-  
-  (b) under Patent Claims infringed by the making, using, or selling of
-  Modifications made by that Contributor either alone and/or in combination with
-  its Contributor Version (or portions of such combination), to make, use, sell,
-  offer for sale, have made, and/or otherwise dispose of: (1) Modifications made
-  by that Contributor (or portions thereof); and (2) the combination of
-  Modifications made by that Contributor with its Contributor Version (or
-  portions of such combination).
-  
-  (c) The licenses granted in Sections 2.2(a) and 2.2(b) are effective on the
-  date Contributor first distributes or otherwise makes the Modifications
-  available to a third party.
-  
-  (d) Notwithstanding Section 2.2(b) above, no patent license is granted: (1) for
-  any code that Contributor has deleted from the Contributor Version; (2) for
-  infringements caused by: (i) third party modifications of Contributor Version,
-  or (ii) the combination of Modifications made by that Contributor with other
-  software (except as part of the Contributor Version) or other devices; or (3)
-  under Patent Claims infringed by Covered Software in the absence of
-  Modifications made by that Contributor.
-  
-  3. Distribution Obligations.
-  
-  3.1. Availability of Source Code.  Any Covered Software that You distribute or
-  otherwise make available in Executable form must also be made available in
-  Source Code form and that Source Code form must be distributed only under the
-  terms of this License. You must include a copy of this License with every copy
-  of the Source Code form of the Covered Software You distribute or otherwise
-  make available. You must inform recipients of any such Covered Software in
-  Executable form as to how they can obtain such Covered Software in Source Code
-  form in a reasonable manner on or through a medium customarily used for
-  software exchange.
-  
-  3.2. Modifications.  The Modifications that You create or to which You
-  contribute are governed by the terms of this License. You represent that You
-  believe Your Modifications are Your original creation(s) and/or You have
-  sufficient rights to grant the rights conveyed by this License.
-  
-  3.3. Required Notices.  You must include a notice in each of Your Modifications
-  that identifies You as the Contributor of the Modification. You may not remove
-  or alter any copyright, patent or trademark notices contained within the
-  Covered Software, or any notices of licensing or any descriptive text giving
-  attribution to any Contributor or the Initial Developer.
-  
-  3.4. Application of Additional Terms.  You may not offer or impose any terms on
-  any Covered Software in Source Code form that alters or restricts the
-  applicable version of this License or the recipients' rights hereunder. You may
-  choose to offer, and to charge a fee for, warranty, support, indemnity or
-  liability obligations to one or more recipients of Covered Software. However,
-  you may do so only on Your own behalf, and not on behalf of the Initial
-  Developer or any Contributor. You must make it absolutely clear that any such
-  warranty, support, indemnity or liability obligation is offered by You alone,
-  and You hereby agree to indemnify the Initial Developer and every Contributor
-  for any liability incurred by the Initial Developer or such Contributor as a
-  result of warranty, support, indemnity or liability terms You offer.
-  
-  3.5. Distribution of Executable Versions.  You may distribute the Executable
-  form of the Covered Software under the terms of this License or under the terms
-  of a license of Your choice, which may contain terms different from this
-  License, provided that You are in compliance with the terms of this License and
-  that the license for the Executable form does not attempt to limit or alter the
-  recipient's rights in the Source Code form from the rights set forth in this
-  License. If You distribute the Covered Software in Executable form under a
-  different license, You must make it absolutely clear that any terms which
-  differ from this License are offered by You alone, not by the Initial Developer
-  or Contributor. You hereby agree to indemnify the Initial Developer and every
-  Contributor for any liability incurred by the Initial Developer or such
-  Contributor as a result of any such terms You offer.
-  
-  3.6. Larger Works.  You may create a Larger Work by combining Covered Software
-  with other code not governed by the terms of this License and distribute the
-  Larger Work as a single product. In such a case, You must make sure the
-  requirements of this License are fulfilled for the Covered Software.
-  
-  4. Versions of the License.
-  
-  4.1. New Versions.  Oracle is the initial license steward and may publish
-  revised and/or new versions of this License from time to time. Each version
-  will be given a distinguishing version number. Except as provided in Section
-  4.3, no one other than the license steward has the right to modify this
-  License.
-  
-  4.2. Effect of New Versions.  You may always continue to use, distribute or
-  otherwise make the Covered Software available under the terms of the version of
-  the License under which You originally received the Covered Software. If the
-  Initial Developer includes a notice in the Original Software prohibiting it
-  from being distributed or otherwise made available under any subsequent version
-  of the License, You must distribute and make the Covered Software available
-  under the terms of the version of the License under which You originally
-  received the Covered Software. Otherwise, You may also choose to use,
-  distribute or otherwise make the Covered Software available under the terms of
-  any subsequent version of the License published by the license steward.
-  
-  4.3. Modified Versions.  When You are an Initial Developer and You want to
-  create a new license for Your Original Software, You may create and use a
-  modified version of this License if You: (a) rename the license and remove any
-  references to the name of the license steward (except to note that the license
-  differs from this License); and (b) otherwise make it clear that the license
-  contains terms which differ from this License.
-  
-  5. DISCLAIMER OF WARRANTY.  COVERED SOFTWARE IS PROVIDED UNDER THIS LICENSE ON
-  AN “AS IS” BASIS, WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED,
-  INCLUDING, WITHOUT LIMITATION, WARRANTIES THAT THE COVERED SOFTWARE IS FREE OF
-  DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR PURPOSE OR NON-INFRINGING. THE
-  ENTIRE RISK AS TO THE QUALITY AND PERFORMANCE OF THE COVERED SOFTWARE IS WITH
-  YOU. SHOULD ANY COVERED SOFTWARE PROVE DEFECTIVE IN ANY RESPECT, YOU (NOT THE
-  INITIAL DEVELOPER OR ANY OTHER CONTRIBUTOR) ASSUME THE COST OF ANY NECESSARY
-  SERVICING, REPAIR OR CORRECTION. THIS DISCLAIMER OF WARRANTY CONSTITUTES AN
-  ESSENTIAL PART OF THIS LICENSE. NO USE OF ANY COVERED SOFTWARE IS AUTHORIZED
-  HEREUNDER EXCEPT UNDER THIS DISCLAIMER.
-  
-  6. TERMINATION.
-  
-  6.1. This License and the rights granted hereunder will terminate automatically
-  if You fail to comply with terms herein and fail to cure such breach within 30
-  days of becoming aware of the breach. Provisions which, by their nature, must
-  remain in effect beyond the termination of this License shall survive.
-  
-  6.2. If You assert a patent infringement claim (excluding declaratory judgment
-  actions) against Initial Developer or a Contributor (the Initial Developer or
-  Contributor against whom You assert such claim is referred to as “Participant”)
-  alleging that the Participant Software (meaning the Contributor Version where
-  the Participant is a Contributor or the Original Software where the Participant
-  is the Initial Developer) directly or indirectly infringes any patent, then any
-  and all rights granted directly or indirectly to You by such Participant, the
-  Initial Developer (if the Initial Developer is not the Participant) and all
-  Contributors under Sections 2.1 and/or 2.2 of this License shall, upon 60 days
-  notice from Participant terminate prospectively and automatically at the
-  expiration of such 60 day notice period, unless if within such 60 day period
-  You withdraw Your claim with respect to the Participant Software against such
-  Participant either unilaterally or pursuant to a written agreement with
-  Participant.
-  
-  6.3. If You assert a patent infringement claim against Participant alleging
-  that the Participant Software directly or indirectly infringes any patent where
-  such claim is resolved (such as by license or settlement) prior to the
-  initiation of patent infringement litigation, then the reasonable value of the
-  licenses granted by such Participant under Sections 2.1 or 2.2 shall be taken
-  into account in determining the amount or value of any payment or license.
-  
-  6.4. In the event of termination under Sections 6.1 or 6.2 above, all end user
-  licenses that have been validly granted by You or any distributor hereunder
-  prior to termination (excluding licenses granted to You by any distributor)
-  shall survive termination.
-  
-  7. LIMITATION OF LIABILITY.
-  
-  UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT (INCLUDING
-  NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE INITIAL DEVELOPER, ANY
-  OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF COVERED SOFTWARE, OR ANY SUPPLIER OF
-  ANY OF SUCH PARTIES, BE LIABLE TO ANY PERSON FOR ANY INDIRECT, SPECIAL,
-  INCIDENTAL, OR CONSEQUENTIAL DAMAGES OF ANY CHARACTER INCLUDING, WITHOUT
-  LIMITATION, DAMAGES FOR LOSS OF GOODWILL, WORK STOPPAGE, COMPUTER FAILURE OR
-  MALFUNCTION, OR ANY AND ALL OTHER COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH
-  PARTY SHALL HAVE BEEN INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS
-  LIMITATION OF LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL
-  INJURY RESULTING FROM SUCH PARTY'S NEGLIGENCE TO THE EXTENT APPLICABLE LAW
-  PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO NOT ALLOW THE EXCLUSION OR
-  LIMITATION OF INCIDENTAL OR CONSEQUENTIAL DAMAGES, SO THIS EXCLUSION AND
-  LIMITATION MAY NOT APPLY TO YOU.
-  
-  8. U.S. GOVERNMENT END USERS.
-  
-  The Covered Software is a “commercial item,” as that term is defined in 48
-  C.F.R. 2.101 (Oct. 1995), consisting of “commercial computer software” (as that
-  term is defined at 48 C.F.R. § 252.227-7014(a)(1)) and “commercial computer
-  software documentation” as such terms are used in 48 C.F.R. 12.212 (Sept.
-  1995). Consistent with 48 C.F.R. 12.212 and 48 C.F.R. 227.7202-1 through
-  227.7202-4 (June 1995), all U.S. Government End Users acquire Covered Software
-  with only those rights set forth herein. This U.S. Government Rights clause is
-  in lieu of, and supersedes, any other FAR, DFAR, or other clause or provision
-  that addresses Government rights in computer software under this License.
-  
-  9. MISCELLANEOUS.
-  
-  This License represents the complete agreement concerning subject matter
-  hereof. If any provision of this License is held to be unenforceable, such
-  provision shall be reformed only to the extent necessary to make it
-  enforceable. This License shall be governed by the law of the jurisdiction
-  specified in a notice contained within the Original Software (except to the
-  extent applicable law, if any, provides otherwise), excluding such
-  jurisdiction's conflict-of-law provisions. Any litigation relating to this
-  License shall be subject to the jurisdiction of the courts located in the
-  jurisdiction and venue specified in a notice contained within the Original
-  Software, with the losing party responsible for costs, including, without
-  limitation, court costs and reasonable attorneys' fees and expenses. The
-  application of the United Nations Convention on Contracts for the International
-  Sale of Goods is expressly excluded. Any law or regulation which provides that
-  the language of a contract shall be construed against the drafter shall not
-  apply to this License. You agree that You alone are responsible for compliance
-  with the United States export administration regulations (and the export
-  control laws and regulation of any other countries) when You use, distribute or
-  otherwise make available any Covered Software.
-  
-  10. RESPONSIBILITY FOR CLAIMS.
-  
-  As between Initial Developer and the Contributors, each party is responsible
-  for claims and damages arising, directly or indirectly, out of its utilization
-  of rights under this License and You agree to work with Initial Developer and
-  Contributors to distribute such responsibility on an equitable basis. Nothing
-  herein is intended or shall be deemed to constitute any admission of liability.
-  
-  NOTICE PURSUANT TO SECTION 9 OF THE COMMON DEVELOPMENT AND DISTRIBUTION LICENSE
-  (CDDL) The code released under the CDDL shall be governed by the laws of the
-  State of California (excluding conflict-of-law provisions). Any litigation
-  relating to this License shall be subject to the jurisdiction of the Federal
-  Courts of the Northern District of California and the state courts of the State
-  of California, with venue lying in Santa Clara County, California.
-
-
-Eclipse Public License, version 1.0
-
-  THE ACCOMPANYING PROGRAM IS PROVIDED UNDER THE TERMS OF THIS ECLIPSE PUBLIC
-  LICENSE ("AGREEMENT"). ANY USE, REPRODUCTION OR DISTRIBUTION OF THE PROGRAM
-  CONSTITUTES RECIPIENT'S ACCEPTANCE OF THIS AGREEMENT.
-  
-  1. DEFINITIONS
-  
-  "Contribution" means:
-  
-  a) in the case of the initial Contributor, the initial code and documentation
-  distributed under this Agreement, and b) in the case of each subsequent
-  Contributor:
-  
-  i) changes to the Program, and
-  
-  ii) additions to the Program;
-  
-  where such changes and/or additions to the Program originate from and are
-  distributed by that particular Contributor. A Contribution 'originates' from a
-  Contributor if it was added to the Program by such Contributor itself or anyone
-  acting on such Contributor's behalf. Contributions do not include additions to
-  the Program which: (i) are separate modules of software distributed in
-  conjunction with the Program under their own license agreement, and (ii) are
-  not derivative works of the Program.
-  
-  "Contributor" means any person or entity that distributes the Program.
-  
-  "Licensed Patents " mean patent claims licensable by a Contributor which are
-  necessarily infringed by the use or sale of its Contribution alone or when
-  combined with the Program.
-  
-  "Program" means the Contributions distributed in accordance with this
-  Agreement.
-  
-  "Recipient" means anyone who receives the Program under this Agreement,
-  including all Contributor

<TRUNCATED>

[42/51] [abbrv] brooklyn-dist git commit: move subdir from incubator up a level as it is promoted to its own repo (first non-incubator commit!)

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/src/main/license/files/LICENSE
----------------------------------------------------------------------
diff --git a/dist/src/main/license/files/LICENSE b/dist/src/main/license/files/LICENSE
new file mode 100644
index 0000000..dd42819
--- /dev/null
+++ b/dist/src/main/license/files/LICENSE
@@ -0,0 +1,2169 @@
+
+This software is distributed under the Apache License, version 2.0. See (1) below.
+This software is copyright (c) The Apache Software Foundation and contributors.
+
+Contents:
+
+  (1) This software license: Apache License, version 2.0
+  (2) Notices for bundled software
+  (3) Licenses for bundled software
+
+
+---------------------------------------------------
+
+(1) This software license: Apache License, version 2.0
+
+
+                                 Apache License
+                           Version 2.0, January 2004
+                        http://www.apache.org/licenses/
+
+   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+
+   1. Definitions.
+
+      "License" shall mean the terms and conditions for use, reproduction,
+      and distribution as defined by Sections 1 through 9 of this document.
+
+      "Licensor" shall mean the copyright owner or entity authorized by
+      the copyright owner that is granting the License.
+
+      "Legal Entity" shall mean the union of the acting entity and all
+      other entities that control, are controlled by, or are under common
+      control with that entity. For the purposes of this definition,
+      "control" means (i) the power, direct or indirect, to cause the
+      direction or management of such entity, whether by contract or
+      otherwise, or (ii) ownership of fifty percent (50%) or more of the
+      outstanding shares, or (iii) beneficial ownership of such entity.
+
+      "You" (or "Your") shall mean an individual or Legal Entity
+      exercising permissions granted by this License.
+
+      "Source" form shall mean the preferred form for making modifications,
+      including but not limited to software source code, documentation
+      source, and configuration files.
+
+      "Object" form shall mean any form resulting from mechanical
+      transformation or translation of a Source form, including but
+      not limited to compiled object code, generated documentation,
+      and conversions to other media types.
+
+      "Work" shall mean the work of authorship, whether in Source or
+      Object form, made available under the License, as indicated by a
+      copyright notice that is included in or attached to the work
+      (an example is provided in the Appendix below).
+
+      "Derivative Works" shall mean any work, whether in Source or Object
+      form, that is based on (or derived from) the Work and for which the
+      editorial revisions, annotations, elaborations, or other modifications
+      represent, as a whole, an original work of authorship. For the purposes
+      of this License, Derivative Works shall not include works that remain
+      separable from, or merely link (or bind by name) to the interfaces of,
+      the Work and Derivative Works thereof.
+
+      "Contribution" shall mean any work of authorship, including
+      the original version of the Work and any modifications or additions
+      to that Work or Derivative Works thereof, that is intentionally
+      submitted to Licensor for inclusion in the Work by the copyright owner
+      or by an individual or Legal Entity authorized to submit on behalf of
+      the copyright owner. For the purposes of this definition, "submitted"
+      means any form of electronic, verbal, or written communication sent
+      to the Licensor or its representatives, including but not limited to
+      communication on electronic mailing lists, source code control systems,
+      and issue tracking systems that are managed by, or on behalf of, the
+      Licensor for the purpose of discussing and improving the Work, but
+      excluding communication that is conspicuously marked or otherwise
+      designated in writing by the copyright owner as "Not a Contribution."
+
+      "Contributor" shall mean Licensor and any individual or Legal Entity
+      on behalf of whom a Contribution has been received by Licensor and
+      subsequently incorporated within the Work.
+
+   2. Grant of Copyright License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      copyright license to reproduce, prepare Derivative Works of,
+      publicly display, publicly perform, sublicense, and distribute the
+      Work and such Derivative Works in Source or Object form.
+
+   3. Grant of Patent License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      (except as stated in this section) patent license to make, have made,
+      use, offer to sell, sell, import, and otherwise transfer the Work,
+      where such license applies only to those patent claims licensable
+      by such Contributor that are necessarily infringed by their
+      Contribution(s) alone or by combination of their Contribution(s)
+      with the Work to which such Contribution(s) was submitted. If You
+      institute patent litigation against any entity (including a
+      cross-claim or counterclaim in a lawsuit) alleging that the Work
+      or a Contribution incorporated within the Work constitutes direct
+      or contributory patent infringement, then any patent licenses
+      granted to You under this License for that Work shall terminate
+      as of the date such litigation is filed.
+
+   4. Redistribution. You may reproduce and distribute copies of the
+      Work or Derivative Works thereof in any medium, with or without
+      modifications, and in Source or Object form, provided that You
+      meet the following conditions:
+
+      (a) You must give any other recipients of the Work or
+          Derivative Works a copy of this License; and
+
+      (b) You must cause any modified files to carry prominent notices
+          stating that You changed the files; and
+
+      (c) You must retain, in the Source form of any Derivative Works
+          that You distribute, all copyright, patent, trademark, and
+          attribution notices from the Source form of the Work,
+          excluding those notices that do not pertain to any part of
+          the Derivative Works; and
+
+      (d) If the Work includes a "NOTICE" text file as part of its
+          distribution, then any Derivative Works that You distribute must
+          include a readable copy of the attribution notices contained
+          within such NOTICE file, excluding those notices that do not
+          pertain to any part of the Derivative Works, in at least one
+          of the following places: within a NOTICE text file distributed
+          as part of the Derivative Works; within the Source form or
+          documentation, if provided along with the Derivative Works; or,
+          within a display generated by the Derivative Works, if and
+          wherever such third-party notices normally appear. The contents
+          of the NOTICE file are for informational purposes only and
+          do not modify the License. You may add Your own attribution
+          notices within Derivative Works that You distribute, alongside
+          or as an addendum to the NOTICE text from the Work, provided
+          that such additional attribution notices cannot be construed
+          as modifying the License.
+
+      You may add Your own copyright statement to Your modifications and
+      may provide additional or different license terms and conditions
+      for use, reproduction, or distribution of Your modifications, or
+      for any such Derivative Works as a whole, provided Your use,
+      reproduction, and distribution of the Work otherwise complies with
+      the conditions stated in this License.
+
+   5. Submission of Contributions. Unless You explicitly state otherwise,
+      any Contribution intentionally submitted for inclusion in the Work
+      by You to the Licensor shall be under the terms and conditions of
+      this License, without any additional terms or conditions.
+      Notwithstanding the above, nothing herein shall supersede or modify
+      the terms of any separate license agreement you may have executed
+      with Licensor regarding such Contributions.
+
+   6. Trademarks. This License does not grant permission to use the trade
+      names, trademarks, service marks, or product names of the Licensor,
+      except as required for reasonable and customary use in describing the
+      origin of the Work and reproducing the content of the NOTICE file.
+
+   7. Disclaimer of Warranty. Unless required by applicable law or
+      agreed to in writing, Licensor provides the Work (and each
+      Contributor provides its Contributions) on an "AS IS" BASIS,
+      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+      implied, including, without limitation, any warranties or conditions
+      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
+      PARTICULAR PURPOSE. You are solely responsible for determining the
+      appropriateness of using or redistributing the Work and assume any
+      risks associated with Your exercise of permissions under this License.
+
+   8. Limitation of Liability. In no event and under no legal theory,
+      whether in tort (including negligence), contract, or otherwise,
+      unless required by applicable law (such as deliberate and grossly
+      negligent acts) or agreed to in writing, shall any Contributor be
+      liable to You for damages, including any direct, indirect, special,
+      incidental, or consequential damages of any character arising as a
+      result of this License or out of the use or inability to use the
+      Work (including but not limited to damages for loss of goodwill,
+      work stoppage, computer failure or malfunction, or any and all
+      other commercial damages or losses), even if such Contributor
+      has been advised of the possibility of such damages.
+
+   9. Accepting Warranty or Additional Liability. While redistributing
+      the Work or Derivative Works thereof, You may choose to offer,
+      and charge a fee for, acceptance of support, warranty, indemnity,
+      or other liability obligations and/or rights consistent with this
+      License. However, in accepting such obligations, You may act only
+      on Your own behalf and on Your sole responsibility, not on behalf
+      of any other Contributor, and only if You agree to indemnify,
+      defend, and hold each Contributor harmless for any liability
+      incurred by, or claims asserted against, such Contributor by reason
+      of your accepting any such warranty or additional liability.
+
+
+---------------------------------------------------
+
+(2) Notices for bundled software
+
+This project includes the software: aopalliance
+  Available at: http://aopalliance.sourceforge.net
+  Version used: 1.0
+  Used under the following license: Public Domain
+
+This project includes the software: asm
+  Available at: http://asm.objectweb.org/
+  Developed by: ObjectWeb (http://www.objectweb.org/)
+  Version used: 3.3.1
+  Used under the following license: BSD License (http://asm.objectweb.org/license.html)
+
+This project includes the software: async.js
+  Available at: https://github.com/p15martin/google-maps-hello-world/blob/master/js/libs/async.js
+  Developed by: Miller Medeiros (https://github.com/millermedeiros/)
+  Version used: 0.1.1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Miller Medeiros (2011)
+
+This project includes the software: backbone.js
+  Available at: http://backbonejs.org
+  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
+  Version used: 1.0.0
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2010-2013)
+
+This project includes the software: bootstrap.js
+  Available at: http://twitter.github.com/bootstrap/javascript.html#transitions
+  Version used: 2.0.4
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+  Copyright (c) Twitter, Inc. (2012)
+
+This project includes the software: ch.qos.logback
+  Available at: http://logback.qos.ch
+  Developed by: QOS.ch (http://www.qos.ch)
+  Version used: 1.0.7
+  Used under the following license: Eclipse Public License, version 1.0 (http://www.eclipse.org/legal/epl-v10.html)
+
+This project includes the software: com.fasterxml.jackson.core
+  Available at: http://github.com/FasterXML/jackson https://github.com/FasterXML/jackson
+  Developed by: FasterXML (http://fasterxml.com/)
+  Version used: 2.4.5
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.fasterxml.jackson.dataformat
+  Available at: https://github.com/FasterXML/jackson http://wiki.fasterxml.com/JacksonExtensionXmlDataBinding
+  Developed by: FasterXML (http://fasterxml.com/)
+  Version used: 2.4.5
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.fasterxml.jackson.datatype
+  Available at: http://wiki.fasterxml.com/JacksonModuleJoda
+  Developed by: FasterXML (http://fasterxml.com/)
+  Version used: 2.4.5
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.fasterxml.jackson.jaxrs
+  Available at: http://wiki.fasterxml.com/JacksonHome
+  Developed by: FasterXML (http://fasterxml.com/)
+  Version used: 2.4.5
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.fasterxml.jackson.module
+  Available at: http://wiki.fasterxml.com/JacksonJAXBAnnotations
+  Developed by: FasterXML (http://fasterxml.com/)
+  Version used: 2.4.5
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.google.code.findbugs
+  Available at: http://findbugs.sourceforge.net/
+  Version used: 2.0.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.google.code.gson
+  Available at: http://code.google.com/p/google-gson/
+  Developed by: Google, Inc. (http://www.google.com)
+  Version used: 2.3
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.google.guava
+  Available at: http://code.google.com/p/guava-libraries
+  Version used: 17.0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.google.http-client
+  Available at: http://code.google.com/p/google-http-java-client/
+  Developed by: Google (http://www.google.com/)
+  Version used: 1.18.0-rc
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.google.inject
+  Available at: http://code.google.com/p/google-guice/
+  Developed by: Google, Inc. (http://www.google.com)
+  Version used: 3.0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.google.inject.extensions
+  Available at: http://code.google.com/p/google-guice/
+  Developed by: Google, Inc. (http://www.google.com)
+  Version used: 3.0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.googlecode.concurrentlinkedhashmap
+  Available at: http://code.google.com/p/concurrentlinkedhashmap
+  Version used: 1.0_jdk5
+  Used under the following license: Apache License (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.jamesmurty.utils
+  Available at: https://github.com/jmurty/java-xmlbuilder
+  Version used: 1.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+
+This project includes the software: com.jayway.jsonpath
+  Available at: https://github.com/jayway/JsonPath
+  Version used: 2.0.0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.jcraft
+  Available at: http://www.jcraft.com/jsch-agent-proxy/
+  Developed by: JCraft,Inc. (http://www.jcraft.com/)
+  Version used: 0.0.8
+  Used under the following license: The BSD 3-Clause (New BSD) License (http://www.jcraft.com/jsch-agent-proxy/LICENSE.txt)
+
+This project includes the software: com.maxmind.db
+  Available at: http://dev.maxmind.com/
+  Developed by: MaxMind, Inc. (http://www.maxmind.com/)
+  Version used: 0.3.4
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.html)
+
+This project includes the software: com.maxmind.geoip2
+  Available at: http://dev.maxmind.com/geoip/geoip2/web-services
+  Developed by: MaxMind, Inc. (http://www.maxmind.com/)
+  Version used: 0.8.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.html)
+
+This project includes the software: com.squareup.okhttp
+  Available at: https://github.com/square/okhttp
+  Version used: 2.2.0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.squareup.okio
+  Available at: https://github.com/square/okio
+  Version used: 1.2.0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.sun.jersey
+  Available at: https://jersey.java.net/
+  Developed by: Oracle Corporation (http://www.oracle.com/)
+  Version used: 1.19
+  Used under the following license: Common Development and Distribution License, version 1.1 (http://glassfish.java.net/public/CDDL+GPL_1_1.html)
+
+This project includes the software: com.sun.jersey.contribs
+  Available at: https://jersey.java.net/
+  Developed by: Oracle Corporation (http://www.oracle.com/)
+  Version used: 1.19
+  Used under the following license: Common Development and Distribution License, version 1.1 (http://glassfish.java.net/public/CDDL+GPL_1_1.html)
+
+This project includes the software: com.thoughtworks.xstream
+  Available at: http://x-stream.github.io/
+  Developed by: XStream (http://xstream.codehaus.org)
+  Version used: 1.4.7
+  Used under the following license: BSD License (http://xstream.codehaus.org/license.html)
+
+This project includes the software: commons-beanutils
+  Available at: http://commons.apache.org/proper/commons-beanutils/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.9.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: commons-codec
+  Available at: http://commons.apache.org/proper/commons-codec/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.9
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: commons-collections
+  Available at: http://commons.apache.org/collections/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 3.2.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: commons-io
+  Available at: http://commons.apache.org/io/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 2.4
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: commons-lang
+  Available at: http://commons.apache.org/lang/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 2.4
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: commons-logging
+  Available at: http://commons.apache.org/proper/commons-logging/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.2
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: dom4j
+  Available at: http://dom4j.sourceforge.net/
+  Developed by: MetaStuff Ltd. (http://sourceforge.net/projects/dom4j)
+  Version used: 1.6.1
+  Used under the following license: MetaStuff BSD style license (3-clause) (http://dom4j.sourceforge.net/dom4j-1.6.1/license.html)
+
+This project includes the software: handlebars.js
+  Available at: https://github.com/wycats/handlebars.js
+  Developed by: Yehuda Katz (https://github.com/wycats/)
+  Inclusive of: handlebars*.js
+  Version used: 1.0-rc1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Yehuda Katz (2012)
+
+This project includes the software: io.airlift
+  Available at: https://github.com/airlift/airline
+  Version used: 0.6
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: io.cloudsoft.windows
+  Available at: http://github.com/cloudsoft/winrm4j
+  Version used: 0.2.0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: io.swagger
+  Available at: https://github.com/swagger-api/swagger-core
+  Version used: 1.5.3
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.html)
+
+This project includes the software: javax.annotation
+  Available at: https://jcp.org/en/jsr/detail?id=250
+  Version used: 1.0
+  Used under the following license: Common Development and Distribution License, version 1.0 (https://glassfish.dev.java.net/public/CDDLv1.0.html)
+
+This project includes the software: javax.inject
+  Available at: http://code.google.com/p/atinject/
+  Version used: 1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: javax.servlet
+  Available at: http://servlet-spec.java.net
+  Developed by: GlassFish Community (https://glassfish.dev.java.net)
+  Version used: 3.1.0
+  Used under the following license: CDDL + GPLv2 with classpath exception (https://glassfish.dev.java.net/nonav/public/CDDL+GPL.html)
+
+This project includes the software: javax.validation
+  Available at: http://beanvalidation.org
+  Version used: 1.1.0.Final
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: javax.ws.rs
+  Available at: https://jsr311.java.net/
+  Developed by: Sun Microsystems, Inc (http://www.sun.com/)
+  Version used: 1.1.1
+  Used under the following license: CDDL License (http://www.opensource.org/licenses/cddl1.php)
+
+This project includes the software: joda-time
+  Available at: http://joda-time.sourceforge.net
+  Developed by: Joda.org (http://www.joda.org)
+  Version used: 2.2
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: jQuery JavaScript Library
+  Available at: http://jquery.com/
+  Developed by: The jQuery Foundation (http://jquery.org/)
+  Inclusive of: jquery.js
+  Version used: 1.7.2
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) John Resig (2005-2011)
+  Includes code fragments from sizzle.js:
+    Copyright (c) The Dojo Foundation
+    Available at http://sizzlejs.com
+    Used under the MIT license
+
+This project includes the software: jQuery BBQ: Back Button & Query Library
+  Available at: http://benalman.com/projects/jquery-bbq-plugin/
+  Developed by: "Cowboy" Ben Alman (http://benalman.com/)
+  Inclusive of: jquery.ba-bbq*.js
+  Version used: 1.2.1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) "Cowboy" Ben Alman (2010)"
+
+This project includes the software: DataTables Table plug-in for jQuery
+  Available at: http://www.datatables.net/
+  Developed by: SpryMedia Ltd (http://sprymedia.co.uk/)
+  Inclusive of: jquery.dataTables.{js,css}
+  Version used: 1.9.4
+  Used under the following license: The BSD 3-Clause (New BSD) License (http://opensource.org/licenses/BSD-3-Clause)
+  Copyright (c) Allan Jardine (2008-2012)
+
+This project includes the software: jQuery Form Plugin
+  Available at: https://github.com/malsup/form
+  Developed by: Mike Alsup (http://malsup.com/)
+  Inclusive of: jquery.form.js
+  Version used: 3.09
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) M. Alsup (2006-2013)
+
+This project includes the software: jQuery Wiggle
+  Available at: https://github.com/jordanthomas/jquery-wiggle
+  Inclusive of: jquery.wiggle.min.js
+  Version used: swagger-ui:1.0.1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) WonderGroup and Jordan Thomas (2010)
+  Previously online at http://labs.wondergroup.com/demos/mini-ui/index.html.
+  The version included here is from the Swagger UI distribution.
+
+This project includes the software: js-uri
+  Available at: http://code.google.com/p/js-uri/
+  Developed by: js-uri contributors (https://code.google.com/js-uri)
+  Inclusive of: URI.js
+  Version used: 0.1
+  Used under the following license: The BSD 3-Clause (New BSD) License (http://opensource.org/licenses/BSD-3-Clause)
+  Copyright (c) js-uri contributors (2013)
+
+This project includes the software: js-yaml.js
+  Available at: https://github.com/nodeca/
+  Developed by: Vitaly Puzrin (https://github.com/nodeca/)
+  Version used: 3.2.7
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Vitaly Puzrin (2011-2015)
+
+This project includes the software: marked.js
+  Available at: https://github.com/chjj/marked
+  Developed by: Christopher Jeffrey (https://github.com/chjj)
+  Version used: 0.3.1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Christopher Jeffrey (2011-2014)
+
+This project includes the software: moment.js
+  Available at: http://momentjs.com
+  Developed by: Tim Wood (http://momentjs.com)
+  Version used: 2.1.0
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Tim Wood, Iskren Chernev, Moment.js contributors (2011-2014)
+
+This project includes the software: net.iharder
+  Available at: http://iharder.net/base64/
+  Version used: 2.3.8
+  Used under the following license: Public domain
+
+This project includes the software: net.java.dev.jna
+  Available at: https://github.com/twall/jna
+  Version used: 4.0.0
+  Used under the following license: Apache License, version 2.0 (http://www.gnu.org/licenses/licenses.html)
+
+This project includes the software: net.minidev
+  Available at: http://www.minidev.net/
+  Developed by: Chemouni Uriel (http://www.minidev.net/)
+  Version used: 2.1.1; 1.0.2
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: net.schmizz
+  Available at: http://github.com/shikhar/sshj
+  Version used: 0.8.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.99soft.guice
+  Available at: http://99soft.github.com/rocoto/
+  Developed by: 99 Software Foundation (http://www.99soft.org/)
+  Version used: 6.2
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.commons
+  Available at: http://commons.apache.org/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 3.3.2; 1.4
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.felix
+  Available at: http://felix.apache.org/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 4.4.0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.httpcomponents
+  Available at: http://hc.apache.org/httpcomponents-client-ga http://hc.apache.org/httpcomponents-core-ga
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 4.4.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.jclouds
+  Available at: http://jclouds.apache.org/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.9.2
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.jclouds.api
+  Available at: http://jclouds.apache.org/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.9.2
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.jclouds.common
+  Available at: http://jclouds.apache.org/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.9.2
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.jclouds.driver
+  Available at: http://jclouds.apache.org/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.9.2
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.jclouds.labs
+  Available at: http://jclouds.apache.org/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.9.2
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.jclouds.provider
+  Available at: http://jclouds.apache.org/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.9.2
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.bouncycastle
+  Available at: http://www.bouncycastle.org/java.html
+  Version used: 1.49
+  Used under the following license: Bouncy Castle Licence (http://www.bouncycastle.org/licence.html)
+
+This project includes the software: org.codehaus.groovy
+  Available at: http://groovy.codehaus.org/
+  Developed by: The Codehaus (http://codehaus.org)
+  Version used: 2.3.7
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.codehaus.jackson
+  Available at: http://jackson.codehaus.org
+  Developed by: FasterXML (http://fasterxml.com)
+  Version used: 1.9.13
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.codehaus.jettison
+  Version used: 1.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+
+This project includes the software: org.codehaus.woodstox
+  Available at: http://wiki.fasterxml.com/WoodstoxStax2
+  Developed by: fasterxml.com (http://fasterxml.com)
+  Version used: 3.1.4
+  Used under the following license: BSD License (http://www.opensource.org/licenses/bsd-license.php)
+
+This project includes the software: org.eclipse.jetty
+  Available at: http://www.eclipse.org/jetty
+  Developed by: Webtide (http://webtide.com)
+  Version used: 9.2.13.v20150730
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+
+This project includes the software: org.eclipse.jetty.toolchain
+  Available at: http://www.eclipse.org/jetty
+  Developed by: Mort Bay Consulting (http://www.mortbay.com)
+  Version used: 3.1.M0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+
+This project includes the software: org.freemarker
+  Available at: http://freemarker.org/
+  Version used: 2.3.22
+  Used under the following license: Apache License, version 2.0 (http://freemarker.org/LICENSE.txt)
+
+This project includes the software: org.glassfish.external
+  Version used: 1.0-b01-ea
+  Used under the following license: Common Development and Distribution License (http://opensource.org/licenses/CDDL-1.0)
+
+This project includes the software: org.hibernate
+  Available at: http://jtidy.sourceforge.net
+  Version used: r8-20060801
+  Used under the following license: Java HTML Tidy License (http://sourceforge.net/p/jtidy/code/HEAD/tree/trunk/jtidy/LICENSE.txt?revision=95)
+
+This project includes the software: org.javassist
+  Available at: http://www.javassist.org/
+  Version used: 3.16.1-GA
+  Used under the following license: Apache License, version 2.0 (http://www.mozilla.org/MPL/MPL-1.1.html)
+
+This project includes the software: org.jvnet.mimepull
+  Available at: http://mimepull.java.net
+  Developed by: Oracle Corporation (http://www.oracle.com/)
+  Version used: 1.9.3
+  Used under the following license: Common Development and Distribution License, version 1.1 (https://glassfish.java.net/public/CDDL+GPL_1_1.html)
+
+This project includes the software: org.mongodb
+  Available at: http://www.mongodb.org
+  Version used: 3.0.3
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.reflections
+  Available at: http://code.google.com/p/reflections/
+  Version used: 0.9.9-RC1
+  Used under the following license: WTFPL (http://www.wtfpl.net/)
+
+This project includes the software: org.slf4j
+  Available at: http://www.slf4j.org
+  Developed by: QOS.ch (http://www.qos.ch)
+  Version used: 1.6.6
+  Used under the following license: The MIT License (http://www.opensource.org/licenses/mit-license.php)
+
+This project includes the software: org.tukaani
+  Available at: http://tukaani.org/xz/java.html
+  Version used: 1.0
+  Used under the following license: Public Domain
+
+This project includes the software: org.yaml
+  Available at: http://www.snakeyaml.org
+  Version used: 1.11
+  Used under the following license: Apache License, version 2.0 (in-project reference: LICENSE.txt)
+
+This project includes the software: RequireJS
+  Available at: http://requirejs.org/
+  Developed by: The Dojo Foundation (http://dojofoundation.org/)
+  Inclusive of: require.js, text.js
+  Version used: 2.0.6
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) The Dojo Foundation (2010-2012)
+
+This project includes the software: RequireJS (r.js maven plugin)
+  Available at: http://github.com/jrburke/requirejs
+  Developed by: The Dojo Foundation (http://dojofoundation.org/)
+  Inclusive of: r.js
+  Version used: 2.1.6
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) The Dojo Foundation (2009-2013)
+  Includes code fragments for source-map and other functionality:
+    Copyright (c) The Mozilla Foundation and contributors (2011)
+    Used under the BSD 2-Clause license.
+  Includes code fragments for parse-js and other functionality:
+    Copyright (c) Mihai Bazon (2010, 2012)
+    Used under the BSD 2-Clause license.
+  Includes code fragments for uglifyjs/consolidator:
+    Copyright (c) Robert Gust-Bardon (2012)
+    Used under the BSD 2-Clause license.
+  Includes code fragments for the esprima parser:
+    Copyright (c):
+      Ariya Hidayat (2011, 2012)
+      Mathias Bynens (2012)
+      Joost-Wim Boekesteijn (2012)
+      Kris Kowal (2012)
+      Yusuke Suzuki (2012)
+      Arpad Borsos (2012)
+    Used under the BSD 2-Clause license.
+
+This project includes the software: Swagger UI
+  Available at: https://github.com/swagger-api/swagger-ui
+  Inclusive of: swagger*.{js,css,html}
+  Version used: 2.1.4
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+  Copyright (c) SmartBear Software (2011-2015)
+
+This project includes the software: typeahead.js
+  Available at: https://github.com/twitter/typeahead.js
+  Developed by: Twitter, Inc (http://twitter.com)
+  Version used: 0.10.5
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Twitter, Inc. and other contributors (2013-2014)
+
+This project includes the software: underscore.js
+  Available at: http://underscorejs.org
+  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
+  Inclusive of: underscore*.{js,map}
+  Version used: 1.4.4
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2009-2013)
+
+This project includes the software: underscore.js:1.7.0
+  Available at: http://underscorejs.org
+  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
+  Inclusive of: underscore*.{js,map}
+  Version used: 1.7.0
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Jeremy Ashkenas, DocumentCloud and Investigative Reporters & Editors (2009-2014)
+
+This project includes the software: xmlpull
+  Available at: http://www.xmlpull.org
+  Version used: 1.1.3.1
+  Used under the following license: Public Domain (http://www.xmlpull.org/v1/download/unpacked/LICENSE.txt)
+
+This project includes the software: xpp3
+  Available at: http://www.extreme.indiana.edu/xgws/xsoap/xpp/mxp1/
+  Developed by: Extreme! Lab, Indiana University (http://www.extreme.indiana.edu/)
+  Version used: 1.1.4c
+  Used under the following license: Indiana University Extreme! Lab Software License, vesion 1.1.1 (https://github.com/apache/openmeetings/blob/a95714ce3f7e587d13d3d0bb3b4f570be15c67a5/LICENSE#L1361)
+
+This project includes the software: ZeroClipboard
+  Available at: http://zeroclipboard.org/
+  Developed by: ZeroClipboard contributors (https://github.com/zeroclipboard)
+  Inclusive of: ZeroClipboard.*
+  Version used: 1.3.1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Jon Rohan, James M. Greene (2014)
+
+
+---------------------------------------------------
+
+(3) Licenses for bundled software
+
+Contents:
+
+  Apache License, Version 2.0
+  The BSD 2-Clause License
+  The BSD 3-Clause License ("New BSD")
+  COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.0
+  COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.1
+  Eclipse Public License, version 1.0
+  The MIT License ("MIT")
+  WTF Public License
+  Bouncy Castle License
+  JTidy License
+  Jython License
+  MetaStuff BSD Style License
+  Indiana University Extreme! Lab Software License, Version 1.1.1
+
+
+Apache License, Version 2.0
+
+  Apache License
+  Version 2.0, January 2004
+  http://www.apache.org/licenses/
+  
+  TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+  
+  1. Definitions.
+  
+  "License" shall mean the terms and conditions for use, reproduction,
+  and distribution as defined by Sections 1 through 9 of this document.
+  
+  "Licensor" shall mean the copyright owner or entity authorized by
+  the copyright owner that is granting the License.
+  
+  "Legal Entity" shall mean the union of the acting entity and all
+  other entities that control, are controlled by, or are under common
+  control with that entity. For the purposes of this definition,
+  "control" means (i) the power, direct or indirect, to cause the
+  direction or management of such entity, whether by contract or
+  otherwise, or (ii) ownership of fifty percent (50%) or more of the
+  outstanding shares, or (iii) beneficial ownership of such entity.
+  
+  "You" (or "Your") shall mean an individual or Legal Entity
+  exercising permissions granted by this License.
+  
+  "Source" form shall mean the preferred form for making modifications,
+  including but not limited to software source code, documentation
+  source, and configuration files.
+  
+  "Object" form shall mean any form resulting from mechanical
+  transformation or translation of a Source form, including but
+  not limited to compiled object code, generated documentation,
+  and conversions to other media types.
+  
+  "Work" shall mean the work of authorship, whether in Source or
+  Object form, made available under the License, as indicated by a
+  copyright notice that is included in or attached to the work
+  (an example is provided in the Appendix below).
+  
+  "Derivative Works" shall mean any work, whether in Source or Object
+  form, that is based on (or derived from) the Work and for which the
+  editorial revisions, annotations, elaborations, or other modifications
+  represent, as a whole, an original work of authorship. For the purposes
+  of this License, Derivative Works shall not include works that remain
+  separable from, or merely link (or bind by name) to the interfaces of,
+  the Work and Derivative Works thereof.
+  
+  "Contribution" shall mean any work of authorship, including
+  the original version of the Work and any modifications or additions
+  to that Work or Derivative Works thereof, that is intentionally
+  submitted to Licensor for inclusion in the Work by the copyright owner
+  or by an individual or Legal Entity authorized to submit on behalf of
+  the copyright owner. For the purposes of this definition, "submitted"
+  means any form of electronic, verbal, or written communication sent
+  to the Licensor or its representatives, including but not limited to
+  communication on electronic mailing lists, source code control systems,
+  and issue tracking systems that are managed by, or on behalf of, the
+  Licensor for the purpose of discussing and improving the Work, but
+  excluding communication that is conspicuously marked or otherwise
+  designated in writing by the copyright owner as "Not a Contribution."
+  
+  "Contributor" shall mean Licensor and any individual or Legal Entity
+  on behalf of whom a Contribution has been received by Licensor and
+  subsequently incorporated within the Work.
+  
+  2. Grant of Copyright License. Subject to the terms and conditions of
+  this License, each Contributor hereby grants to You a perpetual,
+  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+  copyright license to reproduce, prepare Derivative Works of,
+  publicly display, publicly perform, sublicense, and distribute the
+  Work and such Derivative Works in Source or Object form.
+  
+  3. Grant of Patent License. Subject to the terms and conditions of
+  this License, each Contributor hereby grants to You a perpetual,
+  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+  (except as stated in this section) patent license to make, have made,
+  use, offer to sell, sell, import, and otherwise transfer the Work,
+  where such license applies only to those patent claims licensable
+  by such Contributor that are necessarily infringed by their
+  Contribution(s) alone or by combination of their Contribution(s)
+  with the Work to which such Contribution(s) was submitted. If You
+  institute patent litigation against any entity (including a
+  cross-claim or counterclaim in a lawsuit) alleging that the Work
+  or a Contribution incorporated within the Work constitutes direct
+  or contributory patent infringement, then any patent licenses
+  granted to You under this License for that Work shall terminate
+  as of the date such litigation is filed.
+  
+  4. Redistribution. You may reproduce and distribute copies of the
+  Work or Derivative Works thereof in any medium, with or without
+  modifications, and in Source or Object form, provided that You
+  meet the following conditions:
+  
+  (a) You must give any other recipients of the Work or
+  Derivative Works a copy of this License; and
+  
+  (b) You must cause any modified files to carry prominent notices
+  stating that You changed the files; and
+  
+  (c) You must retain, in the Source form of any Derivative Works
+  that You distribute, all copyright, patent, trademark, and
+  attribution notices from the Source form of the Work,
+  excluding those notices that do not pertain to any part of
+  the Derivative Works; and
+  
+  (d) If the Work includes a "NOTICE" text file as part of its
+  distribution, then any Derivative Works that You distribute must
+  include a readable copy of the attribution notices contained
+  within such NOTICE file, excluding those notices that do not
+  pertain to any part of the Derivative Works, in at least one
+  of the following places: within a NOTICE text file distributed
+  as part of the Derivative Works; within the Source form or
+  documentation, if provided along with the Derivative Works; or,
+  within a display generated by the Derivative Works, if and
+  wherever such third-party notices normally appear. The contents
+  of the NOTICE file are for informational purposes only and
+  do not modify the License. You may add Your own attribution
+  notices within Derivative Works that You distribute, alongside
+  or as an addendum to the NOTICE text from the Work, provided
+  that such additional attribution notices cannot be construed
+  as modifying the License.
+  
+  You may add Your own copyright statement to Your modifications and
+  may provide additional or different license terms and conditions
+  for use, reproduction, or distribution of Your modifications, or
+  for any such Derivative Works as a whole, provided Your use,
+  reproduction, and distribution of the Work otherwise complies with
+  the conditions stated in this License.
+  
+  5. Submission of Contributions. Unless You explicitly state otherwise,
+  any Contribution intentionally submitted for inclusion in the Work
+  by You to the Licensor shall be under the terms and conditions of
+  this License, without any additional terms or conditions.
+  Notwithstanding the above, nothing herein shall supersede or modify
+  the terms of any separate license agreement you may have executed
+  with Licensor regarding such Contributions.
+  
+  6. Trademarks. This License does not grant permission to use the trade
+  names, trademarks, service marks, or product names of the Licensor,
+  except as required for reasonable and customary use in describing the
+  origin of the Work and reproducing the content of the NOTICE file.
+  
+  7. Disclaimer of Warranty. Unless required by applicable law or
+  agreed to in writing, Licensor provides the Work (and each
+  Contributor provides its Contributions) on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+  implied, including, without limitation, any warranties or conditions
+  of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
+  PARTICULAR PURPOSE. You are solely responsible for determining the
+  appropriateness of using or redistributing the Work and assume any
+  risks associated with Your exercise of permissions under this License.
+  
+  8. Limitation of Liability. In no event and under no legal theory,
+  whether in tort (including negligence), contract, or otherwise,
+  unless required by applicable law (such as deliberate and grossly
+  negligent acts) or agreed to in writing, shall any Contributor be
+  liable to You for damages, including any direct, indirect, special,
+  incidental, or consequential damages of any character arising as a
+  result of this License or out of the use or inability to use the
+  Work (including but not limited to damages for loss of goodwill,
+  work stoppage, computer failure or malfunction, or any and all
+  other commercial damages or losses), even if such Contributor
+  has been advised of the possibility of such damages.
+  
+  9. Accepting Warranty or Additional Liability. While redistributing
+  the Work or Derivative Works thereof, You may choose to offer,
+  and charge a fee for, acceptance of support, warranty, indemnity,
+  or other liability obligations and/or rights consistent with this
+  License. However, in accepting such obligations, You may act only
+  on Your own behalf and on Your sole responsibility, not on behalf
+  of any other Contributor, and only if You agree to indemnify,
+  defend, and hold each Contributor harmless for any liability
+  incurred by, or claims asserted against, such Contributor by reason
+  of your accepting any such warranty or additional liability.
+  
+
+The BSD 2-Clause License
+
+  Redistribution and use in source and binary forms, with or without
+  modification, are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, this
+  list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice,
+  this list of conditions and the following disclaimer in the documentation
+  and/or other materials provided with the distribution.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
+  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
+  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
+  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
+  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
+  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
+  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
+  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
+  
+
+The BSD 3-Clause License ("New BSD")
+
+  Redistribution and use in source and binary forms, with or without modification,
+  are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, 
+  this list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice, 
+  this list of conditions and the following disclaimer in the documentation 
+  and/or other materials provided with the distribution.
+  
+  3. Neither the name of the copyright holder nor the names of its contributors 
+  may be used to endorse or promote products derived from this software without 
+  specific prior written permission.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
+  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
+  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
+  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
+  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
+  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
+  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
+  POSSIBILITY OF SUCH DAMAGE.
+  
+
+COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.0
+
+  1. Definitions.
+  
+  1.1. "Contributor" means each individual or entity that
+  creates or contributes to the creation of Modifications.
+  
+  1.2. "Contributor Version" means the combination of the
+  Original Software, prior Modifications used by a
+  Contributor (if any), and the Modifications made by that
+  particular Contributor.
+  
+  1.3. "Covered Software" means (a) the Original Software, or
+  (b) Modifications, or (c) the combination of files
+  containing Original Software with files containing
+  Modifications, in each case including portions thereof.
+  
+  1.4. "Executable" means the Covered Software in any form
+  other than Source Code. 
+  
+  1.5. "Initial Developer" means the individual or entity
+  that first makes Original Software available under this
+  License. 
+  
+  1.6. "Larger Work" means a work which combines Covered
+  Software or portions thereof with code not governed by the
+  terms of this License.
+  
+  1.7. "License" means this document.
+  
+  1.8. "Licensable" means having the right to grant, to the
+  maximum extent possible, whether at the time of the initial
+  grant or subsequently acquired, any and all of the rights
+  conveyed herein.
+  
+  1.9. "Modifications" means the Source Code and Executable
+  form of any of the following: 
+  
+  A. Any file that results from an addition to,
+  deletion from or modification of the contents of a
+  file containing Original Software or previous
+  Modifications; 
+  
+  B. Any new file that contains any part of the
+  Original Software or previous Modification; or 
+  
+  C. Any new file that is contributed or otherwise made
+  available under the terms of this License.
+  
+  1.10. "Original Software" means the Source Code and
+  Executable form of computer software code that is
+  originally released under this License. 
+  
+  1.11. "Patent Claims" means any patent claim(s), now owned
+  or hereafter acquired, including without limitation,
+  method, process, and apparatus claims, in any patent
+  Licensable by grantor. 
+  
+  1.12. "Source Code" means (a) the common form of computer
+  software code in which modifications are made and (b)
+  associated documentation included in or with such code.
+  
+  1.13. "You" (or "Your") means an individual or a legal
+  entity exercising rights under, and complying with all of
+  the terms of, this License. For legal entities, "You"
+  includes any entity which controls, is controlled by, or is
+  under common control with You. For purposes of this
+  definition, "control" means (a) the power, direct or
+  indirect, to cause the direction or management of such
+  entity, whether by contract or otherwise, or (b) ownership
+  of more than fifty percent (50%) of the outstanding shares
+  or beneficial ownership of such entity.
+  
+  2. License Grants. 
+  
+  2.1. The Initial Developer Grant.
+  
+  Conditioned upon Your compliance with Section 3.1 below and
+  subject to third party intellectual property claims, the
+  Initial Developer hereby grants You a world-wide,
+  royalty-free, non-exclusive license: 
+  
+  (a) under intellectual property rights (other than
+  patent or trademark) Licensable by Initial Developer,
+  to use, reproduce, modify, display, perform,
+  sublicense and distribute the Original Software (or
+  portions thereof), with or without Modifications,
+  and/or as part of a Larger Work; and 
+  
+  (b) under Patent Claims infringed by the making,
+  using or selling of Original Software, to make, have
+  made, use, practice, sell, and offer for sale, and/or
+  otherwise dispose of the Original Software (or
+  portions thereof). 
+  
+  (c) The licenses granted in Sections 2.1(a) and (b)
+  are effective on the date Initial Developer first
+  distributes or otherwise makes the Original Software
+  available to a third party under the terms of this
+  License. 
+  
+  (d) Notwithstanding Section 2.1(b) above, no patent
+  license is granted: (1) for code that You delete from
+  the Original Software, or (2) for infringements
+  caused by: (i) the modification of the Original
+  Software, or (ii) the combination of the Original
+  Software with other software or devices. 
+  
+  2.2. Contributor Grant.
+  
+  Conditioned upon Your compliance with Section 3.1 below and
+  subject to third party intellectual property claims, each
+  Contributor hereby grants You a world-wide, royalty-free,
+  non-exclusive license:
+  
+  (a) under intellectual property rights (other than
+  patent or trademark) Licensable by Contributor to
+  use, reproduce, modify, display, perform, sublicense
+  and distribute the Modifications created by such
+  Contributor (or portions thereof), either on an
+  unmodified basis, with other Modifications, as
+  Covered Software and/or as part of a Larger Work; and
+  
+  (b) under Patent Claims infringed by the making,
+  using, or selling of Modifications made by that
+  Contributor either alone and/or in combination with
+  its Contributor Version (or portions of such
+  combination), to make, use, sell, offer for sale,
+  have made, and/or otherwise dispose of: (1)
+  Modifications made by that Contributor (or portions
+  thereof); and (2) the combination of Modifications
+  made by that Contributor with its Contributor Version
+  (or portions of such combination). 
+  
+  (c) The licenses granted in Sections 2.2(a) and
+  2.2(b) are effective on the date Contributor first
+  distributes or otherwise makes the Modifications
+  available to a third party. 
+  
+  (d) Notwithstanding Section 2.2(b) above, no patent
+  license is granted: (1) for any code that Contributor
+  has deleted from the Contributor Version; (2) for
+  infringements caused by: (i) third party
+  modifications of Contributor Version, or (ii) the
+  combination of Modifications made by that Contributor
+  with other software (except as part of the
+  Contributor Version) or other devices; or (3) under
+  Patent Claims infringed by Covered Software in the
+  absence of Modifications made by that Contributor. 
+  
+  3. Distribution Obligations.
+  
+  3.1. Availability of Source Code.
+  
+  Any Covered Software that You distribute or otherwise make
+  available in Executable form must also be made available in
+  Source Code form and that Source Code form must be
+  distributed only under the terms of this License. You must
+  include a copy of this License with every copy of the
+  Source Code form of the Covered Software You distribute or
+  otherwise make available. You must inform recipients of any
+  such Covered Software in Executable form as to how they can
+  obtain such Covered Software in Source Code form in a
+  reasonable manner on or through a medium customarily used
+  for software exchange.
+  
+  3.2. Modifications.
+  
+  The Modifications that You create or to which You
+  contribute are governed by the terms of this License. You
+  represent that You believe Your Modifications are Your
+  original creation(s) and/or You have sufficient rights to
+  grant the rights conveyed by this License.
+  
+  3.3. Required Notices.
+  
+  You must include a notice in each of Your Modifications
+  that identifies You as the Contributor of the Modification.
+  You may not remove or alter any copyright, patent or
+  trademark notices contained within the Covered Software, or
+  any notices of licensing or any descriptive text giving
+  attribution to any Contributor or the Initial Developer.
+  
+  3.4. Application of Additional Terms.
+  
+  You may not offer or impose any terms on any Covered
+  Software in Source Code form that alters or restricts the
+  applicable version of this License or the recipients"
+  rights hereunder. You may choose to offer, and to charge a
+  fee for, warranty, support, indemnity or liability
+  obligations to one or more recipients of Covered Software.
+  However, you may do so only on Your own behalf, and not on
+  behalf of the Initial Developer or any Contributor. You
+  must make it absolutely clear that any such warranty,
+  support, indemnity or liability obligation is offered by
+  You alone, and You hereby agree to indemnify the Initial
+  Developer and every Contributor for any liability incurred
+  by the Initial Developer or such Contributor as a result of
+  warranty, support, indemnity or liability terms You offer.
+      
+  3.5. Distribution of Executable Versions.
+  
+  You may distribute the Executable form of the Covered
+  Software under the terms of this License or under the terms
+  of a license of Your choice, which may contain terms
+  different from this License, provided that You are in
+  compliance with the terms of this License and that the
+  license for the Executable form does not attempt to limit
+  or alter the recipient"s rights in the Source Code form
+  from the rights set forth in this License. If You
+  distribute the Covered Software in Executable form under a
+  different license, You must make it absolutely clear that
+  any terms which differ from this License are offered by You
+  alone, not by the Initial Developer or Contributor. You
+  hereby agree to indemnify the Initial Developer and every
+  Contributor for any liability incurred by the Initial
+  Developer or such Contributor as a result of any such terms
+  You offer.
+  
+  3.6. Larger Works.
+  
+  You may create a Larger Work by combining Covered Software
+  with other code not governed by the terms of this License
+  and distribute the Larger Work as a single product. In such
+  a case, You must make sure the requirements of this License
+  are fulfilled for the Covered Software. 
+  
+  4. Versions of the License. 
+  
+  4.1. New Versions.
+  
+  Sun Microsystems, Inc. is the initial license steward and
+  may publish revised and/or new versions of this License
+  from time to time. Each version will be given a
+  distinguishing version number. Except as provided in
+  Section 4.3, no one other than the license steward has the
+  right to modify this License. 
+  
+  4.2. Effect of New Versions.
+  
+  You may always continue to use, distribute or otherwise
+  make the Covered Software available under the terms of the
+  version of the License under which You originally received
+  the Covered Software. If the Initial Developer includes a
+  notice in the Original Software prohibiting it from being
+  distributed or otherwise made available under any
+  subsequent version of the License, You must distribute and
+  make the Covered Software available under the terms of the
+  version of the License under which You originally received
+  the Covered Software. Otherwise, You may also choose to
+  use, distribute or otherwise make the Covered Software
+  available under the terms of any subsequent version of the
+  License published by the license steward. 
+  
+  4.3. Modified Versions.
+  
+  When You are an Initial Developer and You want to create a
+  new license for Your Original Software, You may create and
+  use a modified version of this License if You: (a) rename
+  the license and remove any references to the name of the
+  license steward (except to note that the license differs
+  from this License); and (b) otherwise make it clear that
+  the license contains terms which differ from this License.
+  
+  5. DISCLAIMER OF WARRANTY.
+  
+  COVERED SOFTWARE IS PROVIDED UNDER THIS LICENSE ON AN "AS IS"
+  BASIS, WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED,
+  INCLUDING, WITHOUT LIMITATION, WARRANTIES THAT THE COVERED
+  SOFTWARE IS FREE OF DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR
+  PURPOSE OR NON-INFRINGING. THE ENTIRE RISK AS TO THE QUALITY AND
+  PERFORMANCE OF THE COVERED SOFTWARE IS WITH YOU. SHOULD ANY
+  COVERED SOFTWARE PROVE DEFECTIVE IN ANY RESPECT, YOU (NOT THE
+  INITIAL DEVELOPER OR ANY OTHER CONTRIBUTOR) ASSUME THE COST OF
+  ANY NECESSARY SERVICING, REPAIR OR CORRECTION. THIS DISCLAIMER OF
+  WARRANTY CONSTITUTES AN ESSENTIAL PART OF THIS LICENSE. NO USE OF
+  ANY COVERED SOFTWARE IS AUTHORIZED HEREUNDER EXCEPT UNDER THIS
+  DISCLAIMER. 
+  
+  6. TERMINATION. 
+  
+  6.1. This License and the rights granted hereunder will
+  terminate automatically if You fail to comply with terms
+  herein and fail to cure such breach within 30 days of
+  becoming aware of the breach. Provisions which, by their
+  nature, must remain in effect beyond the termination of
+  this License shall survive.
+  
+  6.2. If You assert a patent infringement claim (excluding
+  declaratory judgment actions) against Initial Developer or
+  a Contributor (the Initial Developer or Contributor against
+  whom You assert such claim is referred to as "Participant")
+  alleging that the Participant Software (meaning the
+  Contributor Version where the Participant is a Contributor
+  or the Original Software where the Participant is the
+  Initial Developer) directly or indirectly infringes any
+  patent, then any and all rights granted directly or
+  indirectly to You by such Participant, the Initial
+  Developer (if the Initial Developer is not the Participant)
+  and all Contributors under Sections 2.1 and/or 2.2 of this
+  License shall, upon 60 days notice from Participant
+  terminate prospectively and automatically at the expiration
+  of such 60 day notice period, unless if within such 60 day
+  period You withdraw Your claim with respect to the
+  Participant Software against such Participant either
+  unilaterally or pursuant to a written agreement with
+  Participant.
+  
+  6.3. In the event of termination under Sections 6.1 or 6.2
+  above, all end user licenses that have been validly granted
+  by You or any distributor hereunder prior to termination
+  (excluding licenses granted to You by any distributor)
+  shall survive termination.
+  
+  7. LIMITATION OF LIABILITY.
+  
+  UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT
+  (INCLUDING NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE
+  INITIAL DEVELOPER, ANY OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF
+  COVERED SOFTWARE, OR ANY SUPPLIER OF ANY OF SUCH PARTIES, BE
+  LIABLE TO ANY PERSON FOR ANY INDIRECT, SPECIAL, INCIDENTAL, OR
+  CONSEQUENTIAL DAMAGES OF ANY CHARACTER INCLUDING, WITHOUT
+  LIMITATION, DAMAGES FOR LOST PROFITS, LOSS OF GOODWILL, WORK
+  STOPPAGE, COMPUTER FAILURE OR MALFUNCTION, OR ANY AND ALL OTHER
+  COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH PARTY SHALL HAVE BEEN
+  INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS LIMITATION OF
+  LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL
+  INJURY RESULTING FROM SUCH PARTY"S NEGLIGENCE TO THE EXTENT
+  APPLICABLE LAW PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO
+  NOT ALLOW THE EXCLUSION OR LIMITATION OF INCIDENTAL OR
+  CONSEQUENTIAL DAMAGES, SO THIS EXCLUSION AND LIMITATION MAY NOT
+  APPLY TO YOU.
+  
+  8. U.S. GOVERNMENT END USERS.
+  
+  The Covered Software is a "commercial item," as that term is
+  defined in 48 C.F.R. 2.101 (Oct. 1995), consisting of "commercial
+  computer software" (as that term is defined at 48 C.F.R. "
+  252.227-7014(a)(1)) and "commercial computer software
+  documentation" as such terms are used in 48 C.F.R. 12.212 (Sept.
+  1995). Consistent with 48 C.F.R. 12.212 and 48 C.F.R. 227.7202-1
+  through 227.7202-4 (June 1995), all U.S. Government End Users
+  acquire Covered Software with only those rights set forth herein.
+  This U.S. Government Rights clause is in lieu of, and supersedes,
+  any other FAR, DFAR, or other clause or provision that addresses
+  Government rights in computer software under this License.
+  
+  9. MISCELLANEOUS.
+  
+  This License represents the complete agreement concerning subject
+  matter hereof. If any provision of this License is held to be
+  unenforceable, such provision shall be reformed only to the
+  extent necessary to make it enforceable. This License shall be
+  governed by the law of the jurisdiction specified in a notice
+  contained within the Original Software (except to the extent
+  applicable law, if any, provides otherwise), excluding such
+  jurisdiction"s conflict-of-law provisions. Any litigation
+  relating to this License shall be subject to the jurisdiction of
+  the courts located in the jurisdiction and venue specified in a
+  notice contained within the Original Software, with the losing
+  party responsible for costs, including, without limitation, court
+  costs and reasonable attorneys" fees and expenses. The
+  application of the United Nations Convention on Contracts for the
+  International Sale of Goods is expressly excluded. Any law or
+  regulation which provides that the language of a contract shall
+  be construed against the drafter shall not apply to this License.
+  You agree that You alone are responsible for compliance with the
+  United States export administration regulations (and the export
+  control laws and regulation of any other countries) when You use,
+  distribute or otherwise make available any Covered Software.
+  
+  10. RESPONSIBILITY FOR CLAIMS.
+  
+  As between Initial Developer and the Contributors, each party is
+  responsible for claims and damages arising, directly or
+  indirectly, out of its utilization of rights under this License
+  and You agree to work with Initial Developer and Contributors to
+  distribute such responsibility on an equitable basis. Nothing
+  herein is intended or shall be deemed to constitute any admission
+  of liability.
+  
+
+COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.1
+
+  1. Definitions.
+  
+  1.1. “Contributor” means each individual or entity that creates or contributes
+  to the creation of Modifications.
+  
+  1.2. “Contributor Version” means the combination of the Original Software,
+  prior Modifications used by a Contributor (if any), and the Modifications made
+  by that particular Contributor.
+  
+  1.3. “Covered Software” means (a) the Original Software, or (b) Modifications,
+  or (c) the combination of files containing Original Software with files
+  containing Modifications, in each case including portions thereof.
+  
+  1.4. “Executable” means the Covered Software in any form other than Source
+  Code.
+  
+  1.5. “Initial Developer” means the individual or entity that first makes
+  Original Software available under this License.
+  
+  1.6. “Larger Work” means a work which combines Covered Software or portions
+  thereof with code not governed by the terms of this License.
+  
+  1.7. “License” means this document.
+  
+  1.8. “Licensable” means having the right to grant, to the maximum extent
+  possible, whether at the time of the initial grant or subsequently acquired,
+  any and all of the rights conveyed herein.
+  
+  1.9. “Modifications” means the Source Code and Executable form of any of the
+  following:
+  
+  A. Any file that results from an addition to, deletion from or modification of
+  the contents of a file containing Original Software or previous Modifications;
+  
+  B. Any new file that contains any part of the Original Software or previous
+  Modification; or
+  
+  C. Any new file that is contributed or otherwise made available under the terms
+  of this License.
+  
+  1.10. “Original Software” means the Source Code and Executable form of computer
+  software code that is originally released under this License.
+  
+  1.11. “Patent Claims” means any patent claim(s), now owned or hereafter
+  acquired, including without limitation, method, process, and apparatus claims,
+  in any patent Licensable by grantor.
+  
+  1.12. “Source Code” means (a) the common form of computer software code in
+  which modifications are made and (b) associated documentation included in or
+  with such code.
+  
+  1.13. “You” (or “Your”) means an individual or a legal entity exercising rights
+  under, and complying with all of the terms of, this License. For legal
+  entities, “You” includes any entity which controls, is controlled by, or is
+  under common control with You. For purposes of this definition, “control” means
+  (a) the power, direct or indirect, to cause the direction or management of such
+  entity, whether by contract or otherwise, or (b) ownership of more than fifty
+  percent (50%) of the outstanding shares or beneficial ownership of such entity.
+  
+  2. License Grants.
+  
+  2.1. The Initial Developer Grant.  Conditioned upon Your compliance with
+  Section 3.1 below and subject to third party intellectual property claims, the
+  Initial Developer hereby grants You a world-wide, royalty-free, non-exclusive
+  license:
+  
+  (a) under intellectual property rights (other than patent or trademark)
+  Licensable by Initial Developer, to use, reproduce, modify, display, perform,
+  sublicense and distribute the Original Software (or portions thereof), with or
+  without Modifications, and/or as part of a Larger Work; and
+  
+  (b) under Patent Claims infringed by the making, using or selling of Original
+  Software, to make, have made, use, practice, sell, and offer for sale, and/or
+  otherwise dispose of the Original Software (or portions thereof).
+  
+  (c) The licenses granted in Sections 2.1(a) and (b) are effective on the date
+  Initial Developer first distributes or otherwise makes the Original Software
+  available to a third party under the terms of this License.
+  
+  (d) Notwithstanding Section 2.1(b) above, no patent license is granted: (1) for
+  code that You delete from the Original Software, or (2) for infringements
+  caused by: (i) the modification of the Original Software, or (ii) the
+  combination of the Original Software with other software or devices.
+  
+  2.2. Contributor Grant.  Conditioned upon Your compliance with Section 3.1
+  below and subject to third party intellectual property claims, each Contributor
+  hereby grants You a world-wide, royalty-free, non-exclusive license:
+  
+  (a) under intellectual property rights (other than patent or trademark)
+  Licensable by Contributor to use, reproduce, modify, display, perform,
+  sublicense and distribute the Modifications created by such Contributor (or
+  portions thereof), either on an unmodified basis, with other Modifications, as
+  Covered Software and/or as part of a Larger Work; and
+  
+  (b) under Patent Claims infringed by the making, using, or selling of
+  Modifications made by that Contributor either alone and/or in combination with
+  its Contributor Version (or portions of such combination), to make, use, sell,
+  offer for sale, have made, and/or otherwise dispose of: (1) Modifications made
+  by that Contributor (or portions thereof); and (2) the combination of
+  Modifications made by that Contributor with its Contributor Version (or
+  portions of such combination).
+  
+  (c) The licenses granted in Sections 2.2(a) and 2.2(b) are effective on the
+  date Contributor first distributes or otherwise makes the Modifications
+  available to a third party.
+  
+  (d) Notwithstanding Section 2.2(b) above, no patent license is granted: (1) for
+  any code that Contributor has deleted from the Contributor Version; (2) for
+  infringements caused by: (i) third party modifications of Contributor Version,
+  or (ii) the combination of Modifications made by that Contributor with other
+  software (except as part of the Contributor Version) or other devices; or (3)
+  under Patent Claims infringed by Covered Software in the absence of
+  Modifications made by that Contributor.
+  
+  3. Distribution Obligations.
+  
+  3.1. Availability of Source Code.  Any Covered Software that You distribute or
+  otherwise make available in Executable form must also be made available in
+  Source Code form and that Source Code form must be distributed only under the
+  terms of this License. You must include a copy of this License with every copy
+  of the Source Code form of the Covered Software You distribute or otherwise
+  make available. You must inform recipients of any such Covered Software in
+  Executable form as to how they can obtain such Covered Software in Source Code
+  form in a reasonable manner on or through a medium customarily used for
+  software exchange.
+  
+  3.2. Modifications.  The Modifications that You create or to which You
+  contribute are governed by the terms of this License. You represent that You
+  believe Your Modifications are Your original creation(s) and/or You have
+  sufficient rights to grant the rights conveyed by this License.
+  
+  3.3. Required Notices.  You must include a notice in each of Your Modifications
+  that identifies You as the Contributor of the Modification. You may not remove
+  or alter any copyright, patent or trademark notices contained within the
+  Covered Software, or any notices of licensing or any descriptive text giving
+  attribution to any Contributor or the Initial Developer.
+  
+  3.4. Application of Additional Terms.  You may not offer or impose any terms on
+  any Covered Software in Source Code form that alters or restricts the
+  applicable version of this License or the recipients' rights hereunder. You may
+  choose to offer, and to charge a fee for, warranty, support, indemnity or
+  liability obligations to one or more recipients of Covered Software. However,
+  you may do so only on Your own behalf, and not on behalf of the Initial
+  Developer or any Contributor. You must make it absolutely clear that any such
+  warranty, support, indemnity or liability obligation is offered by You alone,
+  and You hereby agree to indemnify the Initial Developer and every Contributor
+  for any liability incurred by the Initial Developer or such Contributor as a
+  result of warranty, support, indemnity or liability terms You offer.
+  
+  3.5. Distribution of Executable Versions.  You may distribute the Executable
+  form of the Covered Software under the terms of this License or under the terms
+  of a license of Your choice, which may contain terms different from this
+  License, provided that You are in compliance with the terms of this License and
+  that the license for the Executable form does not attempt to limit or alter the
+  recipient's rights in the Source Code form from the rights set forth in this
+  License. If You distribute the Covered Software in Executable form under a
+  different license, You must make it absolutely clear that any terms which
+  differ from this License are offered by You alone, not by the Initial Developer
+  or Contributor. You hereby agree to indemnify the Initial Developer and every
+  Contributor for any liability incurred by the Initial Developer or such
+  Contributor as a result of any such terms You offer.
+  
+  3.6. Larger Works.  You may create a Larger Work by combining Covered Software
+  with other code not governed by the terms of this License and distribute the
+  Larger Work as a single product. In such a case, You must make sure the
+  requirements of this License are fulfilled for the Covered Software.
+  
+  4. Versions of the License.
+  
+  4.1. New Versions.  Oracle is the initial license steward and may publish
+  revised and/or new versions of this License from time to time. Each version
+  will be given a distinguishing version number. Except as provided in Section
+  4.3, no one other than the license steward has the right to modify this
+  License.
+  
+  4.2. Effect of New Versions.  You may always continue to use, distribute or
+  otherwise make the Covered Software available under the terms of the version of
+  the License under which You originally received the Covered Software. If the
+  Initial Developer includes a notice in the Original Software prohibiting it
+  from being distributed or otherwise made available under any subsequent version
+  of the License, You must distribute and make the Covered Software available
+  under the terms of the version of the License under which You originally
+  received the Covered Software. Otherwise, You may also choose to use,
+  distribute or otherwise make the Covered Software available under the terms of
+  any subsequent version of the License published by the license steward.
+  
+  4.3. Modified Versions.  When You are an Initial Developer and You want to
+  create a new license for Your Original Software, You may create and use a
+  modified version of this License if You: (a) rename the license and remove any
+  references to the name of the license steward (except to note that the license
+  differs from this License); and (b) otherwise make it clear that the license
+  contains terms which differ from this License.
+  
+  5. DISCLAIMER OF WARRANTY.  COVERED SOFTWARE IS PROVIDED UNDER THIS LICENSE ON
+  AN “AS IS” BASIS, WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED,
+  INCLUDING, WITHOUT LIMITATION, WARRANTIES THAT THE COVERED SOFTWARE IS FREE OF
+  DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR PURPOSE OR NON-INFRINGING. THE
+  ENTIRE RISK AS TO THE QUALITY AND PERFORMANCE OF THE COVERED SOFTWARE IS WITH
+  YOU. SHOULD ANY COVERED SOFTWARE PROVE DEFECTIVE IN ANY RESPECT, YOU (NOT THE
+  INITIAL DEVELOPER OR ANY OTHER CONTRIBUTOR) ASSUME THE COST OF ANY NECESSARY
+  SERVICING, REPAIR OR CORRECTION. THIS DISCLAIMER OF WARRANTY CONSTITUTES AN
+  ESSENTIAL PART OF THIS LICENSE. NO USE OF ANY COVERED SOFTWARE IS AUTHORIZED
+  HEREUNDER EXCEPT UNDER THIS DISCLAIMER.
+  
+  6. TERMINATION.
+  
+  6.1. This License and the rights granted hereunder will terminate automatically
+  if You fail to comply with terms herein and fail to cure such breach within 30
+  days of becoming aware of the breach. Provisions which, by their nature, must
+  remain in effect beyond the termination of this License shall survive.
+  
+  6.2. If You assert a patent infringement claim (excluding declaratory judgment
+  actions) against Initial Developer or a Contributor (the Initial Developer or
+  Contributor against whom You assert such claim is referred to as “Participant”)
+  alleging that the Participant Software (meaning the Contributor Version where
+  the Participant is a Contributor or the Original Software where the Participant
+  is the Initial Developer) directly or indirectly infringes any patent, then any
+  and all rights granted directly or indirectly to You by such Participant, the
+  Initial Developer (if the Initial Developer is not the Participant) and all
+  Contributors under Sections 2.1 and/or 2.2 of this License shall, upon 60 days
+  notice from Participant terminate prospectively and automatically at the
+  expiration of such 60 day notice period, unless if within such 60 day period
+  You withdraw Your claim with respect to the Participant Software against such
+  Participant either unilaterally or pursuant to a written agreement with
+  Participant.
+  
+  6.3. If You assert a patent infringement claim against Participant alleging
+  that the Participant Software directly or indirectly infringes any patent where
+  such claim is resolved (such as by license or settlement) prior to the
+  initiation of patent infringement litigation, then the reasonable value of the
+  licenses granted by such Participant under Sections 2.1 or 2.2 shall be taken
+  into account in determining the amount or value of any payment or license.
+  
+  6.4. In the event of termination under Sections 6.1 or 6.2 above, all end user
+  licenses that have been validly granted by You or any distributor hereunder
+  prior to termination (excluding licenses granted to You by any distributor)
+  shall survive termination.
+  
+  7. LIMITATION OF LIABILITY.
+  
+  UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT (INCLUDING
+  NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE INITIAL DEVELOPER, ANY
+  OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF COVERED SOFTWARE, OR ANY SUPPLIER OF
+  ANY OF SUCH PARTIES, BE LIABLE TO ANY PERSON FOR ANY INDIRECT, SPECIAL,
+  INCIDENTAL, OR CONSEQUENTIAL DAMAGES OF ANY CHARACTER INCLUDING, WITHOUT
+  LIMITATION, DAMAGES FOR LOSS OF GOODWILL, WORK STOPPAGE, COMPUTER FAILURE OR
+  MALFUNCTION, OR ANY AND ALL OTHER COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH
+  PARTY SHALL HAVE BEEN INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS
+  LIMITATION OF LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL
+  INJURY RESULTING FROM SUCH PARTY'S NEGLIGENCE TO THE EXTENT APPLICABLE LAW
+  PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO NOT ALLOW THE EXCLUSION OR
+  LIMITATION OF INCIDENTAL OR CONSEQUENTIAL DAMAGES, SO THIS EXCLUSION AND
+  LIMITATION MAY NOT APPLY TO YOU.
+  
+  8. U.S. GOVERNMENT END USERS.
+  
+  The Covered Software is a “commercial item,” as that term is defined in 48
+  C.F.R. 2.101 (Oct. 1995), consisting of “commercial computer software” (as that
+  term is defined at 48 C.F.R. § 252.227-7014(a)(1)) and “commercial computer
+  software documentation” as such terms are used in 48 C.F.R. 12.212 (Sept.
+  1995). Consistent with 48 C.F.R. 12.212 and 48 C.F.R. 227.7202-1 through
+  227.7202-4 (June 1995), all U.S. Government End Users acquire Covered Software
+  with only those rights set forth herein. This U.S. Government Rights clause is
+  in lieu of, and supersedes, any other FAR, DFAR, or other clause or provision
+  that addresses Government rights in computer software under this License.
+  
+  9. MISCELLANEOUS.
+  
+  This License represents the complete agreement concerning subject matter
+  hereof. If any provision of this License is held to be unenforceable, such
+  provision shall be reformed only to the extent necessary to make it
+  enforceable. This License shall be governed by the law of the jurisdiction
+  specified in a notice contained within the Original Software (except to the
+  extent applicable law, if any, provides otherwise), excluding such
+  jurisdiction's conflict-of-law provisions. Any litigation relating to this
+  License shall be subject to the jurisdiction of the courts located in the
+  jurisdiction and venue specified in a notice contained within the Original
+  Software, with the losing party responsible for costs, including, without
+  limitation, court costs and reasonable attorneys' fees and expenses. The
+  application of the United Nations Convention on Contracts for the International
+  Sale of Goods is expressly excluded. Any law or regulation which provides that
+  the language of a contract shall be construed against the drafter shall not
+  apply to this License. You agree that You alone are responsible for compliance
+  with the United States export administration regulations (and the export
+  control laws and regulation of any other countries) when You use, distribute or
+  otherwise make available any Covered Software.
+  
+  10. RESPONSIBILITY FOR CLAIMS.
+  
+  As between Initial Developer and the Contributors, each party is responsible
+  for claims and damages arising, directly or indirectly, out of its utilization
+  of rights under this License and You agree to work with Initial Developer and
+  Contributors to distribute such responsibility on an equitable basis. Nothing
+  herein is intended or shall be deemed to constitute any admission of liability.
+  
+  NOTICE PURSUANT TO SECTION 9 OF THE COMMON DEVELOPMENT AND DISTRIBUTION LICENSE
+  (CDDL) The code released under the CDDL shall be governed by the laws of the
+  State of California (excluding conflict-of-law provisions). Any litigation
+  relating to this License shall be subject to the jurisdiction of the Federal
+  Courts of the Northern District of California and the state courts of the State
+  of California, with venue lying in Santa Clara County, California.
+
+
+Eclipse Public License, version 1.0
+
+  THE ACCOMPANYING PROGRAM IS PROVIDED UNDER THE TERMS OF THIS ECLIPSE PUBLIC
+  LICENSE ("AGREEMENT"). ANY USE, REPRODUCTION OR DISTRIBUTION OF THE PROGRAM
+  CONSTITUTES RECIPIENT'S ACCEPTANCE OF THIS AGREEMENT.
+  
+  1. DEFINITIONS
+  
+  "Contribution" means:
+  
+  a) in the case of the initial Contributor, the initial code 

<TRUNCATED>

[28/51] [abbrv] brooklyn-dist git commit: add getting started vagrant env to release artifacts - following inclusion of Vagrant as a target in #1144 - previously at https://github.com/johnmccabe/vagrant-brooklyn-getting-started

Posted by he...@apache.org.
add getting started vagrant env to release artifacts
- following inclusion of Vagrant as a target in #1144
- previously at https://github.com/johnmccabe/vagrant-brooklyn-getting-started


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

Branch: refs/heads/master
Commit: e9fd416ee2a407eb27bf0454dc47d8f7f09997e7
Parents: fbdd2f7
Author: John McCabe <jo...@johnmccabe.net>
Authored: Thu Jan 21 22:50:59 2016 +0000
Committer: John McCabe <jo...@johnmccabe.net>
Committed: Thu Jan 21 22:50:59 2016 +0000

----------------------------------------------------------------------
 brooklyn-dist/.gitignore                        |   1 +
 brooklyn-dist/pom.xml                           |   1 +
 brooklyn-dist/vagrant/pom.xml                   |  70 ++++
 .../src/main/config/build-distribution.xml      |  33 ++
 .../vagrant/src/main/vagrant/Vagrantfile        |  57 ++++
 .../src/main/vagrant/files/brooklyn.properties  | 325 +++++++++++++++++++
 .../src/main/vagrant/files/brooklyn.service     |  13 +
 .../vagrant/src/main/vagrant/files/logback.xml  |  12 +
 .../vagrant/src/main/vagrant/servers.yaml       |  47 +++
 9 files changed, 559 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/e9fd416e/brooklyn-dist/.gitignore
----------------------------------------------------------------------
diff --git a/brooklyn-dist/.gitignore b/brooklyn-dist/.gitignore
index ed439f2..2ef22e4 100644
--- a/brooklyn-dist/.gitignore
+++ b/brooklyn-dist/.gitignore
@@ -28,5 +28,6 @@ prodDb.*
 brooklyn*.log.*
 
 *brooklyn-persisted-state/
+*.vagrant/
 
 ignored

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/e9fd416e/brooklyn-dist/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/pom.xml b/brooklyn-dist/pom.xml
index a2ecb3a..12ebdd9 100644
--- a/brooklyn-dist/pom.xml
+++ b/brooklyn-dist/pom.xml
@@ -76,6 +76,7 @@
         <module>downstream-parent</module>
         <module>all</module>
         <module>dist</module>
+        <module>vagrant</module>
         <module>archetypes/quickstart</module>
     </modules>
 

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/e9fd416e/brooklyn-dist/vagrant/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/pom.xml b/brooklyn-dist/vagrant/pom.xml
new file mode 100644
index 0000000..3fc1844
--- /dev/null
+++ b/brooklyn-dist/vagrant/pom.xml
@@ -0,0 +1,70 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+    
+     http://www.apache.org/licenses/LICENSE-2.0
+    
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+    <modelVersion>4.0.0</modelVersion>
+    <packaging>pom</packaging>
+
+    <artifactId>brooklyn-vagrant</artifactId>
+
+    <name>Brooklyn Vagrant Getting Started Environment</name>
+    <description>
+        Brooklyn Getting Started Vagrant environment archive, includes all required
+        files to start Brooklyn and sample BYON nodes for use.
+    </description>
+
+    <parent>
+        <groupId>org.apache.brooklyn</groupId>
+        <artifactId>brooklyn-dist-root</artifactId>
+        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+        <relativePath>../pom.xml</relativePath>
+    </parent>
+
+    <build>
+        <plugins>
+            <plugin>
+                <artifactId>maven-assembly-plugin</artifactId>
+                <executions>
+                    <execution>
+                        <id>build-distribution-archive</id>
+                        <phase>package</phase>
+                        <goals>
+                            <goal>single</goal>
+                        </goals>
+                        <configuration>
+                            <appendAssemblyId>true</appendAssemblyId>
+                            <descriptors>
+                                <descriptor>src/main/config/build-distribution.xml</descriptor>
+                            </descriptors>
+                          <!-- finalName affects name in `target/` but we cannot influence name when it is attached/installed,
+                               so `apache-` prefix would be lost there. to keep it consistent this is commented out, 
+                               but would be nice to have if there is a way!
+                            <finalName>apache-brooklyn-${project.version}</finalName>
+                          -->
+                            <formats>
+                                <format>tar.gz</format>
+                                <format>zip</format>
+                            </formats>
+                        </configuration>
+                    </execution>
+                </executions>
+            </plugin>
+        </plugins>
+    </build>
+</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/e9fd416e/brooklyn-dist/vagrant/src/main/config/build-distribution.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/config/build-distribution.xml b/brooklyn-dist/vagrant/src/main/config/build-distribution.xml
new file mode 100644
index 0000000..823ad2a
--- /dev/null
+++ b/brooklyn-dist/vagrant/src/main/config/build-distribution.xml
@@ -0,0 +1,33 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+    
+     http://www.apache.org/licenses/LICENSE-2.0
+    
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<assembly xmlns="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2 http://maven.apache.org/xsd/assembly-1.1.2.xsd">
+    <id>dist</id>
+    <formats><!-- empty, intended for caller to specify --></formats>
+    <fileSets>
+        <fileSet>
+            <directory>${project.basedir}/src/main/vagrant</directory>
+            <outputDirectory></outputDirectory>
+            <fileMode>0644</fileMode>
+            <directoryMode>0755</directoryMode>
+        </fileSet>
+    </fileSets>
+</assembly>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/e9fd416e/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile b/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
new file mode 100644
index 0000000..f5f7927
--- /dev/null
+++ b/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
@@ -0,0 +1,57 @@
+# -*- mode: ruby -*-
+# # vi: set ft=ruby :
+
+# Specify minimum Vagrant version and Vagrant API version
+Vagrant.require_version ">= 1.8.1"
+VAGRANTFILE_API_VERSION = "2"
+
+# Update OS (Debian/RedHat based only)
+UPDATE_OS_CMD = "(sudo apt-get update && sudo apt-get -y upgrade) || (sudo yum -y update)"
+
+# Require YAML module
+require 'yaml'
+
+# Read YAML file with box details
+yaml_cfg = YAML.load_file(__dir__ + '/servers.yaml')
+
+# Create boxes
+Vagrant.configure(VAGRANTFILE_API_VERSION) do |config|
+
+  # Iterate through server entries in YAML file
+  yaml_cfg["servers"].each do |server|
+    config.vm.define server["name"] do |server_config|
+      server_config.vm.box = server["box"]
+
+      server_config.vm.box_check_update = yaml_cfg["default_config"]["check_newer_vagrant_box"]
+
+      if server.has_key?("ip")
+        server_config.vm.network "private_network", ip: server["ip"]
+      end
+
+      if server.has_key?("forwarded_ports")
+        server["forwarded_ports"].each do |ports|
+          server_config.vm.network "forwarded_port", guest: ports["guest"], host: ports["host"], guest_ip: ports["guest_ip"]
+        end
+      end
+
+      server_config.vm.hostname = server["name"]
+      server_config.vm.provider :virtualbox do |vb|
+        vb.name = server["name"]
+        vb.memory = server["ram"]
+        vb.cpus = server["cpus"]
+      end
+
+      if yaml_cfg["default_config"]["run_os_update"]
+        server_config.vm.provision "shell", privileged: false, inline: UPDATE_OS_CMD
+      end
+
+      if server["shell"] && server["shell"]["cmd"]
+        server["shell"]["cmd"].each do |cmd|
+          server_config.vm.provision "shell", privileged: false, inline: cmd, env: server["shell"]["env"]
+        end
+      end
+
+      server_config.vm.post_up_message = server["post_up_message"]
+    end
+  end
+end
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/e9fd416e/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties b/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties
new file mode 100644
index 0000000..e68f9a6
--- /dev/null
+++ b/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties
@@ -0,0 +1,325 @@
+#
+# 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.
+#
+# This is Brooklyn's dot-properties file.
+# It should be located at "~/.brooklyn/brooklyn.properties" for automatic loading,
+# or can be specified as a CLI option with --localProperties /path/to/these.properties.
+
+##################################  Welcome!  ############################################
+
+# It's great to have you here.
+
+# Getting Started options have been pulled to the top. There's a formatting guide at the
+# very bottom.
+
+############################ Getting Started Options  ####################################
+
+## GUI Security
+
+## NOTE: in production it is highly recommended to set this, as otherwise it will not require login,
+## not will it be encrypted (though for safety if security is not set it will only bind to loopback)
+
+## Edit the name(s) and passwords as appropriate to your system:
+
+# brooklyn.webconsole.security.users=admin,bob
+# brooklyn.webconsole.security.user.admin.password=password
+# brooklyn.webconsole.security.user.bob.password=bobsword
+
+## If you prefer to run with https (on port 8443 by default), uncomment this:
+
+# brooklyn.webconsole.security.https.required=true
+
+
+# By default we have AWS set up (but with invalid credentials!).  Many, many other
+# providers are supported.
+
+## Amazon EC2 Credentials
+# These should be an "Access Key ID" and "Secret Access Key" for your account.
+# This is configured at https://console.aws.amazon.com/iam/home?#security_credential .
+
+brooklyn.location.jclouds.aws-ec2.identity = AKA_YOUR_ACCESS_KEY_ID
+brooklyn.location.jclouds.aws-ec2.credential = <access-key-hex-digits>
+
+# Beware of trailing spaces in your cloud credentials. This will cause unexpected
+# 401: unauthorized responses.
+
+## Using Other Clouds
+# 1. Cast your eyes down this document to find your preferred cloud in the Named Locations
+#    section, and the examples.
+# 2. Uncomment the relevant line(s) for your provider.
+# 3. ADD  -.identity and -.credential lines for your provider, similar to the AWS ones above,
+#    replacing 'aws-ec2' with jcloud's id for your cloud.
+
+
+## Deploying to Localhost
+## see: info on locations at brooklyn.io
+#
+## ~/.ssh/id_rsa is Brooklyn's default location
+# brooklyn.location.localhost.privateKeyFile = ~/.ssh/id_rsa
+## Passphrases are supported, but not required
+# brooklyn.location.localhost.privateKeyPassphrase = s3cr3tpassphrase
+
+## Geoscaling Service - used for the Global Web Fabric demo
+## see: the global web example at brooklyn.io
+## https://www.geoscaling.com/dns2/
+## other services may take similar configuration similarly; or can usually be set in YAML
+# brooklyn.geoscaling.username = USERNAME
+# brooklyn.geoscaling.password = PASSWORD
+# brooklyn.geoscaling.primaryDomain = DOMAIN
+
+
+##########################  Getting Started Complete!  ###################################
+
+# That's it, although you may want to read through these options...
+
+################################ Brooklyn Options ########################################
+
+## Brooklyn Management Base Directory: specify where management data should be stored on this server;
+## ~/.brooklyn/ is the default but you could use something like /opt/brooklyn/state/
+## (provided this process has write permissions)
+# brooklyn.base.dir=~/.brooklyn/
+
+## Brooklyn On-Box Directory: specify where data should be stored on managed hosts;
+## for most locations a directory off home is the default (but using /tmp/brooklyn-user/ on localhost),
+## however you could specify something like /opt/brooklyn-managed-process/ (creation and permissions are handled)
+# onbox.base.dir=~/brooklyn-managed-process/
+
+## Additional security: Allow all - if you know what you are doing!
+## (Or you can also plug in e.g. LDAP security etc here)
+# Disabling security on the Vagrant Brooklyn instance for training purposes
+brooklyn.webconsole.security.provider = org.apache.brooklyn.rest.security.provider.AnyoneSecurityProvider
+
+## Optionally disallow deployment to localhost (or any other location)
+# brooklyn.location.localhost.enabled=false
+
+## Scripting Behaviour
+
+## keep scripts around after running them (usually in /tmp)
+# brooklyn.ssh.config.noDeleteAfterExec = true
+
+## Misc Cloud Settings
+## brooklyn will fail a node if the cloud machine doesn't come up, but you can tell it to retry:
+# brooklyn.location.jclouds.machineCreateAttempts = 3
+## many cloud machines don't have sufficient entropy for lots of encrypted networking, so fake it:
+# brooklyn.location.jclouds.installDevUrandom=true
+
+## Sets a minimium ram property for all jclouds locations. Recommended to avoid getting m1.micros on AWS!
+brooklyn.location.jclouds.minRam = 2048
+
+## When setting up a new cloud machine Brooklyn creates a user with the same name as the user running
+## Brooklyn on the management server, but you can force a different user here:
+# brooklyn.location.jclouds.user=brooklyn
+## And you can force a password or key (by default it will use the keys in ~/.ssh/id_rsa{,.pub}
+# brooklyn.location.jclouds.password=s3cr3t
+
+################################ Named Locations ########################################
+
+# Named locations appear in the web console. If using the command line or YAML it may be
+# just as easy to use the jclouds:<provider> locations and specify additional properties there.
+
+## Example: AWS Virginia using Rightscale 6.3 64bit Centos AMI and Large Instances
+# brooklyn.location.named.aws-va-centos-large = jclouds:aws-ec2:us-east-1
+# brooklyn.location.named.aws-va-centos-large.imageId=us-east-1/ami-7d7bfc14
+# brooklyn.location.named.aws-va-centos-large.user=brooklyn
+# brooklyn.location.named.aws-va-centos-large.minRam=4096
+
+## You can also nest these:
+# brooklyn.location.named.aws-acct-two = jclouds:aws-ec2
+# brooklyn.location.named.aws-acct-two.identity = AKA_ACCT_TWO
+# brooklyn.location.named.aws-acct-two.credential = <access-key-hex-digits>
+# brooklyn.location.named.aws-acct-two-singapore = named:aws-acct-two
+# brooklyn.location.named.aws-acct-two-singapore.region = ap-southeast-1
+# brooklyn.location.named.aws-acct-two-singapore.displayName = AWS Singapore (Acct Two)
+
+# For convenience some common defaults:
+brooklyn.location.named.aws-california = jclouds:aws-ec2:us-west-1
+brooklyn.location.named.aws-oregon = jclouds:aws-ec2:us-west-2
+brooklyn.location.named.aws-ireland = jclouds:aws-ec2:eu-west-1
+brooklyn.location.named.aws-tokyo = jclouds:aws-ec2:ap-northeast-1
+
+## Google Compute
+## The credentials for GCE come from the "APIs & auth -> Credentials" page,
+## creating a "Service Account" of type JSON, then extracting
+## the client_email as the identity and private_key as the identity,
+## keeping new lines as \n (exactly as in the JSON supplied)
+# brooklyn.location.jclouds.google-compute-engine.identity=1234567890-somet1mesArand0mU1Dhere@developer.gserviceaccount.com
+# brooklyn.location.jclouds.google-compute-engine.credential=-----BEGIN PRIVATE KEY----- \nMIIblahablahblah \nblahblahblah \n-----END PRIVATE KEY-----
+# brooklyn.location.named.Google\ US = jclouds:google-compute-engine
+# brooklyn.location.named.Google\ US.region=us-central1-a
+# brooklyn.location.named.Google\ EU = jclouds:google-compute-engine
+# brooklyn.location.named.Google\ EU.region=europe-west1-a
+## the following flags for GCE are recommended
+## specify the network to use - otherwise it creates new networks each time and you hit quotas pretty quickly
+## you may have to manually create this network AND enable a firewall rule EG  tcp:1-65535;udp:1-65535;icmp
+## (fix for this is in progress)
+# brooklyn.location.jclouds.google-compute-engine.networkName=brooklyn-default-network
+## gce images have bad entropy, this ensures they have noisy /dev/random (even if the "randomness" is not quite as random)
+# brooklyn.location.jclouds.google-compute-engine.installDevUrandom=true
+## gce images often start with iptables turned on; turn it off unless your blueprints are iptables-aware
+# brooklyn.location.jclouds.google-compute-engine.stopIptables=true
+
+## HP Cloud - also Ubuntu 12.04 LTS
+## You specify your HP Credentials like this:
+# brooklyn.location.jclouds.hpcloud-compute.identity = projectname:username
+# brooklyn.location.jclouds.hpcloud-compute.credential = password
+## where username and password are the same as logging in to the web console, and
+## projectname can be found here: https://account.hpcloud.com/projects
+#�brooklyn.location.named.HP\ Cloud\ Arizona-1 = jclouds:hpcloud-compute:az-1.region-a.geo-1
+# brooklyn.location.named.HP\ Cloud\ Arizona-1.imageId = az-1.region-a.geo-1/75845
+# brooklyn.location.named.HP\ Cloud\ Arizona-1.user = ubuntu
+
+## Softlayer - need a key from the gui, under "administrative -> user administration -> api-access
+# brooklyn.location.jclouds.softlayer.identity=username
+# brooklyn.location.jclouds.softlayer.credential=<private-key-hex-digits>
+## locations
+# brooklyn.location.named.Softlayer\ Dallas=jclouds:softlayer:dal05
+# brooklyn.location.named.Softlayer\ Seattle=jclouds:softlayer:sea01
+# brooklyn.location.named.Softlayer\ Washington\ DC=jclouds:softlayer:wdc01
+# brooklyn.location.named.Softlayer\ Singapore\ 1=jclouds:softlayer:sng01
+# brooklyn.location.named.Softlayer\ Amsterdam\ 1=jclouds:softlayer:ams01
+
+
+## Brooklyn uses the jclouds multi-cloud library to access many clouds.
+## http://www.jclouds.org/documentation/reference/supported-providers/
+
+## Templates for many other clouds, but remember to add identity and credentials:
+
+# brooklyn.location.named.Bluelock = jclouds:bluelock-vcloud-zone01
+
+# brooklyn.location.named.CloudSigma\ Nevada = jclouds:cloudsigma-lvs
+# brooklyn.location.named.CloudSigma\ Zurich = jclouds:cloudsigma-zrh
+
+# brooklyn.location.named.ElasticHosts\ London = jclouds:elastichosts-lon-p
+# brooklyn.location.named.ElasticHosts\ Texas = jclouds:elastichosts-sat-p
+
+# brooklyn.location.named.GleSYS = jclouds:glesys
+
+# brooklyn.location.named.Go2Cloud = jclouds:go2cloud-jhb1
+
+# brooklyn.location.named.GoGrid = jclouds:gogrid
+
+# brooklyn.location.named.Green\ House\ Data = jclouds:greenhousedata-element-vcloud
+
+# brooklyn.location.named.Ninefold = jclouds:ninefold-compute
+
+# brooklyn.location.named.OpenHosting = jclouds:openhosting-east1
+
+# brooklyn.location.named.Rackspace\ Chicago\ (ord) = jclouds:rackspace-cloudservers-us:ORD
+# brooklyn.location.named.Rackspace\ Dallas\ (dfw) = jclouds:rackspace-cloudservers-us:DFW
+# brooklyn.location.named.Rackspace\ Hong\ Kong\ (hkg) = jclouds:rackspace-cloudservers-us:HKG
+# brooklyn.location.named.Rackspace\ Northern\ Virginia\ (iad) = jclouds:rackspace-cloudservers-us:IAD
+# brooklyn.location.named.Rackspace\ Sydney\ (syd) = jclouds:rackspace-cloudservers-us:SYD
+## for UK you will need a separate account with rackspace.co.uk
+# brooklyn.location.named.Rackspace\ London\ (lon) = jclouds:rackspace-cloudservers-uk
+
+## if you need to use Rackspace "first gen" API
+## (note the "next gen" api configured above seems to be faster)
+# brooklyn.location.jclouds.cloudservers-us.identity = YOURAPIKEY
+# brooklyn.location.jclouds.cloudservers-us.credential = YOURSECRETKEY
+# brooklyn.location.named.Rackspace\ US\ (First Gen) = jclouds:cloudservers-us
+## and as with next gen, first gen requires a separate acct for the UK:
+# brooklyn.location.jclouds.cloudservers-uk.identity = YOURAPIKEY
+# brooklyn.location.jclouds.cloudservers-uk.credential = YOURSECRETKEY
+# brooklyn.location.named.Rackspace\ UK\ (First Gen) = jclouds:cloudservers-uk
+
+# brooklyn.location.named.SeverLove = jclouds:serverlove-z1-man
+
+# brooklyn.location.named.SkaliCloud = jclouds:skalicloud-sdg-my
+
+# brooklyn.location.named.Stratogen = jclouds:stratogen-vcloud-mycloud
+
+# brooklyn.location.named.TryStack\ (Openstack) = jclouds:trystack-nova
+
+
+## Production pool of machines for my application (deploy to named:On-Prem\ Iron\ Example)
+# brooklyn.location.named.On-Prem\ Iron\ Example=byon:(hosts="10.9.1.1,10.9.1.2,produser2@10.9.2.{10,11,20-29}")
+# brooklyn.location.named.On-Prem\ Iron\ Example.user=produser1
+# brooklyn.location.named.On-Prem\ Iron\ Example.privateKeyFile=~/.ssh/produser_id_rsa
+# brooklyn.location.named.On-Prem\ Iron\ Example.privateKeyPassphrase=s3cr3tpassphrase
+
+## Various Private Clouds
+
+## Example: OpenStack Nova
+
+## openstack identity and credential are random strings of letters and numbers (TBC - still the case?)
+# brooklyn.location.named.My\ Openstack=jclouds:openstack-nova:https://9.9.9.9:9999/v2.0/
+
+## OpenStack Nova access information can be downloaded from the openstack web interface; for example, as openrc.sh file
+# brooklyn.location.named.My\ Openstack=jclouds:openstack-nova:keystone-url
+# brooklyn.location.named.My\ OpenStack.identity=your-tenant-name:your-user-name
+# brooklyn.location.named.My\ OpenStack.credential=your-password
+# brooklyn.location.named.My\ OpenStack.endpoint=your-keystone-url
+
+## The ID of the image must be configured according to the local OpenStack settings
+## Use the command nova image-list to list all the available images
+## Use the command nova show <image-name> to get more details
+# brooklyn.location.named.My\ OpenStack.imageId=the-region-name/the-image-id
+
+## Virtual Machine flavors must match the ones created upfront according to the local OpenStack settings
+## Use the command nova flavor-list to list all the available options
+## Use the command nova flavor-show <flavor-name> to get more details
+# brooklyn.location.named.My\ OpenStack.hardwareId=the-region-name/the-flavor-id
+
+## (Optional) Configurations
+
+# brooklyn.location.named.My\ OpenStack.user=user-name-inside-the-instance
+
+## The keyPair must by created upfront. Both the following two options are required at the same time.
+# brooklyn.location.named.My\ OpenStack.keyPair=the-key-pair-name
+# brooklyn.location.named.My\ OpenStack.loginUser.privateKeyFile=/path/to/keypair.pem
+
+## Security groups must be created upfront (TBC - How to specify many security groups at one ?)
+# brooklyn.location.named.My\ OpenStack.securityGroups=universal
+
+# brooklyn.location.named.My\ OpenStack.openIptables=true
+# brooklyn.location.named.My\ OpenStack.selinux.disabled=true
+# brooklyn.location.named.My\ OpenStack.auto-create-floating-ips=true
+# brooklyn.location.named.My\ OpenStack.openstack-nova.auto-generate-keypairs=false
+
+## cloudstack identity and credential are rather long random strings of letters and numbers
+## you generate this in the cloudstack gui, under accounts, then "view users", then "generate key"
+## use the "api key" as the identity and "secret key" as the credential
+# brooklyn.location.named.My\ Cloudstack=jclouds:cloudstack:http://9.9.9.9:9999/client/api/
+
+## abiquo identity and credential are your login username/passed
+# brooklyn.location.named.My\ Abiquo=jclouds:abiquo:http://demonstration.abiquo.com/api/
+
+###############################  Formatting Guide  #######################################
+
+! Both # and ! mark lines as comments
+# The follow syntax are ALL valid.
+# example_key example_value
+# example_key : example_value
+# example_key = example_value
+# example_key=example_value
+
+# The backslash below tells Brooklyn to continue reading the value onto the next line.
+# example_key = A very \
+#          	long string!
+# Note all white space before 'long...' is ignored. Also '!' is kept as part of the string
+
+
+# Keys with spaces should be escaped with backslashes.
+# This is useful for named locations, as the name displayed in Brooklyn's web
+# interface is derived from the key name.
+# key\ with\ spaces = some\ value
+
+# Encoding for .properties must be ISO-8859-1, aka Latin-1.
+# All non-latin1 characters must be entered using unicode escape characters
+# polish_pangram = P\u00F3jd\u017A\u017Ce, ki\u0144 \
+#                  t\u0119 chmurno\u015B\u0107 w g\u0142\u0105b flaszy!
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/e9fd416e/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service b/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service
new file mode 100644
index 0000000..04384a1
--- /dev/null
+++ b/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service
@@ -0,0 +1,13 @@
+[Unit]
+Description=Apache Brooklyn service
+Documentation=http://brooklyn.apache.org/documentation/index.html
+
+[Service]
+ExecStart=/home/vagrant/apache-brooklyn/bin/brooklyn launch --persist auto --persistenceDir /vagrant/brooklyn-persisted-state
+WorkingDirectory=/home/vagrant/apache-brooklyn
+Restart=on-abort
+User=vagrant
+Group=vagrant
+
+[Install]
+WantedBy=multi-user.target

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/e9fd416e/brooklyn-dist/vagrant/src/main/vagrant/files/logback.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/files/logback.xml b/brooklyn-dist/vagrant/src/main/vagrant/files/logback.xml
new file mode 100644
index 0000000..77b3816
--- /dev/null
+++ b/brooklyn-dist/vagrant/src/main/vagrant/files/logback.xml
@@ -0,0 +1,12 @@
+<configuration scan="true">
+
+    <!-- to supply custom logging, either change this file, supply your own logback-main.xml
+         (overriding the default provided on the classpath) or any of the files it references;
+         see the Logging section of the Brooklyn web site for more information -->
+
+    <property name="logging.basename" scope="context" value="brooklyn" />
+    <property name="logging.dir" scope="context" value="/var/log/brooklyn/" />
+
+    <include resource="logback-main.xml"/>
+
+</configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/e9fd416e/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml b/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml
new file mode 100644
index 0000000..0bf133b
--- /dev/null
+++ b/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml
@@ -0,0 +1,47 @@
+---
+default_config:
+    check_newer_vagrant_box: true
+    run_os_update: true
+servers:
+  - name: brooklyn
+    box: ubuntu/vivid64
+    ram: 2048
+    cpus: 4
+    ip: 10.10.10.100
+    shell:
+      env:
+        BROOKLYN_VERSION: 0.9.0-SNAPSHOT
+      cmd:
+        - sudo sh -c 'export DEBIAN_FRONTEND=noninteractive; apt-get install --yes openjdk-8-jre-headless'
+        - curl -s -S -J -O -L "https://www.apache.org/dyn/closer.cgi?action=download&filename=brooklyn/apache-brooklyn-${BROOKLYN_VERSION}/apache-brooklyn-${BROOKLYN_VERSION}-bin.tar.gz"
+        - tar zxf apache-brooklyn-${BROOKLYN_VERSION}-bin.tar.gz
+        - ln -s apache-brooklyn-${BROOKLYN_VERSION}-bin apache-brooklyn
+        - sudo mkdir -p /var/log/brooklyn
+        - sudo chown -R vagrant:vagrant /var/log/brooklyn
+        - sudo cp /vagrant/files/brooklyn.service /etc/systemd/system/brooklyn.service
+        - mkdir -p /home/vagrant/.brooklyn
+        - cp /vagrant/files/brooklyn.properties /home/vagrant/.brooklyn/
+        - chmod 600 /home/vagrant/.brooklyn/brooklyn.properties
+        - sudo systemctl start brooklyn
+        - sudo systemctl enable brooklyn
+  - name: byon1
+    box: ubuntu/vivid64
+    ram: 512
+    cpus: 2
+    ip: 10.10.10.101
+  - name: byon2
+    box: ubuntu/vivid64
+    ram: 512
+    cpus: 2
+    ip: 10.10.10.102
+  - name: byon3
+    box: ubuntu/vivid64
+    ram: 512
+    cpus: 2
+    ip: 10.10.10.103
+  - name: byon4
+    box: ubuntu/vivid64
+    ram: 512
+    cpus: 2
+    ip: 10.10.10.104
+...


[35/51] [abbrv] brooklyn-dist git commit: add support for SNAPSHOT downloads - supports release downloads via Apache closer.lua mirror - supports snapshot download from Apache maven - supports snapshot download from a local -dist.tar.gz archive. *NOTE* t

Posted by he...@apache.org.
add support for SNAPSHOT downloads
- supports release downloads via Apache closer.lua mirror
- supports snapshot download from Apache maven
- supports snapshot download from a local -dist.tar.gz archive.
*NOTE* this currently requires the user to copy the dist to the same directory
       as the Vagrantfile


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

Branch: refs/heads/master
Commit: 88327712bf3925f1db1ee0c458fd71b1536f2039
Parents: eab89f0
Author: John McCabe <jo...@johnmccabe.net>
Authored: Thu Jan 28 16:27:44 2016 +0000
Committer: John McCabe <jo...@johnmccabe.net>
Committed: Thu Jan 28 16:27:44 2016 +0000

----------------------------------------------------------------------
 .../vagrant/src/main/vagrant/README.md          | 58 ++++--------
 .../vagrant/src/main/vagrant/Vagrantfile        |  4 -
 .../src/main/vagrant/files/install_brooklyn.sh  | 92 ++++++++++++++++++++
 .../vagrant/src/main/vagrant/servers.yaml       | 27 +++---
 4 files changed, 127 insertions(+), 54 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/88327712/brooklyn-dist/vagrant/src/main/vagrant/README.md
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/README.md b/brooklyn-dist/vagrant/src/main/vagrant/README.md
index b446ab8..2f5573c 100644
--- a/brooklyn-dist/vagrant/src/main/vagrant/README.md
+++ b/brooklyn-dist/vagrant/src/main/vagrant/README.md
@@ -1,63 +1,41 @@
 
 # [![**Brooklyn**](https://brooklyn.apache.org/style/img/apache-brooklyn-logo-244px-wide.png)](http://brooklyn.apache.org/)
 
-### Using Vagrant with Brooklyn -SNAPSHOT releases
-Due to the absence of a single source for snapshots (i.e. locally built vs. [periodically published archives](https://brooklyn.apache.org/v/0.9.0-SNAPSHOT/misc/download.html)), we require that you override the supplied `servers.yaml` to explicitly point at your desired `-SNAPSHOT` release.
+### Using Vagrant with Brooklyn -SNAPSHOT builds
 
-Full releases use the `BROOKLYN_VERSION` environment variable to download the associated `-bin` artifact from the closest Apache mirror, if this environment variable is set to a `-SNAPSHOT` we abort creating the Brooklyn Vagrant VM.
-
-##### Installing from local file
-For example to install from a locally built `-dist` archive:
-
-1. Copy the SNAPSHOT `-dist` archive to the same directory as the `Vagrantfile`
-
-   ```
-   cp  ~/Workspaces/incubator-brooklyn/brooklyn-dist/dist/target/brooklyn-dist-0.9.0-SNAPSHOT-dist.tar.gz .
-   ```
-
-2. Delete the `BROOKLYN_VERSION:` environment variable from `servers.yaml`. For example:
+##### Install a community-managed version from Maven
+1. No action is required other than setting the  `BROOKLYN_VERSION:` environment variable in `servers.yaml` to a `-SNAPSHOT` version. For example:
 
    ```
    env:
      BROOKLYN_VERSION: 0.9.0-SNAPSHOT
    ```
 
-3. Update `servers.yaml` to install from the `-dist` archive. For example, replace:
-   ```
-   - curl -s -S -J -O -L "https://www.apache.org/dyn/closer.cgi?action=download&filename=brooklyn/apache-brooklyn-${BROOKLYN_VERSION}/apache-brooklyn-${BROOKLYN_VERSION}-bin.tar.gz"
-   - tar zxf apache-brooklyn-${BROOKLYN_VERSION}-bin.tar.gz
-   - ln -s apache-brooklyn-${BROOKLYN_VERSION}-bin apache-brooklyn
-   ```
-   with:
-   ```
-   - cp /vagrant/brooklyn-dist-0.9.0-SNAPSHOT-dist.tar.gz .
-   - tar zxf brooklyn-dist-0.9.0-SNAPSHOT-dist.tar.gz
-   - ln -s brooklyn-dist-0.9.0-SNAPSHOT apache-brooklyn
-   ```
-
-4. You may proceed to use the `Vagrantfile` as normal; `vagrant up`, `vagrant destroy` etc.
+2. You may proceed to use the `Vagrantfile` as normal; `vagrant up`, `vagrant destroy` etc.
 
-##### Installing from URL
-For example to install from a published `-SHAPSHOT` archive:
+##### Install a locally built `-dist.tar.gz`
 
-1. Delete the `BROOKLYN_VERSION:` environment variable from `servers.yaml`. For example:
+1. Set the `BROOKLYN_VERSION:` environment variable in `servers.yaml` to your current `-SNAPSHOT` version. For example:
 
    ```
    env:
      BROOKLYN_VERSION: 0.9.0-SNAPSHOT
    ```
 
-2. Update `servers.yaml` to install from URL. For example, replace:
+2. Set the `INSTALL_FROM_LOCAL_DIST:` environment variable in `servers.yaml` to `true`. For example:
+
    ```
-   - curl -s -S -J -O -L "https://www.apache.org/dyn/closer.cgi?action=download&filename=brooklyn/apache-brooklyn-${BROOKLYN_VERSION}/apache-brooklyn-${BROOKLYN_VERSION}-bin.tar.gz"
-   - tar zxf apache-brooklyn-${BROOKLYN_VERSION}-bin.tar.gz
-   - ln -s apache-brooklyn-${BROOKLYN_VERSION}-bin apache-brooklyn
+   env:
+     INSTALL_FROM_LOCAL_DIST: true
    ```
-   with:
+
+
+3. Copy your locally built `-dist.tar.gz` archive to the same directory as the Vagrantfile (this directory is mounted in the Vagrant VM at `/vagrant/`).
+
+   For example to copy a locally built `0.9.0-SNAPSHOT` dist:
+
    ```
-   - curl -s -S -J -O -L "https://repository.apache.org/service/local/artifact/maven/redirect?r=snapshots&g=org.apache.brooklyn&a=brooklyn-dist&v=0.9.0-SNAPSHOT&c=dist&e=tar.gz"
-   - tar zxf brooklyn-dist-0.9.0-SNAPSHOT-dist.tar.gz
-   - ln -s brooklyn-dist-0.9.0-SNAPSHOT apache-brooklyn
+   cp ~/.m2/repository/org/apache/brooklyn/brooklyn-dist/0.9.0-SNAPSHOT/brooklyn-dist-0.9.0-SNAPSHOT-dist.tar.gz .
    ```
 
-3. You may proceed to use the `Vagrantfile` as normal; `vagrant up`, `vagrant destroy` etc.
\ No newline at end of file
+4. You may proceed to use the `Vagrantfile` as normal; `vagrant up`, `vagrant destroy` etc.
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/88327712/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile b/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
index 7f5dbb0..fb35a15 100644
--- a/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
+++ b/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
@@ -39,10 +39,6 @@ Vagrant.configure(VAGRANTFILE_API_VERSION) do |config|
   yaml_cfg["servers"].each do |server|
     config.vm.define server["name"] do |server_config|
 
-      if server["shell"] && server["shell"]["env"]["BROOKLYN_VERSION"] =~ /SNAPSHOT/i
-        raise Vagrant::Errors::VagrantError.new, "Deploying Brooklyn SNAPSHOTS is not supported without a manual update to servers.yaml. See README for instructions."
-      end
-
       server_config.vm.box = server["box"]
 
       server_config.vm.box_check_update = yaml_cfg["default_config"]["check_newer_vagrant_box"]

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/88327712/brooklyn-dist/vagrant/src/main/vagrant/files/install_brooklyn.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/files/install_brooklyn.sh b/brooklyn-dist/vagrant/src/main/vagrant/files/install_brooklyn.sh
new file mode 100755
index 0000000..9c52017
--- /dev/null
+++ b/brooklyn-dist/vagrant/src/main/vagrant/files/install_brooklyn.sh
@@ -0,0 +1,92 @@
+#!/usr/bin/env bash
+
+#
+# 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.
+#
+
+BROOKLYN_VERSION=""
+INSTALL_FROM_LOCAL_DIST="false"
+TMP_ARCHIVE_NAME=apache-brooklyn.tar.gz
+
+do_help() {
+  echo "./install.sh -v <Brooklyn Version> [-l <install from local file: true|false>]"
+  exit 1
+}
+
+while getopts ":hv:l:" opt; do
+    case "$opt" in
+    v)  BROOKLYN_VERSION=$OPTARG ;;
+        # using a true/false argopt rather than just flag to allow easier integration with servers.yaml config
+    l)  INSTALL_FROM_LOCAL_DIST=$OPTARG ;;
+    h)  do_help;;
+    esac
+done
+
+# Exit if any step fails
+set -e
+
+if [ "x${BROOKLYN_VERSION}" == "x" ]; then
+  echo "Error: you must supply a Brooklyn version [-v]"
+  do_help
+fi
+
+if [ ! "${INSTALL_FROM_LOCAL_DIST}" == "true" ]; then
+  if [ ! -z "${BROOKLYN_VERSION##*-SNAPSHOT}" ] ; then
+    # url for official release versions
+    BROOKLYN_URL="https://www.apache.org/dyn/closer.lua?action=download&filename=brooklyn/apache-brooklyn-${BROOKLYN_VERSION}/apache-brooklyn-${BROOKLYN_VERSION}-bin.tar.gz"
+    BROOKLYN_DIR="apache-brooklyn-${BROOKLYN_VERSION}-bin"
+  else
+    # url for community-managed snapshots
+    BROOKLYN_URL="https://repository.apache.org/service/local/artifact/maven/redirect?r=snapshots&g=org.apache.brooklyn&a=brooklyn-dist&v=${BROOKLYN_VERSION}&c=dist&e=tar.gz"
+    BROOKLYN_DIR="brooklyn-dist-${BROOKLYN_VERSION}"
+  fi
+else
+  echo "Installing from a local -dist archive [ /vagrant/brooklyn-dist-${BROOKLYN_VERSION}-dist.tar.gz]"
+  # url to install from mounted /vagrant dir
+  BROOKLYN_URL="file:///vagrant/brooklyn-dist-${BROOKLYN_VERSION}-dist.tar.gz"
+  BROOKLYN_DIR="brooklyn-dist-${BROOKLYN_VERSION}"
+
+  # ensure local file exists
+  if [ ! -f /vagrant/brooklyn-dist-${BROOKLYN_VERSION}-dist.tar.gz ]; then
+    echo "Error: file not found /vagrant/brooklyn-dist-${BROOKLYN_VERSION}-dist.tar.gz"
+    exit 1
+  fi
+fi
+
+echo "Installing Apache Brooklyn version ${BROOKLYN_VERSION} from [${BROOKLYN_URL}]"
+
+echo "Downloading Brooklyn release archive"
+curl --fail --silent --show-error --location --output ${TMP_ARCHIVE_NAME} "${BROOKLYN_URL}"
+echo "Extracting Brooklyn release archive"
+tar zxf ${TMP_ARCHIVE_NAME}
+
+echo "Creating Brooklyn dirs and symlinks"
+ln -s ${BROOKLYN_DIR} apache-brooklyn
+sudo mkdir -p /var/log/brooklyn
+sudo chown -R vagrant:vagrant /var/log/brooklyn
+mkdir -p /home/vagrant/.brooklyn
+
+echo "Copying default vagrant Brooklyn properties file"
+cp /vagrant/files/brooklyn.properties /home/vagrant/.brooklyn/
+chmod 600 /home/vagrant/.brooklyn/brooklyn.properties
+
+echo "Installing JRE"
+sudo sh -c 'export DEBIAN_FRONTEND=noninteractive; apt-get install --yes openjdk-8-jre-headless'
+
+echo "Copying Brooklyn systemd service unit file"
+sudo cp /vagrant/files/brooklyn.service /etc/systemd/system/brooklyn.service
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/88327712/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml b/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml
index 5203171..3959fff 100644
--- a/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml
+++ b/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml
@@ -16,6 +16,21 @@
 # specific language governing permissions and limitations
 # under the License.
 #
+#
+# Default Config
+#   check_newer_vagrant_box
+#     enable/disable the vagrant check for an updated box
+#   run_os_update
+#     enable/disable running a yum/apt-get update on box start
+#
+# Brooklyn Server Config
+#   shell:env:BROOKLYN_VERSION
+#     specifies the version of Brooklyn to install, be aware that for SNAPSHOTS you
+#     may wish to download a local -dist.tar.gz for the latest version.
+#   shell:env:INSTALL_FROM_LOCAL_DIST
+#     if set to `true` Vagrant will install from a local -dist.tar.gz stored in /vagrant
+#     on the guest VM (which is mounted from the Vagrantfile directory). You must
+#     ensure that a -dist.tar.gz archive has been copied to this directory on your host.
 
 ---
 default_config:
@@ -30,17 +45,9 @@ servers:
     shell:
       env:
         BROOKLYN_VERSION: 0.9.0-SNAPSHOT
+        INSTALL_FROM_LOCAL_DIST: false
       cmd:
-        - sudo sh -c 'export DEBIAN_FRONTEND=noninteractive; apt-get install --yes openjdk-8-jre-headless'
-        - curl -s -S -J -O -L "https://www.apache.org/dyn/closer.cgi?action=download&filename=brooklyn/apache-brooklyn-${BROOKLYN_VERSION}/apache-brooklyn-${BROOKLYN_VERSION}-bin.tar.gz"
-        - tar zxf apache-brooklyn-${BROOKLYN_VERSION}-bin.tar.gz
-        - ln -s apache-brooklyn-${BROOKLYN_VERSION}-bin apache-brooklyn
-        - sudo mkdir -p /var/log/brooklyn
-        - sudo chown -R vagrant:vagrant /var/log/brooklyn
-        - sudo cp /vagrant/files/brooklyn.service /etc/systemd/system/brooklyn.service
-        - mkdir -p /home/vagrant/.brooklyn
-        - cp /vagrant/files/brooklyn.properties /home/vagrant/.brooklyn/
-        - chmod 600 /home/vagrant/.brooklyn/brooklyn.properties
+        - /vagrant/files/install_brooklyn.sh -v ${BROOKLYN_VERSION} -l ${INSTALL_FROM_LOCAL_DIST}
         - sudo systemctl start brooklyn
         - sudo systemctl enable brooklyn
   - name: byon1


[26/51] [abbrv] brooklyn-dist git commit: update make-release-artifacts to work with current repo structure

Posted by he...@apache.org.
update make-release-artifacts to work with current repo structure


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

Branch: refs/heads/master
Commit: d09c9455373705d14e6e961db5739e938bd9413b
Parents: 7f9016f
Author: John McCabe <jo...@johnmccabe.net>
Authored: Thu Jan 21 18:42:08 2016 +0000
Committer: John McCabe <jo...@johnmccabe.net>
Committed: Thu Jan 21 18:42:08 2016 +0000

----------------------------------------------------------------------
 brooklyn-dist/release/make-release-artifacts.sh | 10 ++++++----
 1 file changed, 6 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/d09c9455/brooklyn-dist/release/make-release-artifacts.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/make-release-artifacts.sh b/brooklyn-dist/release/make-release-artifacts.sh
index 476a6e3..dfdd976 100755
--- a/brooklyn-dist/release/make-release-artifacts.sh
+++ b/brooklyn-dist/release/make-release-artifacts.sh
@@ -18,7 +18,9 @@
 # under the License.
 #
 
-# creates a source release - this is a .tar.gz file containing all the source code files that are permitted to be released.
+# Creates the following releases with archives (.tar.gz/.zip), signatures and checksums:
+#   binary  (-bin)     - contains the brooklyn dist binary release
+#   source  (-src)     - contains all the source code files that are permitted to be released
 
 set -e
 
@@ -179,7 +181,7 @@ mkdir -p ${bin_staging_dir}
 # * release (where this is running, and people who *have* the release don't need to make it)
 # * jars and friends (these are sometimes included for tests, but those are marked as skippable,
 #     and apache convention does not allow them in source builds; see PR #365
-rsync -rtp --exclude .git\* --exclude docs/ --exclude sandbox/ --exclude release/ --exclude '**/*.[ejw]ar' . ${staging_dir}/${release_name}-src
+rsync -rtp --exclude .git\* --exclude brooklyn-docs/ --exclude brooklyn-library/sandbox/ --exclude brooklyn-dist/release/ --exclude '**/*.[ejw]ar' . ${staging_dir}/${release_name}-src
 
 rm -rf ${artifact_dir}
 mkdir -p ${artifact_dir}
@@ -210,10 +212,10 @@ fi
 # Perform the build and deploy to Nexus staging repository
 ( cd ${src_staging_dir} && mvn deploy -Papache-release )
 ## To test the script without a big deploy, use the line below instead of above
-#( cd ${src_staging_dir} && cd usage/dist && mvn clean install )
+#( cd ${src_staging_dir} && mvn clean install )
 
 # Re-pack the archive with the correct names
-tar xzf ${src_staging_dir}/usage/dist/target/brooklyn-dist-${current_version}-dist.tar.gz -C ${bin_staging_dir}
+tar xzf ${src_staging_dir}/brooklyn-dist/dist/target/brooklyn-dist-${current_version}-dist.tar.gz -C ${bin_staging_dir}
 mv ${bin_staging_dir}/brooklyn-dist-${current_version} ${bin_staging_dir}/${release_name}-bin
 
 ( cd ${bin_staging_dir} && tar czf ${artifact_dir}/${artifact_name}-bin.tar.gz ${release_name}-bin )


[30/51] [abbrv] brooklyn-dist git commit: fix RAT violations

Posted by he...@apache.org.
fix RAT violations


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

Branch: refs/heads/master
Commit: b1f392c67db990919b778849067fbac109ca850a
Parents: c81f483
Author: John McCabe <jo...@johnmccabe.net>
Authored: Sun Jan 24 22:24:50 2016 +0000
Committer: John McCabe <jo...@johnmccabe.net>
Committed: Sun Jan 24 22:24:50 2016 +0000

----------------------------------------------------------------------
 .../vagrant/src/main/vagrant/Vagrantfile        | 20 +++++++++++++++++++-
 .../src/main/vagrant/files/brooklyn.properties  | 19 +++++++++++++++++++
 .../src/main/vagrant/files/brooklyn.service     | 19 +++++++++++++++++++
 .../vagrant/src/main/vagrant/files/logback.xml  | 20 ++++++++++++++++++++
 .../vagrant/src/main/vagrant/servers.yaml       | 19 +++++++++++++++++++
 5 files changed, 96 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/b1f392c6/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile b/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
index f5f7927..395e8bc 100644
--- a/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
+++ b/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
@@ -1,5 +1,23 @@
 # -*- mode: ruby -*-
-# # vi: set ft=ruby :
+# vi: set ft=ruby :
+#
+# 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.
+#
 
 # Specify minimum Vagrant version and Vagrant API version
 Vagrant.require_version ">= 1.8.1"

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/b1f392c6/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties b/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties
index 22f8688..0784ff3 100644
--- a/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties
+++ b/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties
@@ -1,3 +1,22 @@
+#
+# 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.
+#
+
 # Disabling security on the Vagrant Brooklyn instance for training purposes
 brooklyn.webconsole.security.provider = org.apache.brooklyn.rest.security.provider.AnyoneSecurityProvider
 

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/b1f392c6/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service b/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service
index 5fe2767..28b0fea 100644
--- a/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service
+++ b/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service
@@ -1,3 +1,22 @@
+#
+# 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.
+#
+
 [Unit]
 Description=Apache Brooklyn service
 Documentation=http://brooklyn.apache.org/documentation/index.html

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/b1f392c6/brooklyn-dist/vagrant/src/main/vagrant/files/logback.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/files/logback.xml b/brooklyn-dist/vagrant/src/main/vagrant/files/logback.xml
index 77b3816..1560d8b 100644
--- a/brooklyn-dist/vagrant/src/main/vagrant/files/logback.xml
+++ b/brooklyn-dist/vagrant/src/main/vagrant/files/logback.xml
@@ -1,3 +1,23 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+
 <configuration scan="true">
 
     <!-- to supply custom logging, either change this file, supply your own logback-main.xml

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/b1f392c6/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml b/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml
index 0bf133b..5203171 100644
--- a/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml
+++ b/brooklyn-dist/vagrant/src/main/vagrant/servers.yaml
@@ -1,3 +1,22 @@
+#
+# 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.
+#
+
 ---
 default_config:
     check_newer_vagrant_box: true


[17/51] [abbrv] brooklyn-dist git commit: [SPLITPREP] revert version to 0.9.0-SNAPSHOT

Posted by he...@apache.org.
[SPLITPREP] revert version to 0.9.0-SNAPSHOT


Project: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/repo
Commit: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/commit/501bfe3b
Tree: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/tree/501bfe3b
Diff: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/diff/501bfe3b

Branch: refs/heads/master
Commit: 501bfe3b257c21025e114674f73da659aeb92e74
Parents: 9d9e2ce
Author: Alex Heneveld <al...@cloudsoftcorp.com>
Authored: Mon Dec 21 12:25:50 2015 +0000
Committer: Alex Heneveld <al...@cloudsoftcorp.com>
Committed: Mon Dec 21 16:43:39 2015 +0000

----------------------------------------------------------------------
 brooklyn-dist/all/pom.xml                                       | 2 +-
 brooklyn-dist/archetypes/quickstart/NOTES.txt                   | 2 +-
 brooklyn-dist/archetypes/quickstart/pom.xml                     | 2 +-
 brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml | 2 +-
 brooklyn-dist/dist/pom.xml                                      | 2 +-
 brooklyn-dist/downstream-parent/pom.xml                         | 4 ++--
 brooklyn-dist/pom.xml                                           | 4 ++--
 7 files changed, 9 insertions(+), 9 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/501bfe3b/brooklyn-dist/all/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/all/pom.xml b/brooklyn-dist/all/pom.xml
index 46397b1..bcaa758 100644
--- a/brooklyn-dist/all/pom.xml
+++ b/brooklyn-dist/all/pom.xml
@@ -31,7 +31,7 @@
     <parent>
         <groupId>org.apache.brooklyn</groupId>
         <artifactId>brooklyn-dist-root</artifactId>
-        <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
         <relativePath>../pom.xml</relativePath>
     </parent>
 

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/501bfe3b/brooklyn-dist/archetypes/quickstart/NOTES.txt
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/NOTES.txt b/brooklyn-dist/archetypes/quickstart/NOTES.txt
index d195558..4028bf6 100644
--- a/brooklyn-dist/archetypes/quickstart/NOTES.txt
+++ b/brooklyn-dist/archetypes/quickstart/NOTES.txt
@@ -32,7 +32,7 @@ To test a build:
 
     pushd /tmp
     rm -rf brooklyn-sample
-    export BV=0.9.SPLITWIP-SNAPSHOT    # BROOKLYN_VERSION
+    export BV=0.9.0-SNAPSHOT    # BROOKLYN_VERSION
     
     mvn archetype:generate                                  \
                                                             \

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/501bfe3b/brooklyn-dist/archetypes/quickstart/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/pom.xml b/brooklyn-dist/archetypes/quickstart/pom.xml
index 7154f76..f47c395 100644
--- a/brooklyn-dist/archetypes/quickstart/pom.xml
+++ b/brooklyn-dist/archetypes/quickstart/pom.xml
@@ -31,7 +31,7 @@
   <parent>
     <groupId>org.apache.brooklyn</groupId>
     <artifactId>brooklyn-parent</artifactId>
-    <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
     <relativePath>../../../brooklyn-server/parent/pom.xml</relativePath>
   </parent>
 

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/501bfe3b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
index f879498..44f5f93 100644
--- a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
+++ b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
@@ -7,7 +7,7 @@
   <parent>
     <groupId>org.apache.brooklyn</groupId>
     <artifactId>brooklyn-downstream-parent</artifactId>
-    <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
   </parent>
 
   <groupId>com.acme.sample</groupId>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/501bfe3b/brooklyn-dist/dist/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/pom.xml b/brooklyn-dist/dist/pom.xml
index abc6522..a595094 100644
--- a/brooklyn-dist/dist/pom.xml
+++ b/brooklyn-dist/dist/pom.xml
@@ -32,7 +32,7 @@
     <parent>
         <groupId>org.apache.brooklyn</groupId>
         <artifactId>brooklyn-dist-root</artifactId>
-        <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
         <relativePath>../pom.xml</relativePath>
     </parent>
 

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/501bfe3b/brooklyn-dist/downstream-parent/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/downstream-parent/pom.xml b/brooklyn-dist/downstream-parent/pom.xml
index 9b7cc73..6a7d694 100644
--- a/brooklyn-dist/downstream-parent/pom.xml
+++ b/brooklyn-dist/downstream-parent/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <groupId>org.apache.brooklyn</groupId>
     <artifactId>brooklyn-server</artifactId>
-    <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
     <relativePath>../../brooklyn-server/pom.xml</relativePath>
     <!-- TODO this uses server root pom as a way to get version info without rat check;
          it means it inherits apache pom, which might not be desired.
@@ -53,7 +53,7 @@
     <excludedTestGroups>Integration,Acceptance,Live,Live-sanity,WIP</excludedTestGroups>
 
     <!-- Dependencies -->
-    <brooklyn.version>0.9.SPLITWIP-SNAPSHOT</brooklyn.version>  <!-- BROOKLYN_VERSION -->
+    <brooklyn.version>0.9.0-SNAPSHOT</brooklyn.version>  <!-- BROOKLYN_VERSION -->
     <jclouds.groupId>org.apache.jclouds</jclouds.groupId> <!-- JCLOUDS_GROUPID_VERSION -->
 
     <!-- versions should match those used by Brooklyn, to avoid conflicts -->

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/501bfe3b/brooklyn-dist/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/pom.xml b/brooklyn-dist/pom.xml
index 652738c..a2ecb3a 100644
--- a/brooklyn-dist/pom.xml
+++ b/brooklyn-dist/pom.xml
@@ -24,13 +24,13 @@
     <parent>
         <groupId>org.apache.brooklyn</groupId>
         <artifactId>brooklyn-parent</artifactId>
-        <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
         <relativePath>../brooklyn-server/parent/pom.xml</relativePath>
     </parent>
 
     <groupId>org.apache.brooklyn</groupId>
     <artifactId>brooklyn-dist-root</artifactId>
-    <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
     <packaging>pom</packaging>
 
     <name>Brooklyn Dist Root</name>


[44/51] [abbrv] brooklyn-dist git commit: move subdir from incubator up a level as it is promoted to its own repo (first non-incubator commit!)

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/binary/CDDL1.1
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/binary/CDDL1.1 b/dist/licensing/licenses/binary/CDDL1.1
new file mode 100644
index 0000000..def9b35
--- /dev/null
+++ b/dist/licensing/licenses/binary/CDDL1.1
@@ -0,0 +1,304 @@
+COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.1
+
+  1. Definitions.
+  
+  1.1. “Contributor” means each individual or entity that creates or contributes
+  to the creation of Modifications.
+  
+  1.2. “Contributor Version” means the combination of the Original Software,
+  prior Modifications used by a Contributor (if any), and the Modifications made
+  by that particular Contributor.
+  
+  1.3. “Covered Software” means (a) the Original Software, or (b) Modifications,
+  or (c) the combination of files containing Original Software with files
+  containing Modifications, in each case including portions thereof.
+  
+  1.4. “Executable” means the Covered Software in any form other than Source
+  Code.
+  
+  1.5. “Initial Developer” means the individual or entity that first makes
+  Original Software available under this License.
+  
+  1.6. “Larger Work” means a work which combines Covered Software or portions
+  thereof with code not governed by the terms of this License.
+  
+  1.7. “License” means this document.
+  
+  1.8. “Licensable” means having the right to grant, to the maximum extent
+  possible, whether at the time of the initial grant or subsequently acquired,
+  any and all of the rights conveyed herein.
+  
+  1.9. “Modifications” means the Source Code and Executable form of any of the
+  following:
+  
+  A. Any file that results from an addition to, deletion from or modification of
+  the contents of a file containing Original Software or previous Modifications;
+  
+  B. Any new file that contains any part of the Original Software or previous
+  Modification; or
+  
+  C. Any new file that is contributed or otherwise made available under the terms
+  of this License.
+  
+  1.10. “Original Software” means the Source Code and Executable form of computer
+  software code that is originally released under this License.
+  
+  1.11. “Patent Claims” means any patent claim(s), now owned or hereafter
+  acquired, including without limitation, method, process, and apparatus claims,
+  in any patent Licensable by grantor.
+  
+  1.12. “Source Code” means (a) the common form of computer software code in
+  which modifications are made and (b) associated documentation included in or
+  with such code.
+  
+  1.13. “You” (or “Your”) means an individual or a legal entity exercising rights
+  under, and complying with all of the terms of, this License. For legal
+  entities, “You” includes any entity which controls, is controlled by, or is
+  under common control with You. For purposes of this definition, “control” means
+  (a) the power, direct or indirect, to cause the direction or management of such
+  entity, whether by contract or otherwise, or (b) ownership of more than fifty
+  percent (50%) of the outstanding shares or beneficial ownership of such entity.
+  
+  2. License Grants.
+  
+  2.1. The Initial Developer Grant.  Conditioned upon Your compliance with
+  Section 3.1 below and subject to third party intellectual property claims, the
+  Initial Developer hereby grants You a world-wide, royalty-free, non-exclusive
+  license:
+  
+  (a) under intellectual property rights (other than patent or trademark)
+  Licensable by Initial Developer, to use, reproduce, modify, display, perform,
+  sublicense and distribute the Original Software (or portions thereof), with or
+  without Modifications, and/or as part of a Larger Work; and
+  
+  (b) under Patent Claims infringed by the making, using or selling of Original
+  Software, to make, have made, use, practice, sell, and offer for sale, and/or
+  otherwise dispose of the Original Software (or portions thereof).
+  
+  (c) The licenses granted in Sections 2.1(a) and (b) are effective on the date
+  Initial Developer first distributes or otherwise makes the Original Software
+  available to a third party under the terms of this License.
+  
+  (d) Notwithstanding Section 2.1(b) above, no patent license is granted: (1) for
+  code that You delete from the Original Software, or (2) for infringements
+  caused by: (i) the modification of the Original Software, or (ii) the
+  combination of the Original Software with other software or devices.
+  
+  2.2. Contributor Grant.  Conditioned upon Your compliance with Section 3.1
+  below and subject to third party intellectual property claims, each Contributor
+  hereby grants You a world-wide, royalty-free, non-exclusive license:
+  
+  (a) under intellectual property rights (other than patent or trademark)
+  Licensable by Contributor to use, reproduce, modify, display, perform,
+  sublicense and distribute the Modifications created by such Contributor (or
+  portions thereof), either on an unmodified basis, with other Modifications, as
+  Covered Software and/or as part of a Larger Work; and
+  
+  (b) under Patent Claims infringed by the making, using, or selling of
+  Modifications made by that Contributor either alone and/or in combination with
+  its Contributor Version (or portions of such combination), to make, use, sell,
+  offer for sale, have made, and/or otherwise dispose of: (1) Modifications made
+  by that Contributor (or portions thereof); and (2) the combination of
+  Modifications made by that Contributor with its Contributor Version (or
+  portions of such combination).
+  
+  (c) The licenses granted in Sections 2.2(a) and 2.2(b) are effective on the
+  date Contributor first distributes or otherwise makes the Modifications
+  available to a third party.
+  
+  (d) Notwithstanding Section 2.2(b) above, no patent license is granted: (1) for
+  any code that Contributor has deleted from the Contributor Version; (2) for
+  infringements caused by: (i) third party modifications of Contributor Version,
+  or (ii) the combination of Modifications made by that Contributor with other
+  software (except as part of the Contributor Version) or other devices; or (3)
+  under Patent Claims infringed by Covered Software in the absence of
+  Modifications made by that Contributor.
+  
+  3. Distribution Obligations.
+  
+  3.1. Availability of Source Code.  Any Covered Software that You distribute or
+  otherwise make available in Executable form must also be made available in
+  Source Code form and that Source Code form must be distributed only under the
+  terms of this License. You must include a copy of this License with every copy
+  of the Source Code form of the Covered Software You distribute or otherwise
+  make available. You must inform recipients of any such Covered Software in
+  Executable form as to how they can obtain such Covered Software in Source Code
+  form in a reasonable manner on or through a medium customarily used for
+  software exchange.
+  
+  3.2. Modifications.  The Modifications that You create or to which You
+  contribute are governed by the terms of this License. You represent that You
+  believe Your Modifications are Your original creation(s) and/or You have
+  sufficient rights to grant the rights conveyed by this License.
+  
+  3.3. Required Notices.  You must include a notice in each of Your Modifications
+  that identifies You as the Contributor of the Modification. You may not remove
+  or alter any copyright, patent or trademark notices contained within the
+  Covered Software, or any notices of licensing or any descriptive text giving
+  attribution to any Contributor or the Initial Developer.
+  
+  3.4. Application of Additional Terms.  You may not offer or impose any terms on
+  any Covered Software in Source Code form that alters or restricts the
+  applicable version of this License or the recipients' rights hereunder. You may
+  choose to offer, and to charge a fee for, warranty, support, indemnity or
+  liability obligations to one or more recipients of Covered Software. However,
+  you may do so only on Your own behalf, and not on behalf of the Initial
+  Developer or any Contributor. You must make it absolutely clear that any such
+  warranty, support, indemnity or liability obligation is offered by You alone,
+  and You hereby agree to indemnify the Initial Developer and every Contributor
+  for any liability incurred by the Initial Developer or such Contributor as a
+  result of warranty, support, indemnity or liability terms You offer.
+  
+  3.5. Distribution of Executable Versions.  You may distribute the Executable
+  form of the Covered Software under the terms of this License or under the terms
+  of a license of Your choice, which may contain terms different from this
+  License, provided that You are in compliance with the terms of this License and
+  that the license for the Executable form does not attempt to limit or alter the
+  recipient's rights in the Source Code form from the rights set forth in this
+  License. If You distribute the Covered Software in Executable form under a
+  different license, You must make it absolutely clear that any terms which
+  differ from this License are offered by You alone, not by the Initial Developer
+  or Contributor. You hereby agree to indemnify the Initial Developer and every
+  Contributor for any liability incurred by the Initial Developer or such
+  Contributor as a result of any such terms You offer.
+  
+  3.6. Larger Works.  You may create a Larger Work by combining Covered Software
+  with other code not governed by the terms of this License and distribute the
+  Larger Work as a single product. In such a case, You must make sure the
+  requirements of this License are fulfilled for the Covered Software.
+  
+  4. Versions of the License.
+  
+  4.1. New Versions.  Oracle is the initial license steward and may publish
+  revised and/or new versions of this License from time to time. Each version
+  will be given a distinguishing version number. Except as provided in Section
+  4.3, no one other than the license steward has the right to modify this
+  License.
+  
+  4.2. Effect of New Versions.  You may always continue to use, distribute or
+  otherwise make the Covered Software available under the terms of the version of
+  the License under which You originally received the Covered Software. If the
+  Initial Developer includes a notice in the Original Software prohibiting it
+  from being distributed or otherwise made available under any subsequent version
+  of the License, You must distribute and make the Covered Software available
+  under the terms of the version of the License under which You originally
+  received the Covered Software. Otherwise, You may also choose to use,
+  distribute or otherwise make the Covered Software available under the terms of
+  any subsequent version of the License published by the license steward.
+  
+  4.3. Modified Versions.  When You are an Initial Developer and You want to
+  create a new license for Your Original Software, You may create and use a
+  modified version of this License if You: (a) rename the license and remove any
+  references to the name of the license steward (except to note that the license
+  differs from this License); and (b) otherwise make it clear that the license
+  contains terms which differ from this License.
+  
+  5. DISCLAIMER OF WARRANTY.  COVERED SOFTWARE IS PROVIDED UNDER THIS LICENSE ON
+  AN “AS IS” BASIS, WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED,
+  INCLUDING, WITHOUT LIMITATION, WARRANTIES THAT THE COVERED SOFTWARE IS FREE OF
+  DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR PURPOSE OR NON-INFRINGING. THE
+  ENTIRE RISK AS TO THE QUALITY AND PERFORMANCE OF THE COVERED SOFTWARE IS WITH
+  YOU. SHOULD ANY COVERED SOFTWARE PROVE DEFECTIVE IN ANY RESPECT, YOU (NOT THE
+  INITIAL DEVELOPER OR ANY OTHER CONTRIBUTOR) ASSUME THE COST OF ANY NECESSARY
+  SERVICING, REPAIR OR CORRECTION. THIS DISCLAIMER OF WARRANTY CONSTITUTES AN
+  ESSENTIAL PART OF THIS LICENSE. NO USE OF ANY COVERED SOFTWARE IS AUTHORIZED
+  HEREUNDER EXCEPT UNDER THIS DISCLAIMER.
+  
+  6. TERMINATION.
+  
+  6.1. This License and the rights granted hereunder will terminate automatically
+  if You fail to comply with terms herein and fail to cure such breach within 30
+  days of becoming aware of the breach. Provisions which, by their nature, must
+  remain in effect beyond the termination of this License shall survive.
+  
+  6.2. If You assert a patent infringement claim (excluding declaratory judgment
+  actions) against Initial Developer or a Contributor (the Initial Developer or
+  Contributor against whom You assert such claim is referred to as “Participant”)
+  alleging that the Participant Software (meaning the Contributor Version where
+  the Participant is a Contributor or the Original Software where the Participant
+  is the Initial Developer) directly or indirectly infringes any patent, then any
+  and all rights granted directly or indirectly to You by such Participant, the
+  Initial Developer (if the Initial Developer is not the Participant) and all
+  Contributors under Sections 2.1 and/or 2.2 of this License shall, upon 60 days
+  notice from Participant terminate prospectively and automatically at the
+  expiration of such 60 day notice period, unless if within such 60 day period
+  You withdraw Your claim with respect to the Participant Software against such
+  Participant either unilaterally or pursuant to a written agreement with
+  Participant.
+  
+  6.3. If You assert a patent infringement claim against Participant alleging
+  that the Participant Software directly or indirectly infringes any patent where
+  such claim is resolved (such as by license or settlement) prior to the
+  initiation of patent infringement litigation, then the reasonable value of the
+  licenses granted by such Participant under Sections 2.1 or 2.2 shall be taken
+  into account in determining the amount or value of any payment or license.
+  
+  6.4. In the event of termination under Sections 6.1 or 6.2 above, all end user
+  licenses that have been validly granted by You or any distributor hereunder
+  prior to termination (excluding licenses granted to You by any distributor)
+  shall survive termination.
+  
+  7. LIMITATION OF LIABILITY.
+  
+  UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT (INCLUDING
+  NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE INITIAL DEVELOPER, ANY
+  OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF COVERED SOFTWARE, OR ANY SUPPLIER OF
+  ANY OF SUCH PARTIES, BE LIABLE TO ANY PERSON FOR ANY INDIRECT, SPECIAL,
+  INCIDENTAL, OR CONSEQUENTIAL DAMAGES OF ANY CHARACTER INCLUDING, WITHOUT
+  LIMITATION, DAMAGES FOR LOSS OF GOODWILL, WORK STOPPAGE, COMPUTER FAILURE OR
+  MALFUNCTION, OR ANY AND ALL OTHER COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH
+  PARTY SHALL HAVE BEEN INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS
+  LIMITATION OF LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL
+  INJURY RESULTING FROM SUCH PARTY'S NEGLIGENCE TO THE EXTENT APPLICABLE LAW
+  PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO NOT ALLOW THE EXCLUSION OR
+  LIMITATION OF INCIDENTAL OR CONSEQUENTIAL DAMAGES, SO THIS EXCLUSION AND
+  LIMITATION MAY NOT APPLY TO YOU.
+  
+  8. U.S. GOVERNMENT END USERS.
+  
+  The Covered Software is a “commercial item,” as that term is defined in 48
+  C.F.R. 2.101 (Oct. 1995), consisting of “commercial computer software” (as that
+  term is defined at 48 C.F.R. § 252.227-7014(a)(1)) and “commercial computer
+  software documentation” as such terms are used in 48 C.F.R. 12.212 (Sept.
+  1995). Consistent with 48 C.F.R. 12.212 and 48 C.F.R. 227.7202-1 through
+  227.7202-4 (June 1995), all U.S. Government End Users acquire Covered Software
+  with only those rights set forth herein. This U.S. Government Rights clause is
+  in lieu of, and supersedes, any other FAR, DFAR, or other clause or provision
+  that addresses Government rights in computer software under this License.
+  
+  9. MISCELLANEOUS.
+  
+  This License represents the complete agreement concerning subject matter
+  hereof. If any provision of this License is held to be unenforceable, such
+  provision shall be reformed only to the extent necessary to make it
+  enforceable. This License shall be governed by the law of the jurisdiction
+  specified in a notice contained within the Original Software (except to the
+  extent applicable law, if any, provides otherwise), excluding such
+  jurisdiction's conflict-of-law provisions. Any litigation relating to this
+  License shall be subject to the jurisdiction of the courts located in the
+  jurisdiction and venue specified in a notice contained within the Original
+  Software, with the losing party responsible for costs, including, without
+  limitation, court costs and reasonable attorneys' fees and expenses. The
+  application of the United Nations Convention on Contracts for the International
+  Sale of Goods is expressly excluded. Any law or regulation which provides that
+  the language of a contract shall be construed against the drafter shall not
+  apply to this License. You agree that You alone are responsible for compliance
+  with the United States export administration regulations (and the export
+  control laws and regulation of any other countries) when You use, distribute or
+  otherwise make available any Covered Software.
+  
+  10. RESPONSIBILITY FOR CLAIMS.
+  
+  As between Initial Developer and the Contributors, each party is responsible
+  for claims and damages arising, directly or indirectly, out of its utilization
+  of rights under this License and You agree to work with Initial Developer and
+  Contributors to distribute such responsibility on an equitable basis. Nothing
+  herein is intended or shall be deemed to constitute any admission of liability.
+  
+  NOTICE PURSUANT TO SECTION 9 OF THE COMMON DEVELOPMENT AND DISTRIBUTION LICENSE
+  (CDDL) The code released under the CDDL shall be governed by the laws of the
+  State of California (excluding conflict-of-law provisions). Any litigation
+  relating to this License shall be subject to the jurisdiction of the Federal
+  Courts of the Northern District of California and the state courts of the State
+  of California, with venue lying in Santa Clara County, California.
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/binary/EPL1
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/binary/EPL1 b/dist/licensing/licenses/binary/EPL1
new file mode 100644
index 0000000..6891076
--- /dev/null
+++ b/dist/licensing/licenses/binary/EPL1
@@ -0,0 +1,212 @@
+Eclipse Public License, version 1.0
+
+  THE ACCOMPANYING PROGRAM IS PROVIDED UNDER THE TERMS OF THIS ECLIPSE PUBLIC
+  LICENSE ("AGREEMENT"). ANY USE, REPRODUCTION OR DISTRIBUTION OF THE PROGRAM
+  CONSTITUTES RECIPIENT'S ACCEPTANCE OF THIS AGREEMENT.
+  
+  1. DEFINITIONS
+  
+  "Contribution" means:
+  
+  a) in the case of the initial Contributor, the initial code and documentation
+  distributed under this Agreement, and b) in the case of each subsequent
+  Contributor:
+  
+  i) changes to the Program, and
+  
+  ii) additions to the Program;
+  
+  where such changes and/or additions to the Program originate from and are
+  distributed by that particular Contributor. A Contribution 'originates' from a
+  Contributor if it was added to the Program by such Contributor itself or anyone
+  acting on such Contributor's behalf. Contributions do not include additions to
+  the Program which: (i) are separate modules of software distributed in
+  conjunction with the Program under their own license agreement, and (ii) are
+  not derivative works of the Program.
+  
+  "Contributor" means any person or entity that distributes the Program.
+  
+  "Licensed Patents " mean patent claims licensable by a Contributor which are
+  necessarily infringed by the use or sale of its Contribution alone or when
+  combined with the Program.
+  
+  "Program" means the Contributions distributed in accordance with this
+  Agreement.
+  
+  "Recipient" means anyone who receives the Program under this Agreement,
+  including all Contributors.
+  
+  2. GRANT OF RIGHTS
+  
+  a) Subject to the terms of this Agreement, each Contributor hereby grants
+  Recipient a non-exclusive, worldwide, royalty-free copyright license to
+  reproduce, prepare derivative works of, publicly display, publicly perform,
+  distribute and sublicense the Contribution of such Contributor, if any, and
+  such derivative works, in source code and object code form.
+  
+  b) Subject to the terms of this Agreement, each Contributor hereby grants
+  Recipient a non-exclusive, worldwide, royalty-free patent license under
+  Licensed Patents to make, use, sell, offer to sell, import and otherwise
+  transfer the Contribution of such Contributor, if any, in source code and
+  object code form. This patent license shall apply to the combination of the
+  Contribution and the Program if, at the time the Contribution is added by the
+  Contributor, such addition of the Contribution causes such combination to be
+  covered by the Licensed Patents. The patent license shall not apply to any
+  other combinations which include the Contribution. No hardware per se is
+  licensed hereunder.
+  
+  c) Recipient understands that although each Contributor grants the licenses to
+  its Contributions set forth herein, no assurances are provided by any
+  Contributor that the Program does not infringe the patent or other intellectual
+  property rights of any other entity. Each Contributor disclaims any liability
+  to Recipient for claims brought by any other entity based on infringement of
+  intellectual property rights or otherwise. As a condition to exercising the
+  rights and licenses granted hereunder, each Recipient hereby assumes sole
+  responsibility to secure any other intellectual property rights needed, if any.
+  For example, if a third party patent license is required to allow Recipient to
+  distribute the Program, it is Recipient's responsibility to acquire that
+  license before distributing the Program.
+  
+  d) Each Contributor represents that to its knowledge it has sufficient
+  copyright rights in its Contribution, if any, to grant the copyright license
+  set forth in this Agreement.
+  
+  3. REQUIREMENTS
+  
+  A Contributor may choose to distribute the Program in object code form under
+  its own license agreement, provided that:
+  
+  a) it complies with the terms and conditions of this Agreement; and
+  
+  b) its license agreement:
+  
+  i) effectively disclaims on behalf of all Contributors all warranties and
+  conditions, express and implied, including warranties or conditions of title
+  and non-infringement, and implied warranties or conditions of merchantability
+  and fitness for a particular purpose;
+  
+  ii) effectively excludes on behalf of all Contributors all liability for
+  damages, including direct, indirect, special, incidental and consequential
+  damages, such as lost profits;
+  
+  iii) states that any provisions which differ from this Agreement are offered by
+  that Contributor alone and not by any other party; and
+  
+  iv) states that source code for the Program is available from such Contributor,
+  and informs licensees how to obtain it in a reasonable manner on or through a
+  medium customarily used for software exchange.
+  
+  When the Program is made available in source code form:
+  
+  a) it must be made available under this Agreement; and
+  
+  b) a copy of this Agreement must be included with each copy of the Program.
+  
+  Contributors may not remove or alter any copyright notices contained within the
+  Program.
+  
+  Each Contributor must identify itself as the originator of its Contribution, if
+  any, in a manner that reasonably allows subsequent Recipients to identify the
+  originator of the Contribution.
+  
+  4. COMMERCIAL DISTRIBUTION
+  
+  Commercial distributors of software may accept certain responsibilities with
+  respect to end users, business partners and the like. While this license is
+  intended to facilitate the commercial use of the Program, the Contributor who
+  includes the Program in a commercial product offering should do so in a manner
+  which does not create potential liability for other Contributors. Therefore, if
+  a Contributor includes the Program in a commercial product offering, such
+  Contributor ("Commercial Contributor") hereby agrees to defend and indemnify
+  every other Contributor ("Indemnified Contributor") against any losses, damages
+  and costs (collectively "Losses") arising from claims, lawsuits and other legal
+  actions brought by a third party against the Indemnified Contributor to the
+  extent caused by the acts or omissions of such Commercial Contributor in
+  connection with its distribution of the Program in a commercial product
+  offering. The obligations in this section do not apply to any claims or Losses
+  relating to any actual or alleged intellectual property infringement. In order
+  to qualify, an Indemnified Contributor must: a) promptly notify the Commercial
+  Contributor in writing of such claim, and b) allow the Commercial Contributor
+  to control, and cooperate with the Commercial Contributor in, the defense and
+  any related settlement negotiations. The Indemnified Contributor may
+  participate in any such claim at its own expense.
+  
+  For example, a Contributor might include the Program in a commercial product
+  offering, Product X. That Contributor is then a Commercial Contributor. If that
+  Commercial Contributor then makes performance claims, or offers warranties
+  related to Product X, those performance claims and warranties are such
+  Commercial Contributor's responsibility alone. Under this section, the
+  Commercial Contributor would have to defend claims against the other
+  Contributors related to those performance claims and warranties, and if a court
+  requires any other Contributor to pay any damages as a result, the Commercial
+  Contributor must pay those damages.
+  
+  5. NO WARRANTY
+  
+  EXCEPT AS EXPRESSLY SET FORTH IN THIS AGREEMENT, THE PROGRAM IS PROVIDED ON AN
+  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, EITHER EXPRESS OR
+  IMPLIED INCLUDING, WITHOUT LIMITATION, ANY WARRANTIES OR CONDITIONS OF TITLE,
+  NON-INFRINGEMENT, MERCHANTABILITY OR FITNESS FOR A PARTICULAR PURPOSE. Each
+  Recipient is solely responsible for determining the appropriateness of using
+  and distributing the Program and assumes all risks associated with its exercise
+  of rights under this Agreement , including but not limited to the risks and
+  costs of program errors, compliance with applicable laws, damage to or loss of
+  data, programs or equipment, and unavailability or interruption of operations.
+  
+  6. DISCLAIMER OF LIABILITY
+  
+  EXCEPT AS EXPRESSLY SET FORTH IN THIS AGREEMENT, NEITHER RECIPIENT NOR ANY
+  CONTRIBUTORS SHALL HAVE ANY LIABILITY FOR ANY DIRECT, INDIRECT, INCIDENTAL,
+  SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING WITHOUT LIMITATION LOST
+  PROFITS), HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT,
+  STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY
+  WAY OUT OF THE USE OR DISTRIBUTION OF THE PROGRAM OR THE EXERCISE OF ANY RIGHTS
+  GRANTED HEREUNDER, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGES.
+  
+  7. GENERAL
+  
+  If any provision of this Agreement is invalid or unenforceable under applicable
+  law, it shall not affect the validity or enforceability of the remainder of the
+  terms of this Agreement, and without further action by the parties hereto, such
+  provision shall be reformed to the minimum extent necessary to make such
+  provision valid and enforceable.
+  
+  If Recipient institutes patent litigation against any entity (including a
+  cross-claim or counterclaim in a lawsuit) alleging that the Program itself
+  (excluding combinations of the Program with other software or hardware)
+  infringes such Recipient's patent(s), then such Recipient's rights granted
+  under Section 2(b) shall terminate as of the date such litigation is filed.
+  
+  All Recipient's rights under this Agreement shall terminate if it fails to
+  comply with any of the material terms or conditions of this Agreement and does
+  not cure such failure in a reasonable period of time after becoming aware of
+  such noncompliance. If all Recipient's rights under this Agreement terminate,
+  Recipient agrees to cease use and distribution of the Program as soon as
+  reasonably practicable. However, Recipient's obligations under this Agreement
+  and any licenses granted by Recipient relating to the Program shall continue
+  and survive.
+  
+  Everyone is permitted to copy and distribute copies of this Agreement, but in
+  order to avoid inconsistency the Agreement is copyrighted and may only be
+  modified in the following manner. The Agreement Steward reserves the right to
+  publish new versions (including revisions) of this Agreement from time to time.
+  No one other than the Agreement Steward has the right to modify this Agreement.
+  The Eclipse Foundation is the initial Agreement Steward. The Eclipse Foundation
+  may assign the responsibility to serve as the Agreement Steward to a suitable
+  separate entity. Each new version of the Agreement will be given a
+  distinguishing version number. The Program (including Contributions) may always
+  be distributed subject to the version of the Agreement under which it was
+  received. In addition, after a new version of the Agreement is published,
+  Contributor may elect to distribute the Program (including its Contributions)
+  under the new version. Except as expressly stated in Sections 2(a) and 2(b)
+  above, Recipient receives no rights or licenses to the intellectual property of
+  any Contributor under this Agreement, whether expressly, by implication,
+  estoppel or otherwise. All rights in the Program not expressly granted under
+  this Agreement are reserved.
+  
+  This Agreement is governed by the laws of the State of New York and the
+  intellectual property laws of the United States of America. No party to this
+  Agreement will bring a legal action under this Agreement more than one year
+  after the cause of action arose. Each party waives its rights to a jury trial
+  in any resulting litigation.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/binary/MIT
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/binary/MIT b/dist/licensing/licenses/binary/MIT
new file mode 100644
index 0000000..71dfb45
--- /dev/null
+++ b/dist/licensing/licenses/binary/MIT
@@ -0,0 +1,20 @@
+The MIT License ("MIT")
+
+  Permission is hereby granted, free of charge, to any person obtaining a copy
+  of this software and associated documentation files (the "Software"), to deal
+  in the Software without restriction, including without limitation the rights
+  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
+  copies of the Software, and to permit persons to whom the Software is
+  furnished to do so, subject to the following conditions:
+  
+  The above copyright notice and this permission notice shall be included in
+  all copies or substantial portions of the Software.
+  
+  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
+  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
+  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
+  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
+  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
+  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
+  THE SOFTWARE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/binary/WTFPL
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/binary/WTFPL b/dist/licensing/licenses/binary/WTFPL
new file mode 100644
index 0000000..03c1695
--- /dev/null
+++ b/dist/licensing/licenses/binary/WTFPL
@@ -0,0 +1,15 @@
+WTF Public License
+
+  DO WHAT THE FUCK YOU WANT TO PUBLIC LICENSE, Version 2, December 2004 
+ 
+  Copyright (C) 2004 Sam Hocevar <sa...@hocevar.net> 
+ 
+  Everyone is permitted to copy and distribute verbatim or modified 
+  copies of this license document, and changing it is allowed as long 
+  as the name is changed. 
+ 
+             DO WHAT THE FUCK YOU WANT TO PUBLIC LICENSE 
+    TERMS AND CONDITIONS FOR COPYING, DISTRIBUTION AND MODIFICATION 
+ 
+   0. You just DO WHAT THE FUCK YOU WANT TO.
+ 

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/binary/bouncycastle
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/binary/bouncycastle b/dist/licensing/licenses/binary/bouncycastle
new file mode 100644
index 0000000..8589a0b
--- /dev/null
+++ b/dist/licensing/licenses/binary/bouncycastle
@@ -0,0 +1,23 @@
+Bouncy Castle License
+  
+  Copyright (c) 2000 - 2015 The Legion of the Bouncy Castle Inc.
+  (http://www.bouncycastle.org)
+  
+  Permission is hereby granted, free of charge, to any person obtaining a copy of
+  this software and associated documentation files (the "Software"), to deal in
+  the Software without restriction, including without limitation the rights to
+  use, copy, modify, merge, publish, distribute, sublicense, and/or sell copies
+  of the Software, and to permit persons to whom the Software is furnished to do
+  so, subject to the following conditions:
+  
+  The above copyright notice and this permission notice shall be included in all
+  copies or substantial portions of the Software.
+  
+  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
+  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
+  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
+  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
+  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
+  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE
+  SOFTWARE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/binary/jtidy
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/binary/jtidy b/dist/licensing/licenses/binary/jtidy
new file mode 100644
index 0000000..0bcb614
--- /dev/null
+++ b/dist/licensing/licenses/binary/jtidy
@@ -0,0 +1,53 @@
+JTidy License
+
+  Java HTML Tidy - JTidy
+  HTML parser and pretty printer
+  
+  Copyright (c) 1998-2000 World Wide Web Consortium (Massachusetts
+  Institute of Technology, Institut National de Recherche en
+  Informatique et en Automatique, Keio University). All Rights
+  Reserved.
+  
+  Contributing Author(s):
+  
+     Dave Raggett <ds...@w3.org>
+     Andy Quick <ac...@sympatico.ca> (translation to Java)
+     Gary L Peskin <ga...@firstech.com> (Java development)
+     Sami Lempinen <sa...@lempinen.net> (release management)
+     Fabrizio Giustina <fgiust at users.sourceforge.net>
+  
+  The contributing author(s) would like to thank all those who
+  helped with testing, bug fixes, and patience.  This wouldn't
+  have been possible without all of you.
+  
+  COPYRIGHT NOTICE:
+   
+  This software and documentation is provided "as is," and
+  the copyright holders and contributing author(s) make no
+  representations or warranties, express or implied, including
+  but not limited to, warranties of merchantability or fitness
+  for any particular purpose or that the use of the software or
+  documentation will not infringe any third party patents,
+  copyrights, trademarks or other rights. 
+  
+  The copyright holders and contributing author(s) will not be
+  liable for any direct, indirect, special or consequential damages
+  arising out of any use of the software or documentation, even if
+  advised of the possibility of such damage.
+  
+  Permission is hereby granted to use, copy, modify, and distribute
+  this source code, or portions hereof, documentation and executables,
+  for any purpose, without fee, subject to the following restrictions:
+  
+  1. The origin of this source code must not be misrepresented.
+  2. Altered versions must be plainly marked as such and must
+     not be misrepresented as being the original source.
+  3. This Copyright notice may not be removed or altered from any
+     source or altered source distribution.
+   
+  The copyright holders and contributing author(s) specifically
+  permit, without fee, and encourage the use of this source code
+  as a component for supporting the Hypertext Markup Language in
+  commercial products. If you use this source code in a product,
+  acknowledgment is not required but would be appreciated.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/binary/jython
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/binary/jython b/dist/licensing/licenses/binary/jython
new file mode 100644
index 0000000..b2258d4
--- /dev/null
+++ b/dist/licensing/licenses/binary/jython
@@ -0,0 +1,27 @@
+Jython License
+
+  Jython 2.0, 2.1 License
+  
+  Copyright (c) 2000, 2001, 2002, 2003, 2004, 2005, 2006, 2007 Jython Developers All rights reserved.
+  
+  Redistribution and use in source and binary forms, with or without modification, are permitted provided 
+  that the following conditions are met:
+  
+  Redistributions of source code must retain the above copyright notice, this list of conditions and the 
+  following disclaimer.
+  
+  Redistributions in binary form must reproduce the above copyright notice, this list of conditions and 
+  the following disclaimer in the documentation and/or other materials provided with the distribution.
+  Neither the name of the Jython Developers nor the names of its contributors may be used to endorse or 
+  promote products derived from this software without specific prior written permission.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS'' AND ANY EXPRESS OR IMPLIED 
+  WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A 
+  PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE REGENTS OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
+  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO, 
+  PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) 
+  HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING 
+  NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
+  POSSIBILITY OF SUCH DAMAGE.
+  
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/binary/metastuff-bsd-style
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/binary/metastuff-bsd-style b/dist/licensing/licenses/binary/metastuff-bsd-style
new file mode 100644
index 0000000..6bb4ef6
--- /dev/null
+++ b/dist/licensing/licenses/binary/metastuff-bsd-style
@@ -0,0 +1,43 @@
+MetaStuff BSD Style License
+
+  Copyright 2001-2005 (C) MetaStuff, Ltd. All Rights Reserved.
+  
+  Redistribution and use of this software and associated documentation
+  ("Software"), with or without modification, are permitted provided
+  that the following conditions are met:
+  
+  1. Redistributions of source code must retain copyright
+     statements and notices.  Redistributions must also contain a
+     copy of this document.
+  
+  2. Redistributions in binary form must reproduce the
+     above copyright notice, this list of conditions and the
+     following disclaimer in the documentation and/or other
+     materials provided with the distribution.
+  
+  3. The name "DOM4J" must not be used to endorse or promote
+     products derived from this Software without prior written
+     permission of MetaStuff, Ltd.  For written permission,
+     please contact dom4j-info@metastuff.com.
+  
+  4. Products derived from this Software may not be called "DOM4J"
+     nor may "DOM4J" appear in their names without prior written
+     permission of MetaStuff, Ltd. DOM4J is a registered
+     trademark of MetaStuff, Ltd.
+  
+  5. Due credit should be given to the DOM4J Project -
+     http://www.dom4j.org
+  
+  THIS SOFTWARE IS PROVIDED BY METASTUFF, LTD. AND CONTRIBUTORS
+  ``AS IS'' AND ANY EXPRESSED OR IMPLIED WARRANTIES, INCLUDING, BUT
+  NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND
+  FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED.  IN NO EVENT SHALL
+  METASTUFF, LTD. OR ITS CONTRIBUTORS BE LIABLE FOR ANY DIRECT,
+  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES
+  (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
+  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION)
+  HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT,
+  STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE)
+  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED
+  OF THE POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/binary/xpp3_indiana_university
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/binary/xpp3_indiana_university b/dist/licensing/licenses/binary/xpp3_indiana_university
new file mode 100644
index 0000000..7d69a29
--- /dev/null
+++ b/dist/licensing/licenses/binary/xpp3_indiana_university
@@ -0,0 +1,45 @@
+Indiana University Extreme! Lab Software License, Version 1.1.1
+
+  Copyright (c) 2002 Extreme! Lab, Indiana University. All rights reserved.
+  
+  Redistribution and use in source and binary forms, with or without
+  modification, are permitted provided that the following conditions
+  are met:
+  
+  1. Redistributions of source code must retain the above copyright notice,
+     this list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright
+     notice, this list of conditions and the following disclaimer in
+     the documentation and/or other materials provided with the distribution.
+  
+  3. The end-user documentation included with the redistribution, if any,
+     must include the following acknowledgment:
+  
+    "This product includes software developed by the Indiana University
+    Extreme! Lab (http://www.extreme.indiana.edu/)."
+  
+  Alternately, this acknowledgment may appear in the software itself,
+  if and wherever such third-party acknowledgments normally appear.
+  
+  4. The names "Indiana Univeristy" and "Indiana Univeristy Extreme! Lab"
+  must not be used to endorse or promote products derived from this
+  software without prior written permission. For written permission,
+  please contact http://www.extreme.indiana.edu/.
+  
+  5. Products derived from this software may not use "Indiana Univeristy"
+  name nor may "Indiana Univeristy" appear in their name, without prior
+  written permission of the Indiana University.
+  
+  THIS SOFTWARE IS PROVIDED "AS IS" AND ANY EXPRESSED OR IMPLIED
+  WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF
+  MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED.
+  IN NO EVENT SHALL THE AUTHORS, COPYRIGHT HOLDERS OR ITS CONTRIBUTORS
+  BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR
+  CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF
+  SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR PROFITS; OR
+  BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY,
+  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR
+  OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF
+  ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/brooklyn-ui/BSD-2-Clause
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/brooklyn-ui/BSD-2-Clause b/dist/licensing/licenses/brooklyn-ui/BSD-2-Clause
new file mode 100644
index 0000000..832c10e
--- /dev/null
+++ b/dist/licensing/licenses/brooklyn-ui/BSD-2-Clause
@@ -0,0 +1,23 @@
+The BSD 2-Clause License
+
+  Redistribution and use in source and binary forms, with or without
+  modification, are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, this
+  list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice,
+  this list of conditions and the following disclaimer in the documentation
+  and/or other materials provided with the distribution.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
+  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
+  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
+  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
+  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
+  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
+  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
+  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/brooklyn-ui/BSD-3-Clause
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/brooklyn-ui/BSD-3-Clause b/dist/licensing/licenses/brooklyn-ui/BSD-3-Clause
new file mode 100644
index 0000000..be2692c
--- /dev/null
+++ b/dist/licensing/licenses/brooklyn-ui/BSD-3-Clause
@@ -0,0 +1,27 @@
+The BSD 3-Clause License ("New BSD")
+
+  Redistribution and use in source and binary forms, with or without modification,
+  are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, 
+  this list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice, 
+  this list of conditions and the following disclaimer in the documentation 
+  and/or other materials provided with the distribution.
+  
+  3. Neither the name of the copyright holder nor the names of its contributors 
+  may be used to endorse or promote products derived from this software without 
+  specific prior written permission.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
+  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
+  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
+  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
+  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
+  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
+  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
+  POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/brooklyn-ui/MIT
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/brooklyn-ui/MIT b/dist/licensing/licenses/brooklyn-ui/MIT
new file mode 100644
index 0000000..71dfb45
--- /dev/null
+++ b/dist/licensing/licenses/brooklyn-ui/MIT
@@ -0,0 +1,20 @@
+The MIT License ("MIT")
+
+  Permission is hereby granted, free of charge, to any person obtaining a copy
+  of this software and associated documentation files (the "Software"), to deal
+  in the Software without restriction, including without limitation the rights
+  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
+  copies of the Software, and to permit persons to whom the Software is
+  furnished to do so, subject to the following conditions:
+  
+  The above copyright notice and this permission notice shall be included in
+  all copies or substantial portions of the Software.
+  
+  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
+  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
+  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
+  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
+  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
+  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
+  THE SOFTWARE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/server-cli/MIT
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/server-cli/MIT b/dist/licensing/licenses/server-cli/MIT
new file mode 100644
index 0000000..71dfb45
--- /dev/null
+++ b/dist/licensing/licenses/server-cli/MIT
@@ -0,0 +1,20 @@
+The MIT License ("MIT")
+
+  Permission is hereby granted, free of charge, to any person obtaining a copy
+  of this software and associated documentation files (the "Software"), to deal
+  in the Software without restriction, including without limitation the rights
+  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
+  copies of the Software, and to permit persons to whom the Software is
+  furnished to do so, subject to the following conditions:
+  
+  The above copyright notice and this permission notice shall be included in
+  all copies or substantial portions of the Software.
+  
+  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
+  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
+  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
+  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
+  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
+  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
+  THE SOFTWARE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/source/BSD-2-Clause
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/source/BSD-2-Clause b/dist/licensing/licenses/source/BSD-2-Clause
new file mode 100644
index 0000000..832c10e
--- /dev/null
+++ b/dist/licensing/licenses/source/BSD-2-Clause
@@ -0,0 +1,23 @@
+The BSD 2-Clause License
+
+  Redistribution and use in source and binary forms, with or without
+  modification, are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, this
+  list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice,
+  this list of conditions and the following disclaimer in the documentation
+  and/or other materials provided with the distribution.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
+  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
+  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
+  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
+  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
+  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
+  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
+  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/source/BSD-3-Clause
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/source/BSD-3-Clause b/dist/licensing/licenses/source/BSD-3-Clause
new file mode 100644
index 0000000..be2692c
--- /dev/null
+++ b/dist/licensing/licenses/source/BSD-3-Clause
@@ -0,0 +1,27 @@
+The BSD 3-Clause License ("New BSD")
+
+  Redistribution and use in source and binary forms, with or without modification,
+  are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, 
+  this list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice, 
+  this list of conditions and the following disclaimer in the documentation 
+  and/or other materials provided with the distribution.
+  
+  3. Neither the name of the copyright holder nor the names of its contributors 
+  may be used to endorse or promote products derived from this software without 
+  specific prior written permission.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
+  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
+  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
+  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
+  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
+  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
+  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
+  POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/licenses/source/MIT
----------------------------------------------------------------------
diff --git a/dist/licensing/licenses/source/MIT b/dist/licensing/licenses/source/MIT
new file mode 100644
index 0000000..71dfb45
--- /dev/null
+++ b/dist/licensing/licenses/source/MIT
@@ -0,0 +1,20 @@
+The MIT License ("MIT")
+
+  Permission is hereby granted, free of charge, to any person obtaining a copy
+  of this software and associated documentation files (the "Software"), to deal
+  in the Software without restriction, including without limitation the rights
+  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
+  copies of the Software, and to permit persons to whom the Software is
+  furnished to do so, subject to the following conditions:
+  
+  The above copyright notice and this permission notice shall be included in
+  all copies or substantial portions of the Software.
+  
+  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
+  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
+  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
+  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
+  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
+  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
+  THE SOFTWARE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/make-all-licenses.sh
----------------------------------------------------------------------
diff --git a/dist/licensing/make-all-licenses.sh b/dist/licensing/make-all-licenses.sh
new file mode 100755
index 0000000..b08d17f
--- /dev/null
+++ b/dist/licensing/make-all-licenses.sh
@@ -0,0 +1,65 @@
+#
+# 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.
+#
+
+# generates LICENSE files for source and binary,
+# and for each of `projects-with-custom-licenses`
+
+set -e
+
+# update the extras-files file from projects-with-custom-licenses
+cat projects-with-custom-licenses | awk '{ printf("%s/src/main/license/source-inclusions.yaml:", $0); }' | sed 's/:$//' > extras-files
+
+unset BROOKLYN_LICENSE_SPECIALS
+unset BROOKLYN_LICENSE_EXTRAS_FILES
+unset BROOKLYN_LICENSE_MODE
+
+# source build, at root and each sub-project
+export BROOKLYN_LICENSE_MODE=source
+echo MAKING LICENSES FOR: ${BROOKLYN_LICENSE_MODE}
+export BROOKLYN_LICENSE_SPECIALS=-DonlyExtras=true 
+./make-one-license.sh > LICENSE.autogenerated
+cp LICENSE.autogenerated ../../../LICENSE
+# overwrite any existing licenses at root
+for x in ../../../brooklyn-*/LICENSE ; do cp LICENSE.autogenerated $x ; done
+unset BROOKLYN_LICENSE_SPECIALS
+unset BROOKLYN_LICENSE_MODE
+
+# binary build, in dist
+export BROOKLYN_LICENSE_MODE=binary
+echo MAKING LICENSES FOR: ${BROOKLYN_LICENSE_MODE}
+./make-one-license.sh > LICENSE.autogenerated
+cp LICENSE.autogenerated ../src/main/license/files/LICENSE
+unset BROOKLYN_LICENSE_MODE
+
+# individual projects
+for x in `cat projects-with-custom-licenses` ; do
+  export BROOKLYN_LICENSE_MODE=`basename $x`
+  echo MAKING LICENSES FOR: ${BROOKLYN_LICENSE_MODE}
+  export BROOKLYN_LICENSE_SPECIALS=-DonlyExtras=true
+  export BROOKLYN_LICENSE_EXTRAS_FILES=$x/src/main/license/source-inclusions.yaml
+  cp licenses/`basename $x`/* licenses/source
+  ./make-one-license.sh > LICENSE.autogenerated || ( echo FAILED. See details in tmp_stdout/err. && false )
+  cp LICENSE.autogenerated ../$x/src/main/license/files/LICENSE
+  # also copy to root of that project *if* there is already a LICENSE file there
+  [ -f ../$x/LICENSE ] && cp LICENSE.autogenerated ../$x/LICENSE || true
+  unset BROOKLYN_LICENSE_SPECIALS
+  unset BROOKLYN_LICENSE_EXTRAS_FILES
+  unset BROOKLYN_LICENSE_MODE
+done
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/make-one-license.sh
----------------------------------------------------------------------
diff --git a/dist/licensing/make-one-license.sh b/dist/licensing/make-one-license.sh
new file mode 100755
index 0000000..5bcb35b
--- /dev/null
+++ b/dist/licensing/make-one-license.sh
@@ -0,0 +1,79 @@
+#
+# 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.
+#
+
+set -e
+
+# generates a LICENSE file, including notices and other licenses as needed
+# uses various env vars BROOKLYN_LICENSE_* to determine appropriate behaviour;
+# see make-licenses.sh for examples
+
+ls MAIN_LICENSE_ASL2 > /dev/null 2> /dev/null || ( echo "Must run in licensing directory (where this script lives)" > /dev/stderr && false )
+
+if [ -z "${BROOKLYN_LICENSE_MODE}" ] ; then echo BROOKLYN_LICENSE_MODE must be set > /dev/stderr ; false ; fi
+
+
+cat << EOF
+
+This software is distributed under the Apache License, version 2.0. See (1) below.
+This software is copyright (c) The Apache Software Foundation and contributors.
+
+Contents:
+
+  (1) This software license: Apache License, version 2.0
+  (2) Notices for bundled software
+  (3) Licenses for bundled software
+
+
+EOF
+
+echo "---------------------------------------------------"
+echo
+echo "(1) This software license: Apache License, version 2.0"
+echo
+cat MAIN_LICENSE_ASL2
+echo
+echo "---------------------------------------------------"
+echo
+echo "(2) Notices for bundled software"
+echo
+pushd .. > /dev/null
+# add -X on next line to get debug info
+mvn org.heneveld.maven:license-audit-maven-plugin:notices \
+        -DlicensesPreferred=ASL2,ASL,EPL1,BSD-2-Clause,BSD-3-Clause,CDDL1.1,CDDL1,CDDL \
+        -DoverridesFile=licensing/overrides.yaml \
+        -DextrasFiles=${BROOKLYN_LICENSE_EXTRAS_FILES:-`cat licensing/extras-files`} \
+        ${BROOKLYN_LICENSE_SPECIALS} \
+        -DoutputFile=licensing/notices.autogenerated \
+    > tmp_stdout 2> tmp_stderr
+rm tmp_std*
+popd > /dev/null
+cat notices.autogenerated
+
+echo
+echo "---------------------------------------------------"
+echo
+echo "(3) Licenses for bundled software"
+echo
+echo Contents:
+echo
+for x in licenses/${BROOKLYN_LICENSE_MODE}/* ; do head -1 $x | awk '{print "  "$0;}' ; done
+echo
+echo
+for x in licenses/${BROOKLYN_LICENSE_MODE}/* ; do cat $x ; echo ; done
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/overrides.yaml
----------------------------------------------------------------------
diff --git a/dist/licensing/overrides.yaml b/dist/licensing/overrides.yaml
new file mode 100644
index 0000000..1285df4
--- /dev/null
+++ b/dist/licensing/overrides.yaml
@@ -0,0 +1,385 @@
+#
+# 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.
+#
+
+
+# overrides file for org.heneveld.license-audit-maven-plugin
+# expands/corrects detail needed for generating license notices
+
+
+# super-projects to suppress notices for sub-projects
+
+- id: org.apache.brooklyn
+  url: http://brooklyn.incubator.apache.org/
+  license: ASL2
+  internal: true
+
+# poms with missing and incorrect data
+
+- id: org.codehaus.jettison:jettison
+  url: https://github.com/codehaus/jettison
+  license: ASL2 
+- id: org.glassfish.external:opendmk_jmxremote_optional_jar
+  url: https://opendmk.java.net/
+  license: CDDL
+- id: javax.validation:validation-api
+  url: http://beanvalidation.org/
+- id: com.squareup.okhttp:okhttp
+  copyright_by: Square, Inc.
+- id: com.squareup.okio:okio
+  copyright_by: Square, Inc.
+- id: com.wordnik:swagger-core_2.9.1
+  copyright_by: SmartBear Software
+- id: com.wordnik:swagger-jaxrs_2.9.1
+  copyright_by: SmartBear Software
+- id: org.bouncycastle  
+  copyright_by: The Legion of the Bouncy Castle Inc. (http://www.bouncycastle.org)
+- id: org.javassist:javassist
+  copyright_by: Shigeru Chiba
+- id: org.mongodb:mongo-java-driver
+  copyright_by: MongoDB, Inc
+- id: org.apache.httpcomponents:httpclient:*
+  url: http://hc.apache.org/httpcomponents-client-ga
+- id: javax.annotation:jsr250-api:*
+  url: https://jcp.org/en/jsr/detail?id=250
+- id: javax.ws.rs:jsr311-api:*
+  url: https://jsr311.java.net/
+- id: com.thoughtworks.xstream:*:*
+  url: http://x-stream.github.io/
+- id: com.fasterxml.jackson:*:*
+  url: http://wiki.fasterxml.com/JacksonHome
+
+- id: org.hibernate:jtidy:r8-20060801
+  license:
+  - url: "http://sourceforge.net/p/jtidy/code/HEAD/tree/trunk/jtidy/LICENSE.txt?revision=95"
+    name: Java HTML Tidy License
+    comment: Original link http://svn.sourceforge.net/viewvc/*checkout*/jtidy/trunk/jtidy/LICENSE.txt?revision=95 is no longer valid
+
+- id: dom4j:dom4j:1.6.1
+  url: "http://dom4j.sourceforge.net/"
+  license:
+  - name: MetaStuff BSD style license (3-clause)
+    url: http://dom4j.sourceforge.net/dom4j-1.6.1/license.html
+
+- id: org.python:jython-standalone:2.7-b3
+  copyright_by: Jython Developers
+  license:
+  - url: http://www.jython.org/license.html
+    name: Jython Software License
+    comment: Original link http://www.jython.org/Project/license.html is no longer valid
+
+- id: xpp3:xpp3_min:*
+  copyright_by: Extreme! Lab, Indiana University
+  license:
+  - url: https://github.com/apache/openmeetings/blob/a95714ce3f7e587d13d3d0bb3b4f570be15c67a5/LICENSE#L1361
+    name: "Indiana University Extreme! Lab Software License, vesion 1.1.1"
+    comment: |
+      The license applies to the Xpp3 classes (all classes below the org.xmlpull package with exception of classes directly in package org.xmlpull.v1);
+      original link http://www.extreme.indiana.edu/viewcvs/~checkout~/XPP3/java/LICENSE.txt is no longer valid
+  ## as we pull in xmlpull separately we do not use this, and having a single above simplifies the automation:
+  #  - url: http://creativecommons.org/licenses/publicdomain
+  #    name: Public Domain
+  #    comment: "The license applies to the XmlPull API (all classes directly in the org.xmlpull.v1 package)"
+
+
+# info on non-maven projects
+
+# used in UI
+- id: jquery-core:1.7.2
+  url: http://jquery.com/
+  description: JS library for manipulating HTML and eventing
+  name: jQuery JavaScript Library
+  files: jquery.js
+  version: 1.7.2
+  organization: { name: "The jQuery Foundation", url: "http://jquery.org/" }
+  license: MIT
+  notices: 
+  - Copyright (c) John Resig (2005-2011)
+  - "Includes code fragments from sizzle.js:"
+  - "  Copyright (c) The Dojo Foundation"
+  - "  Available at http://sizzlejs.com"
+  - "  Used under the MIT license"
+
+- id: jquery-core:1.8.0
+  url: http://jquery.com/
+  description: JS library for manipulating HTML and eventing
+  name: jQuery JavaScript Library
+  files: jquery.js
+  version: 1.8.0
+  organization: { name: "The jQuery Foundation", url: "http://jquery.org/" }
+  license: MIT
+  notices:
+  - Copyright (c) The jQuery Foundation, Inc. and other contributors (2005-2012)
+  - "Includes code fragments from sizzle.js:"
+  # NB: sizzle copyright changed from Dojo Foundation in 1.7.2
+  - "  Copyright (c) The jQuery Foundation, Inc. and other contributors (2012)"
+  - "  Available at http://sizzlejs.com"
+  - "  Used under the MIT license"
+# used in docs (not reported)
+- id: jquery-core:2.1.1
+  url: http://jquery.com/
+  description: JS library for manipulating HTML and eventing
+  name: jQuery JavaScript Library
+  files: jquery.js
+  version: 2.1.1
+  organization: { name: "The jQuery Foundation", url: "http://jquery.org/" }
+  license: MIT
+  notices: 
+  - Copyright (c) The jQuery Foundation, Inc. and other contributors (2005-2014)
+  - "Includes code fragments from sizzle.js:"
+  # NB: sizzle copyright changed from Dojo Foundation in 1.7.2
+  - "  Copyright (c) The jQuery Foundation, Inc. and other contributors (2013)"
+  - "  Available at http://sizzlejs.com"
+  - "  Used under the MIT license"
+
+# not used anymore? swagger-ui includes what it needs, it seems.
+- id: swagger:2.1.6
+  name: Swagger JS
+  files: swagger-client.js
+  version: 2.1.6
+  url: https://github.com/swagger-api/swagger-js
+  license: ASL2
+  notice: Copyright (c) SmartBear Software (2011-2015)
+
+- id: swagger-ui:2.1.4
+  files: swagger*.{js,css,html}
+  name: Swagger UI
+  version: 2.1.4
+  url: https://github.com/swagger-api/swagger-ui
+  license: ASL2
+  notice: Copyright (c) SmartBear Software (2011-2015)
+  
+- id: jquery.wiggle.min.js
+  name: jQuery Wiggle
+  version: swagger-ui:1.0.1
+  notices: 
+  - Copyright (c) WonderGroup and Jordan Thomas (2010)
+  - Previously online at http://labs.wondergroup.com/demos/mini-ui/index.html.
+  # that is link in copyright but it is no longer valid; url below is same person
+  - The version included here is from the Swagger UI distribution.
+  url: https://github.com/jordanthomas/jquery-wiggle
+  license: MIT
+
+- id: require.js
+  name: RequireJS 
+  files: require.js, text.js
+  version: 2.0.6 
+  url: http://requirejs.org/
+  organization: { name: "The Dojo Foundation", url: "http://dojofoundation.org/" }
+  notice: Copyright (c) The Dojo Foundation (2010-2012)
+  license: MIT
+
+- id: require.js/r.js
+  # new ID because this is a different version to the above
+  name: RequireJS (r.js maven plugin)
+  files: r.js
+  version: 2.1.6 
+  url: http://github.com/jrburke/requirejs
+  organization: { name: "The Dojo Foundation", url: "http://dojofoundation.org/" }
+  notices:
+  - Copyright (c) The Dojo Foundation (2009-2013)
+  - "Includes code fragments for source-map and other functionality:" 
+  - "  Copyright (c) The Mozilla Foundation and contributors (2011)"
+  - "  Used under the BSD 2-Clause license."
+  - "Includes code fragments for parse-js and other functionality:" 
+  - "  Copyright (c) Mihai Bazon (2010, 2012)"
+  - "  Used under the BSD 2-Clause license."
+  - "Includes code fragments for uglifyjs/consolidator:" 
+  - "  Copyright (c) Robert Gust-Bardon (2012)"
+  - "  Used under the BSD 2-Clause license."
+  - "Includes code fragments for the esprima parser:" 
+  - "  Copyright (c):"
+  - "    Ariya Hidayat (2011, 2012)"
+  - "    Mathias Bynens (2012)"
+  - "    Joost-Wim Boekesteijn (2012)"
+  - "    Kris Kowal (2012)"
+  - "    Yusuke Suzuki (2012)"
+  - "    Arpad Borsos (2012)"
+  - "  Used under the BSD 2-Clause license."
+  license: MIT
+
+- id: backbone.js
+  version: 1.0.0
+  url: http://backbonejs.org
+  organization: { name: "DocumentCloud Inc.", url: "http://www.documentcloud.org/" }
+  notice: Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2010-2013)
+  license: MIT
+
+- id: backbone.js:1.1.2
+  version: 1.1.2
+  url: http://backbonejs.org
+  organization: { name: "DocumentCloud Inc.", url: "http://www.documentcloud.org/" }
+  notice: Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2010-2014)
+  license: MIT
+
+- id: bootstrap.js
+  version: 2.0.4
+  url: http://twitter.github.com/bootstrap/javascript.html#transitions
+  notice: Copyright (c) Twitter, Inc. (2012)
+  license: ASL2
+ 
+# used in docs (not needed for licensing) 
+- id: bootstrap.js:3.1.1
+  version: 3.1.1
+  url: http://getbootstrap.com/
+  notice: Copyright (c) Twitter, Inc. (2011-2014)
+  license: MIT
+  
+- id: underscore.js
+  version: 1.4.4
+  files: underscore*.{js,map}
+  url: http://underscorejs.org
+  organization: { name: "DocumentCloud Inc.", url: "http://www.documentcloud.org/" }
+  notice: Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2009-2013)
+  license: MIT
+
+# used in CLI (and in docs)
+- id: underscore.js:1.7.0
+  version: 1.7.0
+  files: underscore*.{js,map}
+  url: http://underscorejs.org
+  organization: { name: "DocumentCloud Inc.", url: "http://www.documentcloud.org/" }
+  notice: "Copyright (c) Jeremy Ashkenas, DocumentCloud and Investigative Reporters & Editors (2009-2014)"
+  license: MIT
+
+- id: async.js
+  version: 0.1.1
+  url: https://github.com/p15martin/google-maps-hello-world/blob/master/js/libs/async.js
+  # ORIGINALLY https://github.com/millermedeiros/requirejs-plugins
+  organization: { name: "Miller Medeiros", url: "https://github.com/millermedeiros/" }
+  description: RequireJS plugin for async dependency load like JSONP and Google Maps
+  notice: Copyright (c) Miller Medeiros (2011)
+  license: MIT 
+
+- id: handlebars.js
+  files: handlebars*.js
+  version: 1.0-rc1
+  url: https://github.com/wycats/handlebars.js 
+  organization: { name: "Yehuda Katz", url: "https://github.com/wycats/" }
+  notice: Copyright (c) Yehuda Katz (2012)
+  license: MIT
+
+- id: handlebars.js:2.0.0
+  files: handlebars*.js
+  version: 2.0.0
+  url: https://github.com/wycats/handlebars.js
+  organization: { name: "Yehuda Katz", url: "https://github.com/wycats/" }
+  notice: Copyright (c) Yehuda Katz (2014)
+  license: MIT
+
+- id: jquery.ba-bbq.js
+  name: "jQuery BBQ: Back Button & Query Library"
+  files: jquery.ba-bbq*.js
+  version: 1.2.1
+  url: http://benalman.com/projects/jquery-bbq-plugin/
+  organization: { name: "\"Cowboy\" Ben Alman", url: "http://benalman.com/" }
+  notice: Copyright (c) "Cowboy" Ben Alman (2010)"
+  license: MIT
+
+- id: moment.js
+  version: 2.1.0
+  url: http://momentjs.com
+  organization: { name: "Tim Wood", url: "http://momentjs.com" }
+  notice: Copyright (c) Tim Wood, Iskren Chernev, Moment.js contributors (2011-2014)
+  license: MIT
+
+- id: ZeroClipboard
+  files: ZeroClipboard.*
+  version: 1.3.1
+  url: http://zeroclipboard.org/
+  organization: { name: "ZeroClipboard contributors", url: "https://github.com/zeroclipboard" }
+  notice: Copyright (c) Jon Rohan, James M. Greene (2014)
+  license: MIT
+
+- id: jquery.dataTables
+  files: jquery.dataTables.{js,css}
+  name: DataTables Table plug-in for jQuery
+  version: 1.9.4
+  url: http://www.datatables.net/
+  organization: { name: "SpryMedia Ltd", url: "http://sprymedia.co.uk/" }
+  notice: Copyright (c) Allan Jardine (2008-2012)
+  license: BSD-3-Clause
+
+- id: js-uri
+  files: URI.js
+  version: 0.1
+  url: http://code.google.com/p/js-uri/
+  organization: { name: "js-uri contributors", url: "https://code.google.com/js-uri" }
+  license: BSD-3-Clause
+  # inferred
+  notice: Copyright (c) js-uri contributors (2013)
+
+- id: js-yaml.js
+  version: 3.2.7
+  organization: { name: "Vitaly Puzrin", url: "https://github.com/nodeca/" }
+  url: https://github.com/nodeca/
+  notice: Copyright (c) Vitaly Puzrin (2011-2015)
+  license: MIT
+
+- id: jquery.form.js
+  name: jQuery Form Plugin
+  version: "3.09"
+  url: https://github.com/malsup/form
+  # also http://malsup.com/jquery/form/
+  organization: { name: "Mike Alsup", url: "http://malsup.com/" }
+  notice: Copyright (c) M. Alsup (2006-2013)
+  license: MIT
+
+# used for CLI to build catalog
+- id: typeahead.js
+  version: 0.10.5
+  url: https://github.com/twitter/typeahead.js
+  organization: { name: "Twitter, Inc", url: "http://twitter.com" }
+  notice: Copyright (c) Twitter, Inc. and other contributors (2013-2014)
+  license: MIT
+
+# used for CLI to build catalog
+- id: marked.js
+  version: 0.3.1
+  url: https://github.com/chjj/marked
+  organization: { name: "Christopher Jeffrey", url: "https://github.com/chjj" }
+  notice: Copyright (c) Christopher Jeffrey (2011-2014)
+  license: MIT
+
+# DOCS files
+#
+# we don't do a distributable docs build -- they are just online.
+# (docs are excluded from the source build, and not bundled with the binary build.)
+# so these are not used currently; but for completeness and in case we change our minds,
+# here they are:
+
+# * different versions of jquery, bootstrap, and underscore noted above,
+# * media items github octicons and font-awesome fonts, not listed
+# * plus the below:
+
+- id: jquery.superfish.js
+  files: superfish.js
+  name: Superfish jQuery Menu Widget
+  version: 1.4.8
+  url: http://users.tpg.com.au/j_birch/plugins/superfish/
+  notice: Copyright (c) Joel Birch (2008)
+  license: MIT
+
+- id: jquery.cookie.js
+  name: jQuery Cookie Plugin
+  version: 1.3.1
+  url: https://github.com/carhartl/jquery-cookie
+  notice: Copyright (c) 2013 Klaus Hartl
+  license: MIT
+
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/licensing/projects-with-custom-licenses
----------------------------------------------------------------------
diff --git a/dist/licensing/projects-with-custom-licenses b/dist/licensing/projects-with-custom-licenses
new file mode 100644
index 0000000..97839fc
--- /dev/null
+++ b/dist/licensing/projects-with-custom-licenses
@@ -0,0 +1,2 @@
+../../brooklyn-ui
+../../brooklyn-server/server-cli

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/pom.xml
----------------------------------------------------------------------
diff --git a/dist/pom.xml b/dist/pom.xml
new file mode 100644
index 0000000..0d01390
--- /dev/null
+++ b/dist/pom.xml
@@ -0,0 +1,159 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+    
+     http://www.apache.org/licenses/LICENSE-2.0
+    
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+    <modelVersion>4.0.0</modelVersion>
+    <packaging>jar</packaging>
+
+    <artifactId>brooklyn-dist</artifactId>
+
+    <name>Brooklyn Distribution</name>
+    <description>
+        Brooklyn redistributable package archive, includes all required
+        Jar files and scripts
+    </description>
+
+    <parent>
+        <groupId>org.apache.brooklyn</groupId>
+        <artifactId>brooklyn-dist-root</artifactId>
+        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+        <relativePath>../pom.xml</relativePath>
+    </parent>
+
+    <dependencies>
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-all</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+
+        <!-- TODO include examples -->
+        <!-- TODO include documentation -->
+
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-test-support</artifactId>
+            <version>${project.version}</version>
+            <scope>test</scope>
+        </dependency>
+        <dependency>
+            <groupId>org.testng</groupId>
+            <artifactId>testng</artifactId>
+            <scope>test</scope>
+        </dependency>
+
+    </dependencies>
+
+    <build>
+        <plugins>
+            <plugin>
+                <artifactId>maven-dependency-plugin</artifactId>
+                <!-- copy the config file from the CLI project (could instead use unpack goal with an includes filter) -->
+                <executions>
+                    <execution>
+                        <id>copy</id>
+                        <phase>process-classes</phase>
+                        <goals>
+                            <goal>copy</goal>
+                        </goals>
+                        <configuration>
+                            <artifactItems>
+                                <artifactItem>
+                                    <!-- this can fail in eclipse trying to copy _from_ target/classes.
+                                         see http://jira.codehaus.org/browse/MDEP-259 -->
+                                    <groupId>${project.groupId}</groupId>
+                                    <artifactId>brooklyn-cli</artifactId>
+                                    <version>${project.version}</version>
+                                    <type>bom</type>
+                                    <classifier>dist</classifier>
+                                    <overWrite>true</overWrite>
+                                    <outputDirectory>target</outputDirectory>
+                                    <destFileName>default.catalog.bom</destFileName>
+                                </artifactItem>
+                            </artifactItems>
+                        </configuration>
+                    </execution>
+                </executions>
+            </plugin>
+            <plugin>
+                <groupId>org.apache.rat</groupId>
+                <artifactId>apache-rat-plugin</artifactId>
+                <configuration>
+                    <excludes combine.children="append">
+                        <!-- Exclude sample config files because they are illustrative, intended for changing -->
+                        <exclude>src/main/dist/conf/**</exclude>
+                        <exclude>src/main/dist/README.md</exclude>
+                        <exclude>licensing/licenses/**</exclude>
+                        <exclude>licensing/README.md</exclude>
+                        <exclude>licensing/*LICENSE*</exclude>
+                        <exclude>licensing/*.autogenerated</exclude>
+                        <exclude>licensing/projects-with-custom-licenses</exclude>
+                        <exclude>licensing/extras-files</exclude>
+                    </excludes>
+                  </configuration>
+            </plugin>
+            <plugin>
+                <artifactId>maven-assembly-plugin</artifactId>
+                <executions>
+                    <execution>
+                        <id>build-distribution-dir</id>
+                        <phase>package</phase>
+                        <goals>
+                            <goal>single</goal>
+                        </goals>
+                        <configuration>
+                            <appendAssemblyId>true</appendAssemblyId>
+                            <descriptors>
+                                <descriptor>src/main/config/build-distribution.xml</descriptor>
+                            </descriptors>
+                            <finalName>brooklyn</finalName>
+                            <includeBaseDirectory>false</includeBaseDirectory>
+                            <formats>
+                                <format>dir</format>
+                            </formats>
+                            <attach>false</attach>
+                        </configuration>
+                    </execution>
+                    <execution>
+                        <id>build-distribution-archive</id>
+                        <phase>package</phase>
+                        <goals>
+                            <goal>single</goal>
+                        </goals>
+                        <configuration>
+                            <appendAssemblyId>true</appendAssemblyId>
+                            <descriptors>
+                                <descriptor>src/main/config/build-distribution.xml</descriptor>
+                            </descriptors>
+                          <!-- finalName affects name in `target/` but we cannot influence name when it is attached/installed,
+                               so `apache-` prefix would be lost there. to keep it consistent this is commented out, 
+                               but would be nice to have if there is a way!
+                            <finalName>apache-brooklyn-${project.version}</finalName>
+                          -->
+                            <formats>
+                                <format>tar.gz</format>
+                                <format>zip</format>
+                            </formats>
+                        </configuration>
+                    </execution>
+                </executions>
+            </plugin>
+        </plugins>
+    </build>
+</project>


[25/51] [abbrv] brooklyn-dist git commit: Updated JClouds to 1.9.2

Posted by he...@apache.org.
Updated JClouds to 1.9.2


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

Branch: refs/heads/master
Commit: 7f9016ff716c828e3e6af32ada5d0e94d12fc95c
Parents: 04235ab
Author: Graeme-Miller <gr...@cloudsoftcorp.com>
Authored: Mon Jan 18 10:59:59 2016 +0000
Committer: Graeme-Miller <gr...@cloudsoftcorp.com>
Committed: Mon Jan 18 10:59:59 2016 +0000

----------------------------------------------------------------------
 brooklyn-dist/downstream-parent/pom.xml | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/7f9016ff/brooklyn-dist/downstream-parent/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/downstream-parent/pom.xml b/brooklyn-dist/downstream-parent/pom.xml
index 6a7d694..f97dba3 100644
--- a/brooklyn-dist/downstream-parent/pom.xml
+++ b/brooklyn-dist/downstream-parent/pom.xml
@@ -57,7 +57,7 @@
     <jclouds.groupId>org.apache.jclouds</jclouds.groupId> <!-- JCLOUDS_GROUPID_VERSION -->
 
     <!-- versions should match those used by Brooklyn, to avoid conflicts -->
-    <jclouds.version>1.9.1</jclouds.version> <!-- JCLOUDS_VERSION -->
+    <jclouds.version>1.9.2</jclouds.version> <!-- JCLOUDS_VERSION -->
     <logback.version>1.0.7</logback.version>
     <slf4j.version>1.6.6</slf4j.version>  <!-- used for java.util.logging jul-to-slf4j interception -->
     <guava.version>17.0</guava.version>


[14/51] [abbrv] brooklyn-dist git commit: [SPLITPREP] brookly version 0.9.SPLITWIP-SNAPSHOT for test purposes

Posted by he...@apache.org.
[SPLITPREP] brookly version 0.9.SPLITWIP-SNAPSHOT  for test purposes


Project: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/repo
Commit: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/commit/74877b1d
Tree: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/tree/74877b1d
Diff: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/diff/74877b1d

Branch: refs/heads/master
Commit: 74877b1d62937b55b3c9e38459fa3d29dbce0f09
Parents: 16b7250
Author: John McCabe <jo...@johnmccabe.net>
Authored: Wed Dec 16 12:00:20 2015 +0000
Committer: Alex Heneveld <al...@cloudsoftcorp.com>
Committed: Mon Dec 21 16:43:33 2015 +0000

----------------------------------------------------------------------
 brooklyn-dist/all/pom.xml                                       | 2 +-
 brooklyn-dist/archetypes/quickstart/NOTES.txt                   | 2 +-
 brooklyn-dist/archetypes/quickstart/pom.xml                     | 2 +-
 brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml | 2 +-
 brooklyn-dist/dist/pom.xml                                      | 2 +-
 brooklyn-dist/downstream-parent/pom.xml                         | 4 ++--
 6 files changed, 7 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/74877b1d/brooklyn-dist/all/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/all/pom.xml b/brooklyn-dist/all/pom.xml
index 289d4a6..c257f0e 100644
--- a/brooklyn-dist/all/pom.xml
+++ b/brooklyn-dist/all/pom.xml
@@ -31,7 +31,7 @@
     <parent>
         <groupId>org.apache.brooklyn</groupId>
         <artifactId>brooklyn-parent</artifactId>
-        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+        <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
         <relativePath>../../parent/pom.xml</relativePath>
     </parent>
 

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/74877b1d/brooklyn-dist/archetypes/quickstart/NOTES.txt
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/NOTES.txt b/brooklyn-dist/archetypes/quickstart/NOTES.txt
index 4028bf6..d195558 100644
--- a/brooklyn-dist/archetypes/quickstart/NOTES.txt
+++ b/brooklyn-dist/archetypes/quickstart/NOTES.txt
@@ -32,7 +32,7 @@ To test a build:
 
     pushd /tmp
     rm -rf brooklyn-sample
-    export BV=0.9.0-SNAPSHOT    # BROOKLYN_VERSION
+    export BV=0.9.SPLITWIP-SNAPSHOT    # BROOKLYN_VERSION
     
     mvn archetype:generate                                  \
                                                             \

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/74877b1d/brooklyn-dist/archetypes/quickstart/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/pom.xml b/brooklyn-dist/archetypes/quickstart/pom.xml
index 6caa79e..1594181 100644
--- a/brooklyn-dist/archetypes/quickstart/pom.xml
+++ b/brooklyn-dist/archetypes/quickstart/pom.xml
@@ -31,7 +31,7 @@
   <parent>
     <groupId>org.apache.brooklyn</groupId>
     <artifactId>brooklyn-parent</artifactId>
-    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+    <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
     <relativePath>../../../parent/pom.xml</relativePath>
   </parent>
 

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/74877b1d/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
index 44f5f93..f879498 100644
--- a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
+++ b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
@@ -7,7 +7,7 @@
   <parent>
     <groupId>org.apache.brooklyn</groupId>
     <artifactId>brooklyn-downstream-parent</artifactId>
-    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+    <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
   </parent>
 
   <groupId>com.acme.sample</groupId>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/74877b1d/brooklyn-dist/dist/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/pom.xml b/brooklyn-dist/dist/pom.xml
index d9c392a..eda7daf 100644
--- a/brooklyn-dist/dist/pom.xml
+++ b/brooklyn-dist/dist/pom.xml
@@ -32,7 +32,7 @@
     <parent>
         <groupId>org.apache.brooklyn</groupId>
         <artifactId>brooklyn-parent</artifactId>
-        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+        <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
         <relativePath>../../parent/pom.xml</relativePath>
     </parent>
 

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/74877b1d/brooklyn-dist/downstream-parent/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/downstream-parent/pom.xml b/brooklyn-dist/downstream-parent/pom.xml
index c1731fd..027c1bf 100644
--- a/brooklyn-dist/downstream-parent/pom.xml
+++ b/brooklyn-dist/downstream-parent/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <groupId>org.apache.brooklyn</groupId>
     <artifactId>brooklyn</artifactId>
-    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+    <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
     <relativePath>../../pom.xml</relativePath>
   </parent>
 
@@ -48,7 +48,7 @@
     <excludedTestGroups>Integration,Acceptance,Live,Live-sanity,WIP</excludedTestGroups>
 
     <!-- Dependencies -->
-    <brooklyn.version>0.9.0-SNAPSHOT</brooklyn.version>  <!-- BROOKLYN_VERSION -->
+    <brooklyn.version>0.9.SPLITWIP-SNAPSHOT</brooklyn.version>  <!-- BROOKLYN_VERSION -->
     <jclouds.groupId>org.apache.jclouds</jclouds.groupId> <!-- JCLOUDS_GROUPID_VERSION -->
 
     <!-- versions should match those used by Brooklyn, to avoid conflicts -->


[10/51] [abbrv] brooklyn-dist git commit: [SPLITPREP] rearranged to have structure of new repositories

Posted by he...@apache.org.
[SPLITPREP] rearranged to have structure of new repositories


Project: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/repo
Commit: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/commit/29757eea
Tree: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/tree/29757eea
Diff: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/diff/29757eea

Branch: refs/heads/master
Commit: 29757eea4a3e397ac7ae272a22ce62808caf4983
Parents: ba4d990
Author: John McCabe <jo...@johnmccabe.net>
Authored: Wed Dec 16 11:25:27 2015 +0000
Committer: John McCabe <jo...@johnmccabe.net>
Committed: Wed Dec 16 20:42:34 2015 +0000

----------------------------------------------------------------------
 brooklyn-dist/.gitattributes                    |    6 +
 brooklyn-dist/.gitignore                        |   32 +
 brooklyn-dist/LICENSE                           |  455 ++++
 brooklyn-dist/NOTICE                            |    5 +
 brooklyn-dist/README.md                         |   21 +
 brooklyn-dist/all/pom.xml                       |  117 +
 brooklyn-dist/archetypes/quickstart/NOTES.txt   |   76 +
 brooklyn-dist/archetypes/quickstart/pom.xml     |  232 ++
 .../quickstart/src/brooklyn-sample/README.md    |   73 +
 .../quickstart/src/brooklyn-sample/pom.xml      |  102 +
 .../src/main/assembly/assembly.xml              |   88 +
 .../src/main/assembly/files/README.txt          |   96 +
 .../src/main/assembly/files/conf/logback.xml    |   11 +
 .../src/main/assembly/scripts/start.sh          |   40 +
 .../com/acme/sample/brooklyn/SampleMain.java    |   81 +
 .../app/ClusterWebServerDatabaseSample.java     |  137 ++
 .../sample/app/SingleWebServerSample.java       |   32 +
 .../src/main/resources/logback-custom.xml       |   10 +
 .../src/main/resources/sample-icon.png          |  Bin 0 -> 46490 bytes
 .../main/resources/visitors-creation-script.sql |   35 +
 .../app/SampleLocalhostIntegrationTest.java     |   81 +
 .../brooklyn/sample/app/SampleUnitTest.java     |   69 +
 .../quickstart/src/main/resources/.gitignore    |    1 +
 .../META-INF/maven/archetype-metadata.xml       |   65 +
 .../projects/integration-test-1/.gitignore      |    1 +
 .../integration-test-1/archetype.properties     |   22 +
 .../projects/integration-test-1/goal.txt        |    1 +
 brooklyn-dist/dist/licensing/.gitignore         |    2 +
 brooklyn-dist/dist/licensing/MAIN_LICENSE_ASL2  |  176 ++
 brooklyn-dist/dist/licensing/README.md          |   78 +
 brooklyn-dist/dist/licensing/extras-files       |    1 +
 .../dist/licensing/licenses/binary/ASL2         |  177 ++
 .../dist/licensing/licenses/binary/BSD-2-Clause |   23 +
 .../dist/licensing/licenses/binary/BSD-3-Clause |   27 +
 .../dist/licensing/licenses/binary/CDDL1        |  381 ++++
 .../dist/licensing/licenses/binary/CDDL1.1      |  304 +++
 .../dist/licensing/licenses/binary/EPL1         |  212 ++
 .../dist/licensing/licenses/binary/MIT          |   20 +
 .../dist/licensing/licenses/binary/WTFPL        |   15 +
 .../dist/licensing/licenses/binary/bouncycastle |   23 +
 .../dist/licensing/licenses/binary/jtidy        |   53 +
 .../dist/licensing/licenses/binary/jython       |   27 +
 .../licenses/binary/metastuff-bsd-style         |   43 +
 .../licenses/binary/xpp3_indiana_university     |   45 +
 brooklyn-dist/dist/licensing/licenses/cli/MIT   |   20 +
 .../dist/licensing/licenses/jsgui/BSD-2-Clause  |   23 +
 .../dist/licensing/licenses/jsgui/BSD-3-Clause  |   27 +
 brooklyn-dist/dist/licensing/licenses/jsgui/MIT |   20 +
 .../dist/licensing/licenses/source/BSD-2-Clause |   23 +
 .../dist/licensing/licenses/source/BSD-3-Clause |   27 +
 .../dist/licensing/licenses/source/MIT          |   20 +
 .../dist/licensing/make-all-licenses.sh         |   61 +
 .../dist/licensing/make-one-license.sh          |   79 +
 brooklyn-dist/dist/licensing/overrides.yaml     |  383 ++++
 .../licensing/projects-with-custom-licenses     |    2 +
 brooklyn-dist/dist/pom.xml                      |  158 ++
 .../dist/src/main/config/build-distribution.xml |   96 +
 .../dist/src/main/dist/bin/.gitattributes       |    3 +
 brooklyn-dist/dist/src/main/dist/bin/brooklyn   |   51 +
 .../dist/src/main/dist/bin/brooklyn.bat         |  111 +
 .../dist/src/main/dist/bin/brooklyn.ps1         |  135 ++
 .../dist/src/main/dist/conf/logback.xml         |   14 +
 brooklyn-dist/dist/src/main/license/README.md   |    2 +
 .../dist/src/main/license/files/DISCLAIMER      |    8 +
 .../dist/src/main/license/files/LICENSE         | 2149 ++++++++++++++++++
 .../dist/src/main/license/files/NOTICE          |    5 +
 .../brooklyn/cli/BaseCliIntegrationTest.java    |  189 ++
 .../apache/brooklyn/cli/CliIntegrationTest.java |  219 ++
 brooklyn-dist/downstream-parent/pom.xml         |  506 +++++
 brooklyn-dist/release/.gitignore                |    2 +
 brooklyn-dist/release/README.md                 |   50 +
 brooklyn-dist/release/Vagrantfile               |   66 +
 brooklyn-dist/release/change-version.sh         |   70 +
 brooklyn-dist/release/gpg-agent.conf            |    2 +
 brooklyn-dist/release/make-release-artifacts.sh |  257 +++
 brooklyn-dist/release/print-vote-email.sh       |  130 ++
 .../release/pull-request-reports/Gemfile        |    5 +
 .../release/pull-request-reports/Gemfile.lock   |   38 +
 .../release/pull-request-reports/pr_report.rb   |   12 +
 brooklyn-dist/release/settings.xml              |   29 +
 brooklyn-dist/scripts/buildAndTest              |  102 +
 brooklyn-dist/scripts/grep-in-poms.sh           |   25 +
 .../scripts/release-branch-from-master          |  114 +
 brooklyn-dist/scripts/release-make              |   83 +
 release/.gitignore                              |    2 -
 release/README.md                               |   50 -
 release/Vagrantfile                             |   66 -
 release/change-version.sh                       |   70 -
 release/gpg-agent.conf                          |    2 -
 release/make-release-artifacts.sh               |  257 ---
 release/print-vote-email.sh                     |  130 --
 release/pull-request-reports/Gemfile            |    5 -
 release/pull-request-reports/Gemfile.lock       |   38 -
 release/pull-request-reports/pr_report.rb       |   12 -
 release/settings.xml                            |   29 -
 usage/all/pom.xml                               |  117 -
 usage/archetypes/quickstart/NOTES.txt           |   76 -
 usage/archetypes/quickstart/pom.xml             |  232 --
 .../quickstart/src/brooklyn-sample/README.md    |   73 -
 .../quickstart/src/brooklyn-sample/pom.xml      |  102 -
 .../src/main/assembly/assembly.xml              |   88 -
 .../src/main/assembly/files/README.txt          |   96 -
 .../src/main/assembly/files/conf/logback.xml    |   11 -
 .../src/main/assembly/scripts/start.sh          |   40 -
 .../com/acme/sample/brooklyn/SampleMain.java    |   81 -
 .../app/ClusterWebServerDatabaseSample.java     |  137 --
 .../sample/app/SingleWebServerSample.java       |   32 -
 .../src/main/resources/logback-custom.xml       |   10 -
 .../src/main/resources/sample-icon.png          |  Bin 46490 -> 0 bytes
 .../main/resources/visitors-creation-script.sql |   35 -
 .../app/SampleLocalhostIntegrationTest.java     |   81 -
 .../brooklyn/sample/app/SampleUnitTest.java     |   69 -
 .../quickstart/src/main/resources/.gitignore    |    1 -
 .../META-INF/maven/archetype-metadata.xml       |   65 -
 .../projects/integration-test-1/.gitignore      |    1 -
 .../integration-test-1/archetype.properties     |   22 -
 .../projects/integration-test-1/goal.txt        |    1 -
 usage/dist/licensing/.gitignore                 |    2 -
 usage/dist/licensing/MAIN_LICENSE_ASL2          |  176 --
 usage/dist/licensing/README.md                  |   78 -
 usage/dist/licensing/extras-files               |    1 -
 usage/dist/licensing/licenses/binary/ASL2       |  177 --
 .../dist/licensing/licenses/binary/BSD-2-Clause |   23 -
 .../dist/licensing/licenses/binary/BSD-3-Clause |   27 -
 usage/dist/licensing/licenses/binary/CDDL1      |  381 ----
 usage/dist/licensing/licenses/binary/CDDL1.1    |  304 ---
 usage/dist/licensing/licenses/binary/EPL1       |  212 --
 usage/dist/licensing/licenses/binary/MIT        |   20 -
 usage/dist/licensing/licenses/binary/WTFPL      |   15 -
 .../dist/licensing/licenses/binary/bouncycastle |   23 -
 usage/dist/licensing/licenses/binary/jtidy      |   53 -
 usage/dist/licensing/licenses/binary/jython     |   27 -
 .../licenses/binary/metastuff-bsd-style         |   43 -
 .../licenses/binary/xpp3_indiana_university     |   45 -
 usage/dist/licensing/licenses/cli/MIT           |   20 -
 .../dist/licensing/licenses/jsgui/BSD-2-Clause  |   23 -
 .../dist/licensing/licenses/jsgui/BSD-3-Clause  |   27 -
 usage/dist/licensing/licenses/jsgui/MIT         |   20 -
 .../dist/licensing/licenses/source/BSD-2-Clause |   23 -
 .../dist/licensing/licenses/source/BSD-3-Clause |   27 -
 usage/dist/licensing/licenses/source/MIT        |   20 -
 usage/dist/licensing/make-all-licenses.sh       |   61 -
 usage/dist/licensing/make-one-license.sh        |   79 -
 usage/dist/licensing/overrides.yaml             |  383 ----
 .../licensing/projects-with-custom-licenses     |    2 -
 usage/dist/pom.xml                              |  158 --
 .../dist/src/main/config/build-distribution.xml |   96 -
 usage/dist/src/main/dist/bin/.gitattributes     |    3 -
 usage/dist/src/main/dist/bin/brooklyn           |   51 -
 usage/dist/src/main/dist/bin/brooklyn.bat       |  111 -
 usage/dist/src/main/dist/bin/brooklyn.ps1       |  135 --
 usage/dist/src/main/dist/conf/logback.xml       |   14 -
 usage/dist/src/main/license/README.md           |    2 -
 usage/dist/src/main/license/files/DISCLAIMER    |    8 -
 usage/dist/src/main/license/files/LICENSE       | 2149 ------------------
 usage/dist/src/main/license/files/NOTICE        |    5 -
 .../brooklyn/cli/BaseCliIntegrationTest.java    |  189 --
 .../apache/brooklyn/cli/CliIntegrationTest.java |  219 --
 usage/downstream-parent/pom.xml                 |  506 -----
 usage/jsgui/src/main/license/files/LICENSE      |  482 ----
 usage/jsgui/src/main/license/files/NOTICE       |    5 -
 usage/jsgui/src/test/license/DISCLAIMER         |    8 -
 usage/jsgui/src/test/license/NOTICE             |    5 -
 usage/scripts/buildAndTest                      |  102 -
 usage/scripts/grep-in-poms.sh                   |   25 -
 usage/scripts/release-branch-from-master        |  114 -
 usage/scripts/release-make                      |   83 -
 167 files changed, 8812 insertions(+), 8793 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/.gitattributes
----------------------------------------------------------------------
diff --git a/brooklyn-dist/.gitattributes b/brooklyn-dist/.gitattributes
new file mode 100644
index 0000000..7920d0e
--- /dev/null
+++ b/brooklyn-dist/.gitattributes
@@ -0,0 +1,6 @@
+#Don't auto-convert line endings for shell scripts on Windows (breaks the scripts)
+* text=auto
+*.sh text eol=lf
+*.bat text eol=crlf
+*.ps1 text eol=crlf
+*.ini text eol=crlf

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/.gitignore
----------------------------------------------------------------------
diff --git a/brooklyn-dist/.gitignore b/brooklyn-dist/.gitignore
new file mode 100644
index 0000000..ed439f2
--- /dev/null
+++ b/brooklyn-dist/.gitignore
@@ -0,0 +1,32 @@
+\#*\#
+*~
+*.bak
+*.swp
+*.swo
+.DS_Store
+
+atlassian-ide-plugin.xml
+*.class
+
+target/
+test-output/
+
+.project
+.classpath
+.settings/
+.metadata/
+
+.idea/
+*.iml
+
+nbactions.xml
+nb-configuration.xml
+
+prodDb.*
+
+*.log
+brooklyn*.log.*
+
+*brooklyn-persisted-state/
+
+ignored

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/LICENSE
----------------------------------------------------------------------
diff --git a/brooklyn-dist/LICENSE b/brooklyn-dist/LICENSE
new file mode 100644
index 0000000..ca60394
--- /dev/null
+++ b/brooklyn-dist/LICENSE
@@ -0,0 +1,455 @@
+
+This software is distributed under the Apache License, version 2.0. See (1) below.
+This software is copyright (c) The Apache Software Foundation and contributors.
+
+Contents:
+
+  (1) This software license: Apache License, version 2.0
+  (2) Notices for bundled software
+  (3) Licenses for bundled software
+
+
+---------------------------------------------------
+
+(1) This software license: Apache License, version 2.0
+
+
+                                 Apache License
+                           Version 2.0, January 2004
+                        http://www.apache.org/licenses/
+
+   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+
+   1. Definitions.
+
+      "License" shall mean the terms and conditions for use, reproduction,
+      and distribution as defined by Sections 1 through 9 of this document.
+
+      "Licensor" shall mean the copyright owner or entity authorized by
+      the copyright owner that is granting the License.
+
+      "Legal Entity" shall mean the union of the acting entity and all
+      other entities that control, are controlled by, or are under common
+      control with that entity. For the purposes of this definition,
+      "control" means (i) the power, direct or indirect, to cause the
+      direction or management of such entity, whether by contract or
+      otherwise, or (ii) ownership of fifty percent (50%) or more of the
+      outstanding shares, or (iii) beneficial ownership of such entity.
+
+      "You" (or "Your") shall mean an individual or Legal Entity
+      exercising permissions granted by this License.
+
+      "Source" form shall mean the preferred form for making modifications,
+      including but not limited to software source code, documentation
+      source, and configuration files.
+
+      "Object" form shall mean any form resulting from mechanical
+      transformation or translation of a Source form, including but
+      not limited to compiled object code, generated documentation,
+      and conversions to other media types.
+
+      "Work" shall mean the work of authorship, whether in Source or
+      Object form, made available under the License, as indicated by a
+      copyright notice that is included in or attached to the work
+      (an example is provided in the Appendix below).
+
+      "Derivative Works" shall mean any work, whether in Source or Object
+      form, that is based on (or derived from) the Work and for which the
+      editorial revisions, annotations, elaborations, or other modifications
+      represent, as a whole, an original work of authorship. For the purposes
+      of this License, Derivative Works shall not include works that remain
+      separable from, or merely link (or bind by name) to the interfaces of,
+      the Work and Derivative Works thereof.
+
+      "Contribution" shall mean any work of authorship, including
+      the original version of the Work and any modifications or additions
+      to that Work or Derivative Works thereof, that is intentionally
+      submitted to Licensor for inclusion in the Work by the copyright owner
+      or by an individual or Legal Entity authorized to submit on behalf of
+      the copyright owner. For the purposes of this definition, "submitted"
+      means any form of electronic, verbal, or written communication sent
+      to the Licensor or its representatives, including but not limited to
+      communication on electronic mailing lists, source code control systems,
+      and issue tracking systems that are managed by, or on behalf of, the
+      Licensor for the purpose of discussing and improving the Work, but
+      excluding communication that is conspicuously marked or otherwise
+      designated in writing by the copyright owner as "Not a Contribution."
+
+      "Contributor" shall mean Licensor and any individual or Legal Entity
+      on behalf of whom a Contribution has been received by Licensor and
+      subsequently incorporated within the Work.
+
+   2. Grant of Copyright License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      copyright license to reproduce, prepare Derivative Works of,
+      publicly display, publicly perform, sublicense, and distribute the
+      Work and such Derivative Works in Source or Object form.
+
+   3. Grant of Patent License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      (except as stated in this section) patent license to make, have made,
+      use, offer to sell, sell, import, and otherwise transfer the Work,
+      where such license applies only to those patent claims licensable
+      by such Contributor that are necessarily infringed by their
+      Contribution(s) alone or by combination of their Contribution(s)
+      with the Work to which such Contribution(s) was submitted. If You
+      institute patent litigation against any entity (including a
+      cross-claim or counterclaim in a lawsuit) alleging that the Work
+      or a Contribution incorporated within the Work constitutes direct
+      or contributory patent infringement, then any patent licenses
+      granted to You under this License for that Work shall terminate
+      as of the date such litigation is filed.
+
+   4. Redistribution. You may reproduce and distribute copies of the
+      Work or Derivative Works thereof in any medium, with or without
+      modifications, and in Source or Object form, provided that You
+      meet the following conditions:
+
+      (a) You must give any other recipients of the Work or
+          Derivative Works a copy of this License; and
+
+      (b) You must cause any modified files to carry prominent notices
+          stating that You changed the files; and
+
+      (c) You must retain, in the Source form of any Derivative Works
+          that You distribute, all copyright, patent, trademark, and
+          attribution notices from the Source form of the Work,
+          excluding those notices that do not pertain to any part of
+          the Derivative Works; and
+
+      (d) If the Work includes a "NOTICE" text file as part of its
+          distribution, then any Derivative Works that You distribute must
+          include a readable copy of the attribution notices contained
+          within such NOTICE file, excluding those notices that do not
+          pertain to any part of the Derivative Works, in at least one
+          of the following places: within a NOTICE text file distributed
+          as part of the Derivative Works; within the Source form or
+          documentation, if provided along with the Derivative Works; or,
+          within a display generated by the Derivative Works, if and
+          wherever such third-party notices normally appear. The contents
+          of the NOTICE file are for informational purposes only and
+          do not modify the License. You may add Your own attribution
+          notices within Derivative Works that You distribute, alongside
+          or as an addendum to the NOTICE text from the Work, provided
+          that such additional attribution notices cannot be construed
+          as modifying the License.
+
+      You may add Your own copyright statement to Your modifications and
+      may provide additional or different license terms and conditions
+      for use, reproduction, or distribution of Your modifications, or
+      for any such Derivative Works as a whole, provided Your use,
+      reproduction, and distribution of the Work otherwise complies with
+      the conditions stated in this License.
+
+   5. Submission of Contributions. Unless You explicitly state otherwise,
+      any Contribution intentionally submitted for inclusion in the Work
+      by You to the Licensor shall be under the terms and conditions of
+      this License, without any additional terms or conditions.
+      Notwithstanding the above, nothing herein shall supersede or modify
+      the terms of any separate license agreement you may have executed
+      with Licensor regarding such Contributions.
+
+   6. Trademarks. This License does not grant permission to use the trade
+      names, trademarks, service marks, or product names of the Licensor,
+      except as required for reasonable and customary use in describing the
+      origin of the Work and reproducing the content of the NOTICE file.
+
+   7. Disclaimer of Warranty. Unless required by applicable law or
+      agreed to in writing, Licensor provides the Work (and each
+      Contributor provides its Contributions) on an "AS IS" BASIS,
+      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+      implied, including, without limitation, any warranties or conditions
+      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
+      PARTICULAR PURPOSE. You are solely responsible for determining the
+      appropriateness of using or redistributing the Work and assume any
+      risks associated with Your exercise of permissions under this License.
+
+   8. Limitation of Liability. In no event and under no legal theory,
+      whether in tort (including negligence), contract, or otherwise,
+      unless required by applicable law (such as deliberate and grossly
+      negligent acts) or agreed to in writing, shall any Contributor be
+      liable to You for damages, including any direct, indirect, special,
+      incidental, or consequential damages of any character arising as a
+      result of this License or out of the use or inability to use the
+      Work (including but not limited to damages for loss of goodwill,
+      work stoppage, computer failure or malfunction, or any and all
+      other commercial damages or losses), even if such Contributor
+      has been advised of the possibility of such damages.
+
+   9. Accepting Warranty or Additional Liability. While redistributing
+      the Work or Derivative Works thereof, You may choose to offer,
+      and charge a fee for, acceptance of support, warranty, indemnity,
+      or other liability obligations and/or rights consistent with this
+      License. However, in accepting such obligations, You may act only
+      on Your own behalf and on Your sole responsibility, not on behalf
+      of any other Contributor, and only if You agree to indemnify,
+      defend, and hold each Contributor harmless for any liability
+      incurred by, or claims asserted against, such Contributor by reason
+      of your accepting any such warranty or additional liability.
+
+
+---------------------------------------------------
+
+(2) Notices for bundled software
+
+This project includes the software: async.js
+  Available at: https://github.com/p15martin/google-maps-hello-world/blob/master/js/libs/async.js
+  Developed by: Miller Medeiros (https://github.com/millermedeiros/)
+  Version used: 0.1.1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Miller Medeiros (2011)
+
+This project includes the software: backbone.js
+  Available at: http://backbonejs.org
+  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
+  Version used: 1.0.0
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2010-2013)
+
+This project includes the software: bootstrap.js
+  Available at: http://twitter.github.com/bootstrap/javascript.html#transitions
+  Version used: 2.0.4
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+  Copyright (c) Twitter, Inc. (2012)
+
+This project includes the software: handlebars.js
+  Available at: https://github.com/wycats/handlebars.js
+  Developed by: Yehuda Katz (https://github.com/wycats/)
+  Inclusive of: handlebars*.js
+  Version used: 1.0-rc1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Yehuda Katz (2012)
+
+This project includes the software: jQuery JavaScript Library
+  Available at: http://jquery.com/
+  Developed by: The jQuery Foundation (http://jquery.org/)
+  Inclusive of: jquery.js
+  Version used: 1.7.2
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) John Resig (2005-2011)
+  Includes code fragments from sizzle.js:
+    Copyright (c) The Dojo Foundation
+    Available at http://sizzlejs.com
+    Used under the MIT license
+
+This project includes the software: jQuery BBQ: Back Button & Query Library
+  Available at: http://benalman.com/projects/jquery-bbq-plugin/
+  Developed by: "Cowboy" Ben Alman (http://benalman.com/)
+  Inclusive of: jquery.ba-bbq*.js
+  Version used: 1.2.1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) "Cowboy" Ben Alman (2010)"
+
+This project includes the software: DataTables Table plug-in for jQuery
+  Available at: http://www.datatables.net/
+  Developed by: SpryMedia Ltd (http://sprymedia.co.uk/)
+  Inclusive of: jquery.dataTables.{js,css}
+  Version used: 1.9.4
+  Used under the following license: The BSD 3-Clause (New BSD) License (http://opensource.org/licenses/BSD-3-Clause)
+  Copyright (c) Allan Jardine (2008-2012)
+
+This project includes the software: jQuery Form Plugin
+  Available at: https://github.com/malsup/form
+  Developed by: Mike Alsup (http://malsup.com/)
+  Inclusive of: jquery.form.js
+  Version used: 3.09
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) M. Alsup (2006-2013)
+
+This project includes the software: jQuery Wiggle
+  Available at: https://github.com/jordanthomas/jquery-wiggle
+  Inclusive of: jquery.wiggle.min.js
+  Version used: swagger-ui:1.0.1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) WonderGroup and Jordan Thomas (2010)
+  Previously online at http://labs.wondergroup.com/demos/mini-ui/index.html.
+  The version included here is from the Swagger UI distribution.
+
+This project includes the software: js-uri
+  Available at: http://code.google.com/p/js-uri/
+  Developed by: js-uri contributors (https://code.google.com/js-uri)
+  Inclusive of: URI.js
+  Version used: 0.1
+  Used under the following license: The BSD 3-Clause (New BSD) License (http://opensource.org/licenses/BSD-3-Clause)
+  Copyright (c) js-uri contributors (2013)
+
+This project includes the software: js-yaml.js
+  Available at: https://github.com/nodeca/
+  Developed by: Vitaly Puzrin (https://github.com/nodeca/)
+  Version used: 3.2.7
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Vitaly Puzrin (2011-2015)
+
+This project includes the software: moment.js
+  Available at: http://momentjs.com
+  Developed by: Tim Wood (http://momentjs.com)
+  Version used: 2.1.0
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Tim Wood, Iskren Chernev, Moment.js contributors (2011-2014)
+
+This project includes the software: RequireJS
+  Available at: http://requirejs.org/
+  Developed by: The Dojo Foundation (http://dojofoundation.org/)
+  Inclusive of: require.js, text.js
+  Version used: 2.0.6
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) The Dojo Foundation (2010-2012)
+
+This project includes the software: RequireJS (r.js maven plugin)
+  Available at: http://github.com/jrburke/requirejs
+  Developed by: The Dojo Foundation (http://dojofoundation.org/)
+  Inclusive of: r.js
+  Version used: 2.1.6
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) The Dojo Foundation (2009-2013)
+  Includes code fragments for source-map and other functionality:
+    Copyright (c) The Mozilla Foundation and contributors (2011)
+    Used under the BSD 2-Clause license.
+  Includes code fragments for parse-js and other functionality:
+    Copyright (c) Mihai Bazon (2010, 2012)
+    Used under the BSD 2-Clause license.
+  Includes code fragments for uglifyjs/consolidator:
+    Copyright (c) Robert Gust-Bardon (2012)
+    Used under the BSD 2-Clause license.
+  Includes code fragments for the esprima parser:
+    Copyright (c):
+      Ariya Hidayat (2011, 2012)
+      Mathias Bynens (2012)
+      Joost-Wim Boekesteijn (2012)
+      Kris Kowal (2012)
+      Yusuke Suzuki (2012)
+      Arpad Borsos (2012)
+    Used under the BSD 2-Clause license.
+
+This project includes the software: Swagger JS
+  Available at: https://github.com/wordnik/swagger-js
+  Inclusive of: swagger.js
+  Version used: 1.0.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+  Copyright (c) SmartBear Software (2011-2015)
+
+This project includes the software: Swagger UI
+  Available at: https://github.com/wordnik/swagger-ui
+  Inclusive of: swagger-ui.js
+  Version used: 1.0.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+  Copyright (c) SmartBear Software (2011-2015)
+
+This project includes the software: typeahead.js
+  Available at: https://github.com/twitter/typeahead.js
+  Developed by: Twitter, Inc (http://twitter.com)
+  Version used: 0.10.5
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Twitter, Inc. and other contributors (2013-2014)
+
+This project includes the software: underscore.js
+  Available at: http://underscorejs.org
+  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
+  Inclusive of: underscore*.{js,map}
+  Version used: 1.4.4
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2009-2013)
+
+This project includes the software: underscore.js:1.7.0
+  Available at: http://underscorejs.org
+  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
+  Inclusive of: underscore*.{js,map}
+  Version used: 1.7.0
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Jeremy Ashkenas, DocumentCloud and Investigative Reporters & Editors (2009-2014)
+
+This project includes the software: ZeroClipboard
+  Available at: http://zeroclipboard.org/
+  Developed by: ZeroClipboard contributors (https://github.com/zeroclipboard)
+  Inclusive of: ZeroClipboard.*
+  Version used: 1.3.1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Jon Rohan, James M. Greene (2014)
+
+
+---------------------------------------------------
+
+(3) Licenses for bundled software
+
+Contents:
+
+  The BSD 2-Clause License
+  The BSD 3-Clause License ("New BSD")
+  The MIT License ("MIT")
+
+
+The BSD 2-Clause License
+
+  Redistribution and use in source and binary forms, with or without
+  modification, are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, this
+  list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice,
+  this list of conditions and the following disclaimer in the documentation
+  and/or other materials provided with the distribution.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
+  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
+  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
+  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
+  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
+  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
+  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
+  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
+  
+
+The BSD 3-Clause License ("New BSD")
+
+  Redistribution and use in source and binary forms, with or without modification,
+  are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, 
+  this list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice, 
+  this list of conditions and the following disclaimer in the documentation 
+  and/or other materials provided with the distribution.
+  
+  3. Neither the name of the copyright holder nor the names of its contributors 
+  may be used to endorse or promote products derived from this software without 
+  specific prior written permission.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
+  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
+  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
+  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
+  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
+  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
+  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
+  POSSIBILITY OF SUCH DAMAGE.
+  
+
+The MIT License ("MIT")
+
+  Permission is hereby granted, free of charge, to any person obtaining a copy
+  of this software and associated documentation files (the "Software"), to deal
+  in the Software without restriction, including without limitation the rights
+  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
+  copies of the Software, and to permit persons to whom the Software is
+  furnished to do so, subject to the following conditions:
+  
+  The above copyright notice and this permission notice shall be included in
+  all copies or substantial portions of the Software.
+  
+  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
+  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
+  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
+  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
+  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
+  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
+  THE SOFTWARE.
+  
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/NOTICE
----------------------------------------------------------------------
diff --git a/brooklyn-dist/NOTICE b/brooklyn-dist/NOTICE
new file mode 100644
index 0000000..f790f13
--- /dev/null
+++ b/brooklyn-dist/NOTICE
@@ -0,0 +1,5 @@
+Apache Brooklyn
+Copyright 2014-2015 The Apache Software Foundation
+
+This product includes software developed at
+The Apache Software Foundation (http://www.apache.org/).

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/README.md
----------------------------------------------------------------------
diff --git a/brooklyn-dist/README.md b/brooklyn-dist/README.md
new file mode 100644
index 0000000..6b66cf2
--- /dev/null
+++ b/brooklyn-dist/README.md
@@ -0,0 +1,21 @@
+
+# [![**Brooklyn**](https://brooklyn.apache.org/style/img/apache-brooklyn-logo-244px-wide.png)](http://brooklyn.apache.org/)
+
+### Apache Brooklyn helps to model, deploy, and manage systems.
+
+It supports blueprints in YAML or Java, and deploys them to many clouds and other target environments.
+It monitors those deployments, maintains a live model, and runs autonomic policies to maintain their health.
+
+For more information see **[brooklyn.apache.org](https://brooklyn.apache.org/)**.
+
+
+### To Build
+
+The code can be built with a:
+
+    mvn clean install
+
+This creates a build in `usage/dist/target/brooklyn-dist`.  Run with `bin/brooklyn launch`.
+
+The **[developer guide](https://brooklyn.apache.org/v/latest/dev/)**
+has more information about the source code.

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/all/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/all/pom.xml b/brooklyn-dist/all/pom.xml
new file mode 100644
index 0000000..289d4a6
--- /dev/null
+++ b/brooklyn-dist/all/pom.xml
@@ -0,0 +1,117 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+    
+     http://www.apache.org/licenses/LICENSE-2.0
+    
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+    <modelVersion>4.0.0</modelVersion>
+    <packaging>jar</packaging>
+
+    <artifactId>brooklyn-all</artifactId>
+
+    <name>Brooklyn All Things</name>
+    <description>
+        A meta-dependency for all the major Brooklyn modules.
+    </description>
+
+    <parent>
+        <groupId>org.apache.brooklyn</groupId>
+        <artifactId>brooklyn-parent</artifactId>
+        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+        <relativePath>../../parent/pom.xml</relativePath>
+    </parent>
+
+    <dependencies>
+        <dependency>
+            <groupId>com.google.guava</groupId>
+            <artifactId>guava</artifactId>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-policy</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-locations-jclouds</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-software-webapp</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-software-messaging</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-software-monitoring</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-software-database</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-software-osgi</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-software-nosql</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-software-network</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-launcher</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-cli</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-test-framework</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+
+        <!-- bring in all jclouds-supported cloud providers -->
+        <dependency>
+            <groupId>${jclouds.groupId}</groupId>
+            <artifactId>jclouds-allcompute</artifactId>
+        </dependency>
+    </dependencies>
+
+</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/NOTES.txt
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/NOTES.txt b/brooklyn-dist/archetypes/quickstart/NOTES.txt
new file mode 100644
index 0000000..4028bf6
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/NOTES.txt
@@ -0,0 +1,76 @@
+
+This file contains notes for anyone working on the archetype.
+
+
+Some things to keep in mind:
+
+* The sample project in `src/brooklyn-sample` is what populates the
+  archetype source (in `src/main/resources/archetype-resources`, 
+  copied there by the `pom.xml` in this directory, in `clean` phase).
+  (You can open and edit it in your IDE.)
+  
+* That archetype source then becomes the archetype (in `install` phase)
+  according to the copy and filter rules in `src/main/resources/META-INF/maven/archetype-metadata.xml`
+
+* For any changes to the project:
+
+  * ensure `brooklyn-sample` builds as you would like
+  * ensure the resulting archetype builds as you would like
+    (should be reasonably safe and automated, but check that the 2 sets of 
+    copy/translation rules above do what you intended!)
+  * update the `README.*` files in the root of `brooklyn-sample` and the
+    `src/main/assembly/files` within that
+  * update the docs under `use/guide/defining-applications/archetype.md` and `use/guide/quickstart/index.md`
+
+
+To build:
+
+    mvn clean install
+
+
+To test a build:
+
+    pushd /tmp
+    rm -rf brooklyn-sample
+    export BV=0.9.0-SNAPSHOT    # BROOKLYN_VERSION
+    
+    mvn archetype:generate                                  \
+                                                            \
+      -DarchetypeGroupId=org.apache.brooklyn                \
+      -DarchetypeArtifactId=brooklyn-archetype-quickstart   \
+      -DarchetypeVersion=${BV} \
+      \
+      -DgroupId=com.acme.sample                             \
+      -DartifactId=brooklyn-sample                          \
+      -Dversion=0.1.0-SNAPSHOT                              \
+      -Dpackage=com.acme.sample.brooklyn                    \
+      \
+      --batch-mode
+    
+    cd brooklyn-sample
+    mvn clean assembly:assembly
+    cd target/brooklyn-sample-0.1.0-SNAPSHOT-dist/brooklyn-sample-0.1.0-SNAPSHOT/
+    ./start.sh launch --cluster --location localhost
+
+
+References
+
+ * http://stackoverflow.com/questions/4082643/how-can-i-test-a-maven-archetype-that-ive-just-created/18916065#18916065
+
+----
+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.

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/pom.xml b/brooklyn-dist/archetypes/quickstart/pom.xml
new file mode 100644
index 0000000..6caa79e
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/pom.xml
@@ -0,0 +1,232 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+    
+     http://www.apache.org/licenses/LICENSE-2.0
+    
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+  <modelVersion>4.0.0</modelVersion>
+  <artifactId>brooklyn-archetype-quickstart</artifactId>
+  <packaging>maven-archetype</packaging>
+  <name>Brooklyn Quick-Start Project Archetype</name>
+  <description>
+    This project defines an archetype for creating new projects which consume brooklyn,
+    including an example application and an example new entity type,
+    able to build an OSGi JAR and a binary assembly, with logging and READMEs.
+  </description>
+
+  <parent>
+    <groupId>org.apache.brooklyn</groupId>
+    <artifactId>brooklyn-parent</artifactId>
+    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+    <relativePath>../../../parent/pom.xml</relativePath>
+  </parent>
+
+  <build>
+    <plugins>
+      <plugin>
+        <artifactId>maven-archetype-plugin</artifactId>
+        <!-- all we want to do is skip _integration tests_ when skipTests is set, not other phases;
+             but for some reason this seems to do it, and it still builds the archetype (!?).
+             whereas setting skip inside the integration-test execution goal does NOT work.
+              
+             TODO promote to root pom.xml when we better understand why
+        -->
+        <configuration>
+          <skip>${skipTests}</skip>
+        </configuration>
+      </plugin>
+      
+      <plugin>
+        <artifactId>maven-clean-plugin</artifactId>
+        <configuration>
+          <filesets>
+            <fileset> 
+                <directory>src/test/resources/projects/integration-test-1/reference</directory> 
+                <includes><include>**/*</include></includes>
+            </fileset>
+            <fileset> 
+                <directory>src/main/resources/archetype-resources/</directory> 
+                <includes><include>**/*</include></includes>
+            </fileset>
+          </filesets>
+        </configuration>
+      </plugin>
+
+      <plugin>
+        <groupId>com.google.code.maven-replacer-plugin</groupId>
+        <artifactId>maven-replacer-plugin</artifactId>
+        <executions>
+          <execution>
+            <id>copy-brooklyn-sample-to-integration-test-reference</id>
+            <phase>clean</phase>
+            <goals> <goal>replace</goal> </goals>
+            <configuration>
+              <basedir>${basedir}/src/brooklyn-sample</basedir> 
+              <outputBasedir>${basedir}</outputBasedir>
+              <outputDir>src/test/resources/projects/integration-test-1/reference</outputDir>
+              <includes> <include>**</include> </includes>
+              <excludes> 
+                <exclude>.*</exclude> 
+                <exclude>.*/**</exclude> 
+                <exclude>target/**</exclude> 
+                <exclude>*.log</exclude> 
+              </excludes>
+              
+              <replacements />
+            </configuration>
+          </execution>
+          <!-- would be nice to reduce the repetion below, but don't see how;
+               have tried with valueTokenMap but it must lie beneath basedir;
+               and tried with {input,output}FilePattern but that doesn't apply to dirs  -->
+          <execution>
+            <!-- copy creating variables and unpackaged, for src/main/java -->
+            <id>copy-brooklyn-sample-to-archetype-src-main-java</id>
+            <phase>clean</phase>
+            <goals> <goal>replace</goal> </goals>
+            <configuration>
+              <basedir>${basedir}/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn</basedir>
+              <outputBasedir>${basedir}</outputBasedir>
+              <outputDir>src/main/resources/archetype-resources/src/main/java</outputDir>
+              <includes> <include>**/*</include> </includes>
+              <replacements>
+                <replacement> <token>brooklyn-sample</token> <value>\$\{artifactId}</value> </replacement>
+                <replacement> <token>com\.acme\.sample\.brooklyn</token> <value>\$\{package}</value> </replacement>
+                <replacement> <token>com/acme/sample/brooklyn</token> <value>\$\{packageInPathFormat}</value> </replacement>
+                <replacement> <token>com\.acme\.sample</token> <value>\$\{groupId}</value> </replacement>
+                <replacement> <token>0.1.0-SNAPSHOT</token> <value>\$\{version}</value> </replacement>
+              </replacements>
+            </configuration>
+          </execution>
+          <execution>
+            <!-- copy creating variables and unpackaged, for src/test/java -->
+            <id>copy-brooklyn-sample-to-archetype-src-test-java</id>
+            <phase>clean</phase>
+            <goals> <goal>replace</goal> </goals>
+            <configuration>
+              <basedir>${basedir}/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn</basedir>
+              <outputBasedir>${basedir}</outputBasedir>
+              <outputDir>src/main/resources/archetype-resources/src/test/java</outputDir>
+              <includes> <include>**/*</include> </includes>
+              <replacements>
+                <replacement> <token>brooklyn-sample</token> <value>\$\{artifactId}</value> </replacement>
+                <replacement> <token>com\.acme\.sample\.brooklyn</token> <value>\$\{package}</value> </replacement>
+                <replacement> <token>com/acme/sample/brooklyn</token> <value>\$\{packageInPathFormat}</value> </replacement>
+                <replacement> <token>com\.acme\.sample</token> <value>\$\{groupId}</value> </replacement>
+                <replacement> <token>0.1.0-SNAPSHOT</token> <value>\$\{version}</value> </replacement>
+              </replacements>
+            </configuration>
+          </execution>
+          <execution>
+            <!-- copy creating variables, for all other places -->
+            <id>copy-brooklyn-sample-to-archetype-resources</id>
+            <phase>clean</phase>
+            <goals> <goal>replace</goal> </goals>
+            <configuration>
+              <basedir>${basedir}/src/brooklyn-sample/</basedir>
+              <outputBasedir>${basedir}</outputBasedir>
+              <outputDir>src/main/resources/archetype-resources/</outputDir>
+              <includes> <include>**/*</include> </includes>
+              <excludes> 
+                <exclude>src/main/java/**</exclude> 
+                <exclude>src/test/java/**</exclude> 
+                <exclude>target/**</exclude> 
+                <exclude>test-output/**</exclude> 
+                <exclude>.*</exclude> 
+                <exclude>**/*.png</exclude> 
+                <exclude>.*/**</exclude> 
+                <exclude>*.log</exclude>
+                <exclude>**/*.sh</exclude>
+              </excludes>
+              <replacements>
+                <!-- special chars in velocity have to be escaped.
+                     fortunately we only use fairly simple examples so we don't need to solve the general case! -->
+                <!-- escaping # is ugly -->
+                <replacement> <token>(#+)</token> <value>#set\(\$H='$1'\)\${H}</value> </replacement>
+                <!-- and escaping $ doesn't even seem to work; perhaps an old version of velocity in use?
+                     (however velocity ignores $ except for variables which are defined, so we're okay)
+                <replacement> <token>\$</token> <value>\\\$</value> </replacement>
+                -->
+                
+                <replacement> <token>brooklyn-sample</token> <value>\$\{artifactId}</value> </replacement>
+                <replacement> <token>com\.acme\.sample\.brooklyn</token> <value>\$\{package}</value> </replacement>
+                <replacement> <token>com/acme/sample/brooklyn</token> <value>\$\{packageInPathFormat}</value> </replacement>
+                <replacement> <token>com\.acme\.sample</token> <value>\$\{groupId}</value> </replacement>
+                <replacement> <token>0.1.0-SNAPSHOT</token> <value>\$\{version}</value> </replacement>
+              </replacements>
+            </configuration>
+          </execution>
+          <execution>
+            <!-- copy creating variables, for all other places -->
+            <id>copy-brooklyn-sample-to-archetype-resources-binary</id>
+            <phase>clean</phase>
+            <goals> <goal>replace</goal> </goals>
+            <configuration>
+              <basedir>${basedir}/src/brooklyn-sample/</basedir>
+              <outputBasedir>${basedir}</outputBasedir>
+              <outputDir>src/main/resources/archetype-resources/</outputDir>
+              <includes>
+                <include>**/*.png</include>
+                <include>**/*.sh</include>
+              </includes>
+              <excludes> 
+                <exclude>target/**</exclude> 
+                <exclude>test-output/**</exclude> 
+                <exclude>.*</exclude> 
+                <exclude>.*/**</exclude> 
+              </excludes>
+              <!-- no replacements for binary (put one just so we can use this plugin for consistency) -->
+              <replacements><replacement> <token>NONCE_123456789XYZ</token> <value>NONCE_123456789XYZ</value> </replacement></replacements>
+            </configuration>
+          </execution>
+          
+        </executions>
+      </plugin>
+
+    </plugins>
+      <pluginManagement>
+        <plugins>
+          <plugin>
+            <groupId>org.apache.rat</groupId>
+            <artifactId>apache-rat-plugin</artifactId>
+            <configuration>
+              <excludes combine.children="append">
+                <!-- 
+                    The maven archetype are files "without any degree of creativity". They are intended
+                    purely as a template to generate a new project for a user, where upon the user can
+                    write their code within this new project.
+                    The exclusions seem to need to include code that is auto-generated during a test run.
+                -->
+                <exclude>**/src/main/resources/archetype-resources/**/*</exclude>
+                <exclude>**/src/test/resources/projects/integration-test-1/goal.txt</exclude>
+                <exclude>**/src/test/resources/projects/integration-test-1/reference/**/*</exclude>
+                <exclude>**/src/main/java/sample/**/*Sample*.java</exclude>
+                <exclude>**/src/main/resources/logback-custom.xml</exclude>
+                <exclude>**/src/brooklyn-sample/README.md</exclude>
+                <exclude>**/src/brooklyn-sample/pom.xml</exclude>
+                <exclude>**/src/brooklyn-sample/src/main/assembly/files/conf/*</exclude>
+                <exclude>**/src/brooklyn-sample/src/main/java/**/*.java</exclude>
+                <exclude>**/src/brooklyn-sample/src/main/resources/logback-custom.xml</exclude>
+                <exclude>**/src/brooklyn-sample/src/test/java/**/*.java</exclude>
+              </excludes>
+            </configuration>
+          </plugin>
+        </plugins>
+      </pluginManagement>
+
+  </build>
+
+</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/README.md
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/README.md b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/README.md
new file mode 100644
index 0000000..b40df41
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/README.md
@@ -0,0 +1,73 @@
+brooklyn-sample
+===
+
+This is a Sample Brooklyn project, showing how to define an application
+which Brooklyn will deploy and manage.
+
+This sample project is intended to be customized to suit your purposes: but
+search for all lines containing the word "sample" to make sure all the
+references to this being a sample are removed!   
+
+To build an assembly, simply run:
+
+    mvn clean assembly:assembly
+
+This creates a tarball with a full standalone application which can be installed in any *nix machine at:
+    target/brooklyn-sample-0.1.0-SNAPSHOT-dist.tar.gz
+
+It also installs an unpacked version which you can run locally:
+ 
+     cd target/brooklyn-sample-0.1.0-SNAPSHOT-dist/brooklyn-sample-0.1.0-SNAPSHOT
+     ./start.sh server
+ 
+For more information see the README (or `./start.sh help`) in that directory.
+On OS X and Linux, this application will deploy to localhost *if* you have key-based 
+password-less (and passphrase-less) ssh enabled.
+
+To configure cloud and fixed-IP locations, see the README file in the built application directly.
+For more information you can run `./start.sh help`) in that directory.
+
+
+### Opening in an IDE
+
+To open this project in an IDE, you will need maven support enabled
+(e.g. with the relevant plugin).  You should then be able to develop
+it and run it as usual.  For more information on IDE support, visit:
+
+    https://brooklyn.incubator.apache.org/v/latest/dev/env/ide/
+
+
+### Customizing the Assembly
+
+The artifacts (directory and tar.gz by default) which get built into
+`target/` can be changed.  Simply edit the relevant files under
+`src/main/assembly`.
+
+You will likely wish to customize the `SampleMain` class as well as
+the `Sample*App` classes provided.  That is the intention!
+You will also likely want to update the `start.sh` script and
+the `README.*` files.
+
+To easily find the bits you should customize, do a:
+
+    grep -ri sample src/ *.*
+
+
+### More About Apache Brooklyn
+
+Apache Brooklyn is a code library and framework for managing applications in a 
+cloud-first dev-ops-y way.  It has been used to create this sample project 
+which shows how to define an application and entities for Brooklyn.
+
+This project can be extended for more complex topologies and more 
+interesting applications, and to develop the policies to scale or tune the 
+deployment depending on what the application needs.
+
+For more information consider:
+
+* Visiting the Apache Brooklyn home page at https://brooklyn.incubator.apache.org
+* Finding us on IRC #brooklyncentral or email (click "Community" at the site above) 
+* Forking the project at  http://github.com/apache/incubator-brooklyn/
+
+A sample Brooklyn project should specify its license.
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
new file mode 100644
index 0000000..44f5f93
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
@@ -0,0 +1,102 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+
+  <modelVersion>4.0.0</modelVersion>
+
+  <parent>
+    <groupId>org.apache.brooklyn</groupId>
+    <artifactId>brooklyn-downstream-parent</artifactId>
+    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+  </parent>
+
+  <groupId>com.acme.sample</groupId>
+  <artifactId>brooklyn-sample</artifactId>
+  <version>0.1.0-SNAPSHOT</version>
+  <packaging>jar</packaging>
+
+  <name>Sample Brooklyn Project com.acme.sample:brooklyn-sample v0.1.0-SNAPSHOT</name>
+  <description>
+    Sample optional description goes here.
+  </description>
+
+  <!-- Optional metadata (commented out in this sample) 
+
+  <url>https://github.com/sample/sample</url>
+
+  <licenses>
+    <license>
+      <name>The Apache Software License, Version 2.0</name>
+      <url>http://www.apache.org/licenses/LICENSE-2.0.txt</url>
+      <distribution>repo</distribution>
+    </license>
+  </licenses>
+
+  <developers>
+    <developer>
+      <name>Sample Project Committers</name>
+    </developer>
+  </developers>
+
+  <scm>
+    <connection>scm:git:git://github.com/sample/sample</connection>
+    <developerConnection>scm:git:git@github.com:sample/sample.git</developerConnection>
+    <url>http://github.com/sample/sample</url>
+  </scm>
+
+  -->
+
+  <properties>
+    <project.entry>com.acme.sample.brooklyn.SampleMain</project.entry>
+  </properties>
+
+  <repositories>
+    <repository>
+      <id>apache.snapshots</id>
+      <name>Apache Snapshot Repository</name>
+      <url>http://repository.apache.org/snapshots</url>
+      <releases>
+        <enabled>false</enabled>
+      </releases>
+    </repository>
+  </repositories>
+
+  <dependencies>
+    <dependency>
+      <!-- this pulls in all brooklyn entities and clouds; 
+           you can cherry pick selected ones instead (for a smaller build) -->
+      <groupId>org.apache.brooklyn</groupId>
+      <artifactId>brooklyn-all</artifactId>
+      <version>${brooklyn.version}</version>
+    </dependency>
+
+    <dependency>
+      <!-- includes testng and useful logging for tests -->
+      <groupId>org.apache.brooklyn</groupId>
+      <artifactId>brooklyn-test-support</artifactId>
+      <version>${brooklyn.version}</version>
+      <scope>test</scope>
+    </dependency>
+
+    <dependency>
+      <!-- this gives us flexible and easy-to-use logging; just edit logback-custom.xml! -->
+      <groupId>org.apache.brooklyn</groupId>
+      <artifactId>brooklyn-logback-xml</artifactId>
+      <version>${brooklyn.version}</version>
+    </dependency>
+  </dependencies>
+
+  <build>
+    <plugins>
+      <plugin>
+        <artifactId>maven-assembly-plugin</artifactId>
+        <configuration>
+          <descriptors>
+            <descriptor>src/main/assembly/assembly.xml</descriptor>
+          </descriptors>
+        </configuration>
+      </plugin>
+    </plugins>
+  </build>
+
+</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/assembly.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/assembly.xml b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/assembly.xml
new file mode 100644
index 0000000..2875a8a
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/assembly.xml
@@ -0,0 +1,88 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+    
+     http://www.apache.org/licenses/LICENSE-2.0
+    
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<assembly>
+    <id>dist</id>
+    <!-- Generates an archive and a dir containing the needed files; 
+         can add e.g. zip to the following
+         (but executable bit is not preserved) -->
+    <formats>
+        <format>dir</format>
+        <format>tar.gz</format>
+    </formats>
+
+    <!-- Adds dependencies to zip package under lib directory -->
+    <dependencySets>
+        <dependencySet>
+            <!--
+               Project artifact is not copied under library directory since
+               it is added to the root directory of the zip package.
+           -->
+            <useProjectArtifact>false</useProjectArtifact>
+            <outputDirectory>lib</outputDirectory>
+            <unpack>false</unpack>
+        </dependencySet>
+    </dependencySets>
+
+    <!--
+       Adds startup scripts to the root directory of zip package. The startup
+       scripts are located to src/main/scripts directory as stated by Maven
+       conventions.
+    -->
+    <files>
+        <file>
+            <source>src/main/assembly/scripts/start.sh</source>
+            <outputDirectory></outputDirectory>
+            <fileMode>0755</fileMode>
+            <filtered>true</filtered>
+        </file>
+    </files>
+    <fileSets>
+        <fileSet>
+            <directory>src/main/assembly/scripts</directory>
+            <outputDirectory></outputDirectory>
+            <fileMode>0755</fileMode>
+            <includes>
+                <include>*</include>
+            </includes>
+            <excludes>
+                <exclude>start.sh</exclude>
+            </excludes>
+        </fileSet>
+        <!--  add additional files (but not marked executable) -->
+        <fileSet>
+            <directory>src/main/assembly/files</directory>
+            <outputDirectory></outputDirectory>
+            <includes>
+                <include>**</include>
+            </includes>
+        </fileSet>
+        <!-- adds jar package to the root directory of zip package -->
+        <fileSet>
+            <directory>target</directory>
+            <outputDirectory></outputDirectory>
+            <includes>
+                <include>*.jar</include>
+            </includes>
+            <excludes>
+                <exclude>*-tests.jar</exclude>
+            </excludes>
+        </fileSet>
+    </fileSets>
+</assembly>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/README.txt
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/README.txt b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/README.txt
new file mode 100644
index 0000000..8ba14f1
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/README.txt
@@ -0,0 +1,96 @@
+brooklyn-sample
+===
+
+This is a sample application which is launched and managed by Brooklyn.
+This README file is at the root of the built assembly, which can be uploaded
+and run most anywhere.  This file provides end-user instructions.
+
+To use this, configure any cloud credentials then run  ./start.sh  in this 
+directory. You can then access the management context in your browser, 
+typically on  http://localhost:8081 , and through that console deploy the
+applications contained in this archive.
+
+
+### Cloud Credentials
+
+To run, you'll need to specify credentials for your preferred cloud.  This 
+can be done in `~/.brooklyn/brooklyn.properties`.
+
+A recommended starting point is the file at:
+
+    https://brooklyn.incubator.apache.org/v/latest/use/guide/quickstart/brooklyn.properties
+
+As a quick-start, you can specify:
+
+    brooklyn.location.jclouds.aws-ec2.identity=AKXXXXXXXXXXXXXXXXXX
+    brooklyn.location.jclouds.aws-ec2.credential=secret01xxxxxxxxxxxxxxxxxxxxxxxxxxx
+    
+    brooklyn.location.named.My_Amazon_US_west=jclouds:aws-ec2:us-west-1
+    brooklyn.location.named.My_Amazon_EU=jclouds:aws-ec2:eu-west-1
+
+Alternatively these can be set as shell environment parameters or JVM system properties.
+
+Many other clouds are supported also, as well as pre-existing machines 
+("bring your own nodes"), custom endpoints for private clouds, and specifying 
+custom keys and passphrases. For more information see:
+
+    https://brooklyn.incubator.apache.org/v/latest/use/guide/defining-applications/common-usage#locations
+
+
+### Run
+
+Usage:
+
+    ./start.sh launch [--WHAT] \
+        [--port 8081+] \
+        [--location location] 
+
+The optional port argument specifies the port where the Brooklyn console 
+will be running, such as localhost:8081. (The console is only bound to 
+localhost, unless you set up users and security, as described at
+https://brooklyn.incubator.apache.org/v/latest/use/guide/management/ .)
+
+In the console, you can access the catalog and deploy applications to
+configured locations.
+
+In this sample application, `--cluster` and `--single` are supported in place of `--WHAT`,
+corresponding to sample blueprints in the project. This can be left blank to have nothing 
+launched; note that the blueprints can be launched at runtime via the GUI or API.
+
+Use `./start.sh help` or `./start.sh help launch` for more detailed help.
+
+The location might be `localhost` (the default), `aws-ec2:us-east-1`, 
+`openstack:endpoint`, `softlayer`, or based on names, such as
+`named:My_Amazon_US_west`, so long as it is configured as above. 
+(Localhost does not need any configuration in `~/brooklyn/brooklyn.properties`, 
+provided you have password-less ssh access enabled to localhost, using a 
+private key with no passphrase.) 
+
+
+### More About Brooklyn
+
+Brooklyn is a code library and framework for managing applications in a 
+cloud-first dev-ops-y way.  It has been used to create this sample project 
+which shows how to define an application and entities for Brooklyn.
+
+This project can be extended for more complex topologies and more 
+interesting applications, and to develop the policies to scale or tune the 
+deployment depending on what the application needs.
+
+For more information consider:
+
+* Visiting the open-source Brooklyn home page at  http://brooklyncentral.github.com
+* Forking the Brooklyn project at  http://github.com/brooklyncentral/brooklyn
+* Emailing  brooklyn-users@googlegroups.com 
+
+For commercial enquiries -- including bespoke development and paid support --
+contact Cloudsoft, the supporters of Brooklyn, at:
+
+* www.CloudsoftCorp.com
+* info@cloudsoftcorp.com
+
+Brooklyn is (c) 2014 Cloudsoft Corporation and released as open source under 
+the Apache License v2.0.
+
+A sample Brooklyn project should specify its license here.
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/conf/logback.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/conf/logback.xml b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/conf/logback.xml
new file mode 100644
index 0000000..7b7a972
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/conf/logback.xml
@@ -0,0 +1,11 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<configuration>
+
+  <!-- logging configuration for this project; edit this file as required, or override the files 
+       this includes as described in the Logging section of the brooklyn users guide.
+       this project already supplies a logback-custom.xml which gets included to log our
+       classes at debug level and write to a log file named after this project -->
+
+  <include resource="logback-main.xml"/>
+  
+</configuration>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/scripts/start.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/scripts/start.sh b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/scripts/start.sh
new file mode 100755
index 0000000..2879b6d
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/scripts/start.sh
@@ -0,0 +1,40 @@
+#!/bin/bash
+#
+# 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.
+#
+
+if [ ! -z "$JAVA_HOME" ] ; then 
+    JAVA=$JAVA_HOME/bin/java
+else
+    JAVA=`which java`
+fi
+
+if [ ! -x "$JAVA" ] ; then
+  echo Cannot find java. Set JAVA_HOME or add java to path.
+  exit 1
+fi
+
+if [[ ! `ls ${project.artifactId}-*.jar 2> /dev/null` ]] ; then
+  echo Command must be run from the directory where the JAR is installed.
+  exit 4
+fi
+
+$JAVA -Xms256m -Xmx1024m -XX:MaxPermSize=1024m \
+    -classpath "conf/:patch/*:*:lib/*" \
+    ${project.entry} \
+    "$@"

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/SampleMain.java
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/SampleMain.java b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/SampleMain.java
new file mode 100644
index 0000000..253f657
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/SampleMain.java
@@ -0,0 +1,81 @@
+package com.acme.sample.brooklyn;
+
+import java.util.Arrays;
+
+import io.airlift.command.Command;
+import io.airlift.command.Option;
+
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import org.apache.brooklyn.api.catalog.BrooklynCatalog;
+import org.apache.brooklyn.cli.Main;
+
+import com.google.common.base.Objects.ToStringHelper;
+
+import com.acme.sample.brooklyn.sample.app.*;
+
+/**
+ * This class provides a static main entry point for launching a custom Brooklyn-based app.
+ * <p>
+ * It inherits the standard Brooklyn CLI options from {@link Main},
+ * plus adds a few more shortcuts for favourite blueprints to the {@link LaunchCommand}.
+ */
+public class SampleMain extends Main {
+    
+    private static final Logger log = LoggerFactory.getLogger(SampleMain.class);
+    
+    public static final String DEFAULT_LOCATION = "localhost";
+
+    public static void main(String... args) {
+        log.debug("CLI invoked with args "+Arrays.asList(args));
+        new SampleMain().execCli(args);
+    }
+
+    @Override
+    protected String cliScriptName() {
+        return "start.sh";
+    }
+    
+    @Override
+    protected Class<? extends BrooklynCommand> cliLaunchCommand() {
+        return LaunchCommand.class;
+    }
+
+    @Command(name = "launch", description = "Starts a server, and optionally an application. "
+        + "Use e.g. --single or --cluster to launch one-node and clustered variants of the sample web application.")
+    public static class LaunchCommand extends Main.LaunchCommand {
+
+        // add these options to the LaunchCommand as shortcuts for our favourite applications
+        
+        @Option(name = { "--single" }, description = "Launch a single web-server instance")
+        public boolean single;
+
+        @Option(name = { "--cluster" }, description = "Launch a web-server cluster")
+        public boolean cluster;
+
+        @Override
+        public Void call() throws Exception {
+            // process our CLI arguments
+            if (single) setAppToLaunch( SingleWebServerSample.class.getCanonicalName() );
+            if (cluster) setAppToLaunch( ClusterWebServerDatabaseSample.class.getCanonicalName() );
+            
+            // now process the standard launch arguments
+            return super.call();
+        }
+
+        @Override
+        protected void populateCatalog(BrooklynCatalog catalog) {
+            super.populateCatalog(catalog);
+            catalog.addItem(SingleWebServerSample.class);
+            catalog.addItem(ClusterWebServerDatabaseSample.class);
+        }
+
+        @Override
+        public ToStringHelper string() {
+            return super.string()
+                    .add("single", single)
+                    .add("cluster", cluster);
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/ClusterWebServerDatabaseSample.java
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/ClusterWebServerDatabaseSample.java b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/ClusterWebServerDatabaseSample.java
new file mode 100644
index 0000000..11d977f
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/ClusterWebServerDatabaseSample.java
@@ -0,0 +1,137 @@
+package com.acme.sample.brooklyn.sample.app;
+
+import java.util.concurrent.TimeUnit;
+
+import org.apache.brooklyn.api.catalog.Catalog;
+import org.apache.brooklyn.api.catalog.CatalogConfig;
+import org.apache.brooklyn.api.entity.EntitySpec;
+import org.apache.brooklyn.api.sensor.AttributeSensor;
+import org.apache.brooklyn.config.ConfigKey;
+import org.apache.brooklyn.core.config.ConfigKeys;
+import org.apache.brooklyn.core.entity.AbstractApplication;
+import org.apache.brooklyn.core.entity.Entities;
+import org.apache.brooklyn.core.location.PortRanges;
+import org.apache.brooklyn.core.sensor.Sensors;
+import org.apache.brooklyn.enricher.stock.SensorPropagatingEnricher;
+import org.apache.brooklyn.enricher.stock.SensorTransformingEnricher;
+import org.apache.brooklyn.entity.database.DatastoreMixins.DatastoreCommon;
+import org.apache.brooklyn.entity.database.mysql.MySqlNode;
+import org.apache.brooklyn.entity.group.DynamicCluster;
+import org.apache.brooklyn.entity.java.JavaEntityMethods;
+import org.apache.brooklyn.entity.webapp.ControlledDynamicWebAppCluster;
+import org.apache.brooklyn.entity.webapp.DynamicWebAppCluster;
+import org.apache.brooklyn.entity.webapp.JavaWebAppService;
+import org.apache.brooklyn.entity.webapp.WebAppService;
+import org.apache.brooklyn.entity.webapp.WebAppServiceConstants;
+import org.apache.brooklyn.policy.autoscaling.AutoScalerPolicy;
+import org.apache.brooklyn.policy.enricher.HttpLatencyDetector;
+import org.apache.brooklyn.util.maven.MavenArtifact;
+import org.apache.brooklyn.util.maven.MavenRetriever;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import com.google.common.base.Functions;
+
+import static org.apache.brooklyn.core.sensor.DependentConfiguration.attributeWhenReady;
+import static org.apache.brooklyn.core.sensor.DependentConfiguration.formatString;
+
+
+/** This sample builds a 3-tier application with an elastic app-server cluster,
+ *  and it sets it up for use in the Brooklyn catalog. 
+ *  <p>
+ *  Note that root access (and xcode etc) may be required to install nginx.
+ **/
+@Catalog(name="Elastic Java Web + DB",
+    description="Deploys a WAR to a load-balanced elastic Java AppServer cluster, " +
+        "with an auto-scaling policy, " +
+        "wired to a database initialized with the provided SQL; " +
+        "defaults to a 'Hello World' chatroom app.",
+    iconUrl="classpath://sample-icon.png")
+public class ClusterWebServerDatabaseSample extends AbstractApplication {
+
+    public static final Logger LOG = LoggerFactory.getLogger(ClusterWebServerDatabaseSample.class);
+
+    // ---------- WAR configuration ---------------
+    
+    public static final String DEFAULT_WAR_URL =
+            // can supply any URL -- this loads a stock example from maven central / sonatype
+            MavenRetriever.localUrl(MavenArtifact.fromCoordinate("io.brooklyn.example:brooklyn-example-hello-world-sql-webapp:war:0.5.0"));
+
+    @CatalogConfig(label="WAR (URL)", priority=2)
+    public static final ConfigKey<String> WAR_URL = ConfigKeys.newConfigKey(
+        "app.war", "URL to the application archive which should be deployed", DEFAULT_WAR_URL);    
+
+    
+    // ---------- DB configuration ----------------
+    
+    // this is included in src/main/resources. if in an IDE, ensure your build path is set appropriately.
+    public static final String DEFAULT_DB_SETUP_SQL_URL = "classpath://visitors-creation-script.sql";
+    
+    @CatalogConfig(label="DB Setup SQL (URL)", priority=1)
+    public static final ConfigKey<String> DB_SETUP_SQL_URL = ConfigKeys.newConfigKey(
+        "app.db_sql", "URL to the SQL script to set up the database", 
+        DEFAULT_DB_SETUP_SQL_URL);
+    
+    public static final String DB_TABLE = "visitors";
+    public static final String DB_USERNAME = "brooklyn";
+    public static final String DB_PASSWORD = "br00k11n";
+    
+
+    // --------- Custom Sensor --------------------
+    
+    AttributeSensor<Integer> APPSERVERS_COUNT = Sensors.newIntegerSensor( 
+            "appservers.count", "Number of app servers deployed");
+
+    
+    // --------- Initialization -------------------
+    
+    /** Initialize our application. In this case it consists of 
+     *  a single DB, with a load-balanced cluster (nginx + multiple JBosses, by default),
+     *  with some sensors and a policy. */
+    @Override
+    public void init() {
+        DatastoreCommon db = addChild(
+                EntitySpec.create(MySqlNode.class)
+                        .configure(MySqlNode.CREATION_SCRIPT_URL, Entities.getRequiredUrlConfig(this, DB_SETUP_SQL_URL)));
+
+        ControlledDynamicWebAppCluster web = addChild(
+                EntitySpec.create(ControlledDynamicWebAppCluster.class)
+                        // set WAR to use, and port to use
+                        .configure(JavaWebAppService.ROOT_WAR, getConfig(WAR_URL))
+                        .configure(WebAppService.HTTP_PORT, PortRanges.fromString("8080+"))
+                        
+//                        // optionally - use Tomcat instead of JBoss (default:
+//                        .configure(ControlledDynamicWebAppCluster.MEMBER_SPEC, EntitySpec.create(TomcatServer.class))
+                        
+                        // inject a JVM system property to point to the DB
+                        .configure(JavaEntityMethods.javaSysProp("brooklyn.example.db.url"), 
+                                formatString("jdbc:%s%s?user=%s\\&password=%s", 
+                                        attributeWhenReady(db, DatastoreCommon.DATASTORE_URL), DB_TABLE, DB_USERNAME, DB_PASSWORD))
+                    
+                        // start with 2 appserver nodes, initially
+                        .configure(DynamicCluster.INITIAL_SIZE, 2) 
+                    );
+
+        // add an enricher which measures latency
+        web.addEnricher(HttpLatencyDetector.builder().
+                url(WebAppServiceConstants.ROOT_URL).
+                rollup(10, TimeUnit.SECONDS).
+                build());
+
+        // add a policy which scales out based on Reqs/Sec
+        web.getCluster().addPolicy(AutoScalerPolicy.builder().
+                metric(DynamicWebAppCluster.REQUESTS_PER_SECOND_IN_WINDOW_PER_NODE).
+                metricRange(10, 100).
+                sizeRange(2, 5).
+                build());
+
+        // add a few more sensors at the top-level (KPI's at the root of the application)
+        addEnricher(SensorPropagatingEnricher.newInstanceListeningTo(web,  
+                WebAppServiceConstants.ROOT_URL,
+                DynamicWebAppCluster.REQUESTS_PER_SECOND_IN_WINDOW,
+                HttpLatencyDetector.REQUEST_LATENCY_IN_SECONDS_IN_WINDOW));
+        addEnricher(SensorTransformingEnricher.newInstanceTransforming(web, 
+                DynamicWebAppCluster.GROUP_SIZE, Functions.<Integer>identity(), APPSERVERS_COUNT));
+    }
+    
+}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/SingleWebServerSample.java
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/SingleWebServerSample.java b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/SingleWebServerSample.java
new file mode 100644
index 0000000..3cc9426
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/SingleWebServerSample.java
@@ -0,0 +1,32 @@
+package com.acme.sample.brooklyn.sample.app;
+
+import org.apache.brooklyn.api.entity.EntitySpec;
+import org.apache.brooklyn.core.entity.AbstractApplication;
+import org.apache.brooklyn.core.entity.Attributes;
+import org.apache.brooklyn.core.location.PortRanges;
+import org.apache.brooklyn.entity.webapp.JavaWebAppService;
+import org.apache.brooklyn.entity.webapp.jboss.JBoss7Server;
+import org.apache.brooklyn.util.maven.MavenArtifact;
+import org.apache.brooklyn.util.maven.MavenRetriever;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+/** This example starts one web app on 8080. */
+public class SingleWebServerSample extends AbstractApplication {
+
+    public static final Logger LOG = LoggerFactory.getLogger(SingleWebServerSample.class);
+
+    public static final String DEFAULT_WAR_URL =
+            // can supply any URL -- this loads a stock example from maven central / sonatype
+            MavenRetriever.localUrl(MavenArtifact.fromCoordinate("io.brooklyn.example:brooklyn-example-hello-world-sql-webapp:war:0.5.0"));
+
+    /** Initialize our application. In this case it consists of 
+     *  a single JBoss entity, configured to run the WAR above. */
+    @Override
+    public void init() {
+        addChild(EntitySpec.create(JBoss7Server.class)
+                .configure(JavaWebAppService.ROOT_WAR, DEFAULT_WAR_URL)
+                .configure(Attributes.HTTP_PORT, PortRanges.fromString("8080+")));
+    }
+
+}


[09/51] [abbrv] brooklyn-dist git commit: [SPLITPREP] rearranged to have structure of new repositories

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/logback-custom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/logback-custom.xml b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/logback-custom.xml
new file mode 100644
index 0000000..5a1ec98
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/logback-custom.xml
@@ -0,0 +1,10 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<included>
+
+    <!-- include everything in this project at debug level -->
+    <logger name="com.acme.sample.brooklyn" level="DEBUG"/>    
+    
+    <!-- logfile named after this project -->
+    <property name="logging.basename" scope="context" value="brooklyn-sample" />
+
+</included>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/sample-icon.png
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/sample-icon.png b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/sample-icon.png
new file mode 100644
index 0000000..542a1de
Binary files /dev/null and b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/sample-icon.png differ

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/visitors-creation-script.sql
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/visitors-creation-script.sql b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/visitors-creation-script.sql
new file mode 100644
index 0000000..0a805c4
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/visitors-creation-script.sql
@@ -0,0 +1,35 @@
+--
+-- 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.
+--
+create database visitors;
+use visitors;
+create user 'brooklyn' identified by 'br00k11n';
+grant usage on *.* to 'brooklyn'@'%' identified by 'br00k11n';
+# ''@localhost is sometimes set up, overriding brooklyn@'%', so do a second explicit grant
+grant usage on *.* to 'brooklyn'@'localhost' identified by 'br00k11n';
+grant all privileges on visitors.* to 'brooklyn'@'%';
+flush privileges;
+
+CREATE TABLE MESSAGES (
+        id INT NOT NULL AUTO_INCREMENT,
+        NAME VARCHAR(30) NOT NULL,
+        MESSAGE VARCHAR(400) NOT NULL,
+        PRIMARY KEY (ID)
+    );
+
+INSERT INTO MESSAGES values (default, 'Isaac Asimov', 'I grew up in Brooklyn' );

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleLocalhostIntegrationTest.java
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleLocalhostIntegrationTest.java b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleLocalhostIntegrationTest.java
new file mode 100644
index 0000000..f640f6a
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleLocalhostIntegrationTest.java
@@ -0,0 +1,81 @@
+package com.acme.sample.brooklyn.sample.app;
+
+import java.util.Arrays;
+import java.util.Iterator;
+
+import org.apache.brooklyn.api.entity.Entity;
+import org.apache.brooklyn.api.entity.EntitySpec;
+import org.apache.brooklyn.api.mgmt.ManagementContext;
+import org.apache.brooklyn.core.mgmt.internal.LocalManagementContext;
+import org.apache.brooklyn.core.entity.Entities;
+import org.apache.brooklyn.core.entity.StartableApplication;
+import org.apache.brooklyn.entity.webapp.JavaWebAppService;
+import org.apache.brooklyn.util.core.ResourceUtils;
+import org.apache.brooklyn.util.text.Strings;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+import org.testng.Assert;
+import org.testng.annotations.AfterMethod;
+import org.testng.annotations.BeforeMethod;
+import org.testng.annotations.Test;
+
+/**
+ * Sample integration tests which show how to launch the sample applications on localhost,
+ * make some assertions about them, and then destroy them.
+ */
+@Test(groups="Integration")
+public class SampleLocalhostIntegrationTest {
+
+    private static final Logger log = LoggerFactory.getLogger(SampleLocalhostIntegrationTest.class);
+    
+    private ManagementContext mgmt;
+
+    @BeforeMethod(alwaysRun=true)
+    public void setup() {
+        mgmt = new LocalManagementContext();
+    }
+
+    @AfterMethod(alwaysRun=true)
+    public void shutdown() {
+        if (mgmt != null) Entities.destroyAll(mgmt);
+    }
+
+
+    public void testSingle() {
+        StartableApplication app = mgmt.getEntityManager().createEntity(
+                EntitySpec.create(StartableApplication.class, SingleWebServerSample.class));
+        Entities.startManagement(app, mgmt);
+        Entities.start(app, Arrays.asList(mgmt.getLocationRegistry().resolve("localhost")));
+        
+        Iterator<Entity> children = app.getChildren().iterator();
+        if (!children.hasNext()) Assert.fail("Should have had a single JBoss child; had none");
+        
+        Entity web = children.next();
+        
+        if (children.hasNext()) Assert.fail("Should have had a single JBoss child; had too many: "+app.getChildren());
+        
+        String url = web.getAttribute(JavaWebAppService.ROOT_URL);
+        Assert.assertNotNull(url);
+        
+        String page = new ResourceUtils(this).getResourceAsString(url);
+        log.info("Read web page for "+app+" from "+url+":\n"+page);
+        Assert.assertTrue(!Strings.isBlank(page));
+    }
+
+    public void testCluster() {
+        StartableApplication app = mgmt.getEntityManager().createEntity(
+                EntitySpec.create(StartableApplication.class, ClusterWebServerDatabaseSample.class));
+        Entities.startManagement(app, mgmt);
+        Entities.start(app, Arrays.asList(mgmt.getLocationRegistry().resolve("localhost")));
+        
+        log.debug("APP is started");
+        
+        String url = app.getAttribute(JavaWebAppService.ROOT_URL);
+        Assert.assertNotNull(url);
+
+        String page = new ResourceUtils(this).getResourceAsString(url);
+        log.info("Read web page for "+app+" from "+url+":\n"+page);
+        Assert.assertTrue(!Strings.isBlank(page));
+    }
+    
+}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleUnitTest.java
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleUnitTest.java b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleUnitTest.java
new file mode 100644
index 0000000..6a34301
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleUnitTest.java
@@ -0,0 +1,69 @@
+package com.acme.sample.brooklyn.sample.app;
+
+import org.apache.brooklyn.api.entity.Entity;
+import org.apache.brooklyn.api.entity.EntitySpec;
+import org.apache.brooklyn.api.mgmt.ManagementContext;
+import org.apache.brooklyn.core.mgmt.internal.LocalManagementContext;
+import org.apache.brooklyn.core.entity.Entities;
+import org.apache.brooklyn.core.entity.StartableApplication;
+import org.apache.brooklyn.entity.database.DatastoreMixins.DatastoreCommon;
+import org.apache.brooklyn.entity.database.mysql.MySqlNode;
+import org.apache.brooklyn.entity.webapp.JavaWebAppService;
+import org.apache.brooklyn.entity.webapp.WebAppService;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+import org.testng.Assert;
+import org.testng.annotations.AfterMethod;
+import org.testng.annotations.BeforeMethod;
+import org.testng.annotations.Test;
+
+import com.google.common.base.Predicates;
+import com.google.common.collect.Iterables;
+
+/** 
+ * Unit tests for the sample applications defined in this project.
+ * Shows how to examine the spec and make assertions about configuration.
+ */
+@Test
+public class SampleUnitTest {
+
+    private static final Logger log = LoggerFactory.getLogger(SampleUnitTest.class);
+
+    
+    private ManagementContext mgmt;
+
+    @BeforeMethod(alwaysRun=true)
+    public void setup() {
+        mgmt = new LocalManagementContext();
+    }
+
+    @AfterMethod(alwaysRun=true)
+    public void shutdown() {
+        if (mgmt != null) Entities.destroyAll(mgmt);
+    }
+
+    
+    public void testSampleSingleStructure() {
+        StartableApplication app = mgmt.getEntityManager().createEntity(
+                EntitySpec.create(StartableApplication.class, SingleWebServerSample.class));
+        log.info("app from spec is: "+app);
+        
+        Assert.assertEquals(app.getChildren().size(), 1);
+        Assert.assertNotNull( app.getChildren().iterator().next().getConfig(JavaWebAppService.ROOT_WAR) );
+    }
+    
+    public void testSampleClusterStructure() {
+        StartableApplication app = mgmt.getEntityManager().createEntity(
+                EntitySpec.create(StartableApplication.class, ClusterWebServerDatabaseSample.class));
+        log.info("app from spec is: "+app);
+        
+        Assert.assertEquals(app.getChildren().size(), 2);
+        
+        Entity webappCluster = Iterables.find(app.getChildren(), Predicates.instanceOf(WebAppService.class));
+        Entity database = Iterables.find(app.getChildren(), Predicates.instanceOf(DatastoreCommon.class));
+        
+        Assert.assertNotNull( webappCluster.getConfig(JavaWebAppService.ROOT_WAR) );
+        Assert.assertNotNull( database.getConfig(MySqlNode.CREATION_SCRIPT_URL) );
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/main/resources/.gitignore
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/main/resources/.gitignore b/brooklyn-dist/archetypes/quickstart/src/main/resources/.gitignore
new file mode 100644
index 0000000..6d7b6a3
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/main/resources/.gitignore
@@ -0,0 +1 @@
+archetype-resources

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/main/resources/META-INF/maven/archetype-metadata.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/main/resources/META-INF/maven/archetype-metadata.xml b/brooklyn-dist/archetypes/quickstart/src/main/resources/META-INF/maven/archetype-metadata.xml
new file mode 100644
index 0000000..4768945
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/main/resources/META-INF/maven/archetype-metadata.xml
@@ -0,0 +1,65 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+    
+     http://www.apache.org/licenses/LICENSE-2.0
+    
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<archetype xmlns="http://maven.apache.org/plugins/maven-archetype-plugin/archetype/1.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+  xsi:schemaLocation="http://maven.apache.org/plugins/maven-archetype-plugin/archetype/1.0.0 http://maven.apache.org/xsd/archetype-1.0.0.xsd">
+
+  <fileSets>
+    <fileSet filtered="true" packaged="true">
+      <directory>src/main/java</directory>
+      <includes>
+        <include>**/*.java</include>
+      </includes>
+    </fileSet>
+    
+    <fileSet filtered="true" packaged="true">
+      <directory>src/test/java</directory>
+      <includes>
+        <include>**/*.java</include>
+      </includes>
+    </fileSet>
+    
+    <!-- we cannot have src/main/resources/** be "packaged" (package dirs prepended) and non-packaged;
+         so we put everything non-packaged here.
+         (also note for src/main/java, the root pom uses google-replacer to drop the "package" directory) -->
+           
+    <fileSet filtered="false" packaged="false">
+      <directory></directory>
+      <includes>
+        <include>**/*.png</include>
+        <include>**/*.sh</include>
+      </includes>
+    </fileSet>
+    <fileSet filtered="true" packaged="false">
+      <directory></directory>
+      <includes>
+        <include>**/*</include>
+        <include>*</include>
+      </includes>
+      <excludes>
+        <exclude>src/main/java/**</exclude> 
+        <exclude>src/test/java/**</exclude> 
+        <exclude>pom.xml</exclude>
+        <exclude>**.png</exclude>
+        <exclude>**.sh</exclude>
+      </excludes>
+    </fileSet>
+  </fileSets>
+
+</archetype>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/.gitignore
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/.gitignore b/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/.gitignore
new file mode 100644
index 0000000..25d80f5
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/.gitignore
@@ -0,0 +1 @@
+reference

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/archetype.properties
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/archetype.properties b/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/archetype.properties
new file mode 100644
index 0000000..d1f4da4
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/archetype.properties
@@ -0,0 +1,22 @@
+#
+# 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.
+#
+groupId=com.acme.sample
+artifactId=brooklyn-sample
+version=0.1.0-SNAPSHOT
+package=com.acme.sample.brooklyn

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/goal.txt
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/goal.txt b/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/goal.txt
new file mode 100644
index 0000000..f7ffc47
--- /dev/null
+++ b/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/goal.txt
@@ -0,0 +1 @@
+install
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/.gitignore
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/.gitignore b/brooklyn-dist/dist/licensing/.gitignore
new file mode 100644
index 0000000..2d17061
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/.gitignore
@@ -0,0 +1,2 @@
+LICENSE.autogenerated
+notices.autogenerated

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/MAIN_LICENSE_ASL2
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/MAIN_LICENSE_ASL2 b/brooklyn-dist/dist/licensing/MAIN_LICENSE_ASL2
new file mode 100644
index 0000000..68c771a
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/MAIN_LICENSE_ASL2
@@ -0,0 +1,176 @@
+
+                                 Apache License
+                           Version 2.0, January 2004
+                        http://www.apache.org/licenses/
+
+   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+
+   1. Definitions.
+
+      "License" shall mean the terms and conditions for use, reproduction,
+      and distribution as defined by Sections 1 through 9 of this document.
+
+      "Licensor" shall mean the copyright owner or entity authorized by
+      the copyright owner that is granting the License.
+
+      "Legal Entity" shall mean the union of the acting entity and all
+      other entities that control, are controlled by, or are under common
+      control with that entity. For the purposes of this definition,
+      "control" means (i) the power, direct or indirect, to cause the
+      direction or management of such entity, whether by contract or
+      otherwise, or (ii) ownership of fifty percent (50%) or more of the
+      outstanding shares, or (iii) beneficial ownership of such entity.
+
+      "You" (or "Your") shall mean an individual or Legal Entity
+      exercising permissions granted by this License.
+
+      "Source" form shall mean the preferred form for making modifications,
+      including but not limited to software source code, documentation
+      source, and configuration files.
+
+      "Object" form shall mean any form resulting from mechanical
+      transformation or translation of a Source form, including but
+      not limited to compiled object code, generated documentation,
+      and conversions to other media types.
+
+      "Work" shall mean the work of authorship, whether in Source or
+      Object form, made available under the License, as indicated by a
+      copyright notice that is included in or attached to the work
+      (an example is provided in the Appendix below).
+
+      "Derivative Works" shall mean any work, whether in Source or Object
+      form, that is based on (or derived from) the Work and for which the
+      editorial revisions, annotations, elaborations, or other modifications
+      represent, as a whole, an original work of authorship. For the purposes
+      of this License, Derivative Works shall not include works that remain
+      separable from, or merely link (or bind by name) to the interfaces of,
+      the Work and Derivative Works thereof.
+
+      "Contribution" shall mean any work of authorship, including
+      the original version of the Work and any modifications or additions
+      to that Work or Derivative Works thereof, that is intentionally
+      submitted to Licensor for inclusion in the Work by the copyright owner
+      or by an individual or Legal Entity authorized to submit on behalf of
+      the copyright owner. For the purposes of this definition, "submitted"
+      means any form of electronic, verbal, or written communication sent
+      to the Licensor or its representatives, including but not limited to
+      communication on electronic mailing lists, source code control systems,
+      and issue tracking systems that are managed by, or on behalf of, the
+      Licensor for the purpose of discussing and improving the Work, but
+      excluding communication that is conspicuously marked or otherwise
+      designated in writing by the copyright owner as "Not a Contribution."
+
+      "Contributor" shall mean Licensor and any individual or Legal Entity
+      on behalf of whom a Contribution has been received by Licensor and
+      subsequently incorporated within the Work.
+
+   2. Grant of Copyright License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      copyright license to reproduce, prepare Derivative Works of,
+      publicly display, publicly perform, sublicense, and distribute the
+      Work and such Derivative Works in Source or Object form.
+
+   3. Grant of Patent License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      (except as stated in this section) patent license to make, have made,
+      use, offer to sell, sell, import, and otherwise transfer the Work,
+      where such license applies only to those patent claims licensable
+      by such Contributor that are necessarily infringed by their
+      Contribution(s) alone or by combination of their Contribution(s)
+      with the Work to which such Contribution(s) was submitted. If You
+      institute patent litigation against any entity (including a
+      cross-claim or counterclaim in a lawsuit) alleging that the Work
+      or a Contribution incorporated within the Work constitutes direct
+      or contributory patent infringement, then any patent licenses
+      granted to You under this License for that Work shall terminate
+      as of the date such litigation is filed.
+
+   4. Redistribution. You may reproduce and distribute copies of the
+      Work or Derivative Works thereof in any medium, with or without
+      modifications, and in Source or Object form, provided that You
+      meet the following conditions:
+
+      (a) You must give any other recipients of the Work or
+          Derivative Works a copy of this License; and
+
+      (b) You must cause any modified files to carry prominent notices
+          stating that You changed the files; and
+
+      (c) You must retain, in the Source form of any Derivative Works
+          that You distribute, all copyright, patent, trademark, and
+          attribution notices from the Source form of the Work,
+          excluding those notices that do not pertain to any part of
+          the Derivative Works; and
+
+      (d) If the Work includes a "NOTICE" text file as part of its
+          distribution, then any Derivative Works that You distribute must
+          include a readable copy of the attribution notices contained
+          within such NOTICE file, excluding those notices that do not
+          pertain to any part of the Derivative Works, in at least one
+          of the following places: within a NOTICE text file distributed
+          as part of the Derivative Works; within the Source form or
+          documentation, if provided along with the Derivative Works; or,
+          within a display generated by the Derivative Works, if and
+          wherever such third-party notices normally appear. The contents
+          of the NOTICE file are for informational purposes only and
+          do not modify the License. You may add Your own attribution
+          notices within Derivative Works that You distribute, alongside
+          or as an addendum to the NOTICE text from the Work, provided
+          that such additional attribution notices cannot be construed
+          as modifying the License.
+
+      You may add Your own copyright statement to Your modifications and
+      may provide additional or different license terms and conditions
+      for use, reproduction, or distribution of Your modifications, or
+      for any such Derivative Works as a whole, provided Your use,
+      reproduction, and distribution of the Work otherwise complies with
+      the conditions stated in this License.
+
+   5. Submission of Contributions. Unless You explicitly state otherwise,
+      any Contribution intentionally submitted for inclusion in the Work
+      by You to the Licensor shall be under the terms and conditions of
+      this License, without any additional terms or conditions.
+      Notwithstanding the above, nothing herein shall supersede or modify
+      the terms of any separate license agreement you may have executed
+      with Licensor regarding such Contributions.
+
+   6. Trademarks. This License does not grant permission to use the trade
+      names, trademarks, service marks, or product names of the Licensor,
+      except as required for reasonable and customary use in describing the
+      origin of the Work and reproducing the content of the NOTICE file.
+
+   7. Disclaimer of Warranty. Unless required by applicable law or
+      agreed to in writing, Licensor provides the Work (and each
+      Contributor provides its Contributions) on an "AS IS" BASIS,
+      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+      implied, including, without limitation, any warranties or conditions
+      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
+      PARTICULAR PURPOSE. You are solely responsible for determining the
+      appropriateness of using or redistributing the Work and assume any
+      risks associated with Your exercise of permissions under this License.
+
+   8. Limitation of Liability. In no event and under no legal theory,
+      whether in tort (including negligence), contract, or otherwise,
+      unless required by applicable law (such as deliberate and grossly
+      negligent acts) or agreed to in writing, shall any Contributor be
+      liable to You for damages, including any direct, indirect, special,
+      incidental, or consequential damages of any character arising as a
+      result of this License or out of the use or inability to use the
+      Work (including but not limited to damages for loss of goodwill,
+      work stoppage, computer failure or malfunction, or any and all
+      other commercial damages or losses), even if such Contributor
+      has been advised of the possibility of such damages.
+
+   9. Accepting Warranty or Additional Liability. While redistributing
+      the Work or Derivative Works thereof, You may choose to offer,
+      and charge a fee for, acceptance of support, warranty, indemnity,
+      or other liability obligations and/or rights consistent with this
+      License. However, in accepting such obligations, You may act only
+      on Your own behalf and on Your sole responsibility, not on behalf
+      of any other Contributor, and only if You agree to indemnify,
+      defend, and hold each Contributor harmless for any liability
+      incurred by, or claims asserted against, such Contributor by reason
+      of your accepting any such warranty or additional liability.
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/README.md
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/README.md b/brooklyn-dist/dist/licensing/README.md
new file mode 100644
index 0000000..94ae070
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/README.md
@@ -0,0 +1,78 @@
+
+We use a special maven plugin and scripts to automatically create the LICENSE
+files, including all notices, based on metadata in overrides.yaml and **/source-inclusions.yaml.
+
+First install  https://github.com/ahgittin/license-audit-maven-plugin 
+and then, in the usage/dist/ project of Brooklyn...
+
+
+# Quick Usage
+
+To see a tree of license info:
+
+    mvn org.heneveld.maven:license-audit-maven-plugin:report \
+        -Dformat=summary \
+        -DlicensesPreferred=ASL2,ASL,EPL1,BSD-2-Clause,BSD-3-Clause,CDDL1.1,CDDL1,CDDL \
+        -DoverridesFile=licensing/overrides.yaml \
+        -DextrasFiles=`cat licensing/extras-files`
+
+
+To create the LICENSE files needed for Apache Brooklyn
+(consisting of: one in the root for the source build, in the dist project for the binary build,
+and in `projects-with-custom-licenses` for those JARs which include other source code):
+
+    pushd licensing
+    ./make-all-licenses.sh || ( echo 'FAILED!!!' && rm LICENSE.autogenerated )
+    popd
+
+This combines the relevant `source-inclusions.yaml` files to create `extrasFile` files
+for `license-audit-maven-plugin` then runs the `notices` target for the various dists we make.
+If you need to add a new project to those which require custom LICENSE files, see below.
+
+
+# CSV License Report
+
+If you need to generate a CSV report of license usage, e.g. for use in a spreadsheet:
+
+    mvn org.heneveld.maven:license-audit-maven-plugin:report \
+        -Dformat=csv \
+        -DlistDependencyIdOnly=true \
+        -DsuppressExcludedDependencies=true \
+        -DlicensesPreferred=ASL2,ASL,EPL1,BSD-2-Clause,BSD-3-Clause,CDDL1.1,CDDL1,CDDL \
+        -DoverridesFile=licensing/overrides.yaml \
+        -DextrasFiles=`cat licensing/extras-files` \
+        -DoutputFile=dependencies-licenses.csv
+
+
+# When Projects Need Custom Licenses
+
+If a JAR includes 3rd party source code (as opposed to binary dependencies), it will typically 
+require a custom LICENSE file.
+
+To support this: 
+
+1. Add the relative path to that project to `projects-with-custom-licenses`,
+
+2. Create the necessary file structure and maven instructions:
+
+* in `src/main/license/` put a `README.md` pointing here
+* in `src/main/license/` put a `source-inclusion.yaml` listing the included 3rd-party projects by an `id:`
+  (you may need to choose an ID; this should be a meaningful name, e.g. `typeahead.js` or `Swagger UI`)
+* in `src/main/license/files` put the relevant non-LICENSE license files you want included (e.g. NOTICE)
+* in `src/test/license/files` put the standard files *including* LICENSE to include in the test JAR
+  (NB: these scripts don't generate custom licenses for test JARs, as so far that has not been needed)
+* in `pom.xml` add instructions to include `src/{main,test}/license/files` in the main and test JARs
+
+You can follow the pattern done for `cli` and `jsgui`.
+
+3. In `licensing/overrides.yaml` in this directory, add the metadata for the included projects.
+
+4. In `licensing/licenses/<your_project>/` include the relevant licenses for any included 3rd-party projects;
+   look in `licensing/licenses/binary` for samples.
+
+5. Run `make-all-licenses.sh` to auto-generate required config files and license copies,
+   and to generate the LICENSE for your project.
+
+Confirm that a LICENSE file for your project was generated, and that it is present in the JAR,
+and then open a pull-request, and confirm the changes there are appropriate.
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/extras-files
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/extras-files b/brooklyn-dist/dist/licensing/extras-files
new file mode 100644
index 0000000..bb4a3b3
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/extras-files
@@ -0,0 +1 @@
+../jsgui/src/main/license/source-inclusions.yaml:../cli/src/main/license/source-inclusions.yaml

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/binary/ASL2
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/ASL2 b/brooklyn-dist/dist/licensing/licenses/binary/ASL2
new file mode 100644
index 0000000..eccbc6a
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/binary/ASL2
@@ -0,0 +1,177 @@
+Apache License, Version 2.0
+
+  Apache License
+  Version 2.0, January 2004
+  http://www.apache.org/licenses/
+  
+  TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+  
+  1. Definitions.
+  
+  "License" shall mean the terms and conditions for use, reproduction,
+  and distribution as defined by Sections 1 through 9 of this document.
+  
+  "Licensor" shall mean the copyright owner or entity authorized by
+  the copyright owner that is granting the License.
+  
+  "Legal Entity" shall mean the union of the acting entity and all
+  other entities that control, are controlled by, or are under common
+  control with that entity. For the purposes of this definition,
+  "control" means (i) the power, direct or indirect, to cause the
+  direction or management of such entity, whether by contract or
+  otherwise, or (ii) ownership of fifty percent (50%) or more of the
+  outstanding shares, or (iii) beneficial ownership of such entity.
+  
+  "You" (or "Your") shall mean an individual or Legal Entity
+  exercising permissions granted by this License.
+  
+  "Source" form shall mean the preferred form for making modifications,
+  including but not limited to software source code, documentation
+  source, and configuration files.
+  
+  "Object" form shall mean any form resulting from mechanical
+  transformation or translation of a Source form, including but
+  not limited to compiled object code, generated documentation,
+  and conversions to other media types.
+  
+  "Work" shall mean the work of authorship, whether in Source or
+  Object form, made available under the License, as indicated by a
+  copyright notice that is included in or attached to the work
+  (an example is provided in the Appendix below).
+  
+  "Derivative Works" shall mean any work, whether in Source or Object
+  form, that is based on (or derived from) the Work and for which the
+  editorial revisions, annotations, elaborations, or other modifications
+  represent, as a whole, an original work of authorship. For the purposes
+  of this License, Derivative Works shall not include works that remain
+  separable from, or merely link (or bind by name) to the interfaces of,
+  the Work and Derivative Works thereof.
+  
+  "Contribution" shall mean any work of authorship, including
+  the original version of the Work and any modifications or additions
+  to that Work or Derivative Works thereof, that is intentionally
+  submitted to Licensor for inclusion in the Work by the copyright owner
+  or by an individual or Legal Entity authorized to submit on behalf of
+  the copyright owner. For the purposes of this definition, "submitted"
+  means any form of electronic, verbal, or written communication sent
+  to the Licensor or its representatives, including but not limited to
+  communication on electronic mailing lists, source code control systems,
+  and issue tracking systems that are managed by, or on behalf of, the
+  Licensor for the purpose of discussing and improving the Work, but
+  excluding communication that is conspicuously marked or otherwise
+  designated in writing by the copyright owner as "Not a Contribution."
+  
+  "Contributor" shall mean Licensor and any individual or Legal Entity
+  on behalf of whom a Contribution has been received by Licensor and
+  subsequently incorporated within the Work.
+  
+  2. Grant of Copyright License. Subject to the terms and conditions of
+  this License, each Contributor hereby grants to You a perpetual,
+  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+  copyright license to reproduce, prepare Derivative Works of,
+  publicly display, publicly perform, sublicense, and distribute the
+  Work and such Derivative Works in Source or Object form.
+  
+  3. Grant of Patent License. Subject to the terms and conditions of
+  this License, each Contributor hereby grants to You a perpetual,
+  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+  (except as stated in this section) patent license to make, have made,
+  use, offer to sell, sell, import, and otherwise transfer the Work,
+  where such license applies only to those patent claims licensable
+  by such Contributor that are necessarily infringed by their
+  Contribution(s) alone or by combination of their Contribution(s)
+  with the Work to which such Contribution(s) was submitted. If You
+  institute patent litigation against any entity (including a
+  cross-claim or counterclaim in a lawsuit) alleging that the Work
+  or a Contribution incorporated within the Work constitutes direct
+  or contributory patent infringement, then any patent licenses
+  granted to You under this License for that Work shall terminate
+  as of the date such litigation is filed.
+  
+  4. Redistribution. You may reproduce and distribute copies of the
+  Work or Derivative Works thereof in any medium, with or without
+  modifications, and in Source or Object form, provided that You
+  meet the following conditions:
+  
+  (a) You must give any other recipients of the Work or
+  Derivative Works a copy of this License; and
+  
+  (b) You must cause any modified files to carry prominent notices
+  stating that You changed the files; and
+  
+  (c) You must retain, in the Source form of any Derivative Works
+  that You distribute, all copyright, patent, trademark, and
+  attribution notices from the Source form of the Work,
+  excluding those notices that do not pertain to any part of
+  the Derivative Works; and
+  
+  (d) If the Work includes a "NOTICE" text file as part of its
+  distribution, then any Derivative Works that You distribute must
+  include a readable copy of the attribution notices contained
+  within such NOTICE file, excluding those notices that do not
+  pertain to any part of the Derivative Works, in at least one
+  of the following places: within a NOTICE text file distributed
+  as part of the Derivative Works; within the Source form or
+  documentation, if provided along with the Derivative Works; or,
+  within a display generated by the Derivative Works, if and
+  wherever such third-party notices normally appear. The contents
+  of the NOTICE file are for informational purposes only and
+  do not modify the License. You may add Your own attribution
+  notices within Derivative Works that You distribute, alongside
+  or as an addendum to the NOTICE text from the Work, provided
+  that such additional attribution notices cannot be construed
+  as modifying the License.
+  
+  You may add Your own copyright statement to Your modifications and
+  may provide additional or different license terms and conditions
+  for use, reproduction, or distribution of Your modifications, or
+  for any such Derivative Works as a whole, provided Your use,
+  reproduction, and distribution of the Work otherwise complies with
+  the conditions stated in this License.
+  
+  5. Submission of Contributions. Unless You explicitly state otherwise,
+  any Contribution intentionally submitted for inclusion in the Work
+  by You to the Licensor shall be under the terms and conditions of
+  this License, without any additional terms or conditions.
+  Notwithstanding the above, nothing herein shall supersede or modify
+  the terms of any separate license agreement you may have executed
+  with Licensor regarding such Contributions.
+  
+  6. Trademarks. This License does not grant permission to use the trade
+  names, trademarks, service marks, or product names of the Licensor,
+  except as required for reasonable and customary use in describing the
+  origin of the Work and reproducing the content of the NOTICE file.
+  
+  7. Disclaimer of Warranty. Unless required by applicable law or
+  agreed to in writing, Licensor provides the Work (and each
+  Contributor provides its Contributions) on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+  implied, including, without limitation, any warranties or conditions
+  of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
+  PARTICULAR PURPOSE. You are solely responsible for determining the
+  appropriateness of using or redistributing the Work and assume any
+  risks associated with Your exercise of permissions under this License.
+  
+  8. Limitation of Liability. In no event and under no legal theory,
+  whether in tort (including negligence), contract, or otherwise,
+  unless required by applicable law (such as deliberate and grossly
+  negligent acts) or agreed to in writing, shall any Contributor be
+  liable to You for damages, including any direct, indirect, special,
+  incidental, or consequential damages of any character arising as a
+  result of this License or out of the use or inability to use the
+  Work (including but not limited to damages for loss of goodwill,
+  work stoppage, computer failure or malfunction, or any and all
+  other commercial damages or losses), even if such Contributor
+  has been advised of the possibility of such damages.
+  
+  9. Accepting Warranty or Additional Liability. While redistributing
+  the Work or Derivative Works thereof, You may choose to offer,
+  and charge a fee for, acceptance of support, warranty, indemnity,
+  or other liability obligations and/or rights consistent with this
+  License. However, in accepting such obligations, You may act only
+  on Your own behalf and on Your sole responsibility, not on behalf
+  of any other Contributor, and only if You agree to indemnify,
+  defend, and hold each Contributor harmless for any liability
+  incurred by, or claims asserted against, such Contributor by reason
+  of your accepting any such warranty or additional liability.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/binary/BSD-2-Clause
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/BSD-2-Clause b/brooklyn-dist/dist/licensing/licenses/binary/BSD-2-Clause
new file mode 100644
index 0000000..832c10e
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/binary/BSD-2-Clause
@@ -0,0 +1,23 @@
+The BSD 2-Clause License
+
+  Redistribution and use in source and binary forms, with or without
+  modification, are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, this
+  list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice,
+  this list of conditions and the following disclaimer in the documentation
+  and/or other materials provided with the distribution.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
+  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
+  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
+  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
+  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
+  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
+  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
+  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/binary/BSD-3-Clause
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/BSD-3-Clause b/brooklyn-dist/dist/licensing/licenses/binary/BSD-3-Clause
new file mode 100644
index 0000000..be2692c
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/binary/BSD-3-Clause
@@ -0,0 +1,27 @@
+The BSD 3-Clause License ("New BSD")
+
+  Redistribution and use in source and binary forms, with or without modification,
+  are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, 
+  this list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice, 
+  this list of conditions and the following disclaimer in the documentation 
+  and/or other materials provided with the distribution.
+  
+  3. Neither the name of the copyright holder nor the names of its contributors 
+  may be used to endorse or promote products derived from this software without 
+  specific prior written permission.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
+  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
+  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
+  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
+  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
+  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
+  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
+  POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/binary/CDDL1
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/CDDL1 b/brooklyn-dist/dist/licensing/licenses/binary/CDDL1
new file mode 100644
index 0000000..611d916
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/binary/CDDL1
@@ -0,0 +1,381 @@
+COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.0
+
+  1. Definitions.
+  
+  1.1. "Contributor" means each individual or entity that
+  creates or contributes to the creation of Modifications.
+  
+  1.2. "Contributor Version" means the combination of the
+  Original Software, prior Modifications used by a
+  Contributor (if any), and the Modifications made by that
+  particular Contributor.
+  
+  1.3. "Covered Software" means (a) the Original Software, or
+  (b) Modifications, or (c) the combination of files
+  containing Original Software with files containing
+  Modifications, in each case including portions thereof.
+  
+  1.4. "Executable" means the Covered Software in any form
+  other than Source Code. 
+  
+  1.5. "Initial Developer" means the individual or entity
+  that first makes Original Software available under this
+  License. 
+  
+  1.6. "Larger Work" means a work which combines Covered
+  Software or portions thereof with code not governed by the
+  terms of this License.
+  
+  1.7. "License" means this document.
+  
+  1.8. "Licensable" means having the right to grant, to the
+  maximum extent possible, whether at the time of the initial
+  grant or subsequently acquired, any and all of the rights
+  conveyed herein.
+  
+  1.9. "Modifications" means the Source Code and Executable
+  form of any of the following: 
+  
+  A. Any file that results from an addition to,
+  deletion from or modification of the contents of a
+  file containing Original Software or previous
+  Modifications; 
+  
+  B. Any new file that contains any part of the
+  Original Software or previous Modification; or 
+  
+  C. Any new file that is contributed or otherwise made
+  available under the terms of this License.
+  
+  1.10. "Original Software" means the Source Code and
+  Executable form of computer software code that is
+  originally released under this License. 
+  
+  1.11. "Patent Claims" means any patent claim(s), now owned
+  or hereafter acquired, including without limitation,
+  method, process, and apparatus claims, in any patent
+  Licensable by grantor. 
+  
+  1.12. "Source Code" means (a) the common form of computer
+  software code in which modifications are made and (b)
+  associated documentation included in or with such code.
+  
+  1.13. "You" (or "Your") means an individual or a legal
+  entity exercising rights under, and complying with all of
+  the terms of, this License. For legal entities, "You"
+  includes any entity which controls, is controlled by, or is
+  under common control with You. For purposes of this
+  definition, "control" means (a) the power, direct or
+  indirect, to cause the direction or management of such
+  entity, whether by contract or otherwise, or (b) ownership
+  of more than fifty percent (50%) of the outstanding shares
+  or beneficial ownership of such entity.
+  
+  2. License Grants. 
+  
+  2.1. The Initial Developer Grant.
+  
+  Conditioned upon Your compliance with Section 3.1 below and
+  subject to third party intellectual property claims, the
+  Initial Developer hereby grants You a world-wide,
+  royalty-free, non-exclusive license: 
+  
+  (a) under intellectual property rights (other than
+  patent or trademark) Licensable by Initial Developer,
+  to use, reproduce, modify, display, perform,
+  sublicense and distribute the Original Software (or
+  portions thereof), with or without Modifications,
+  and/or as part of a Larger Work; and 
+  
+  (b) under Patent Claims infringed by the making,
+  using or selling of Original Software, to make, have
+  made, use, practice, sell, and offer for sale, and/or
+  otherwise dispose of the Original Software (or
+  portions thereof). 
+  
+  (c) The licenses granted in Sections 2.1(a) and (b)
+  are effective on the date Initial Developer first
+  distributes or otherwise makes the Original Software
+  available to a third party under the terms of this
+  License. 
+  
+  (d) Notwithstanding Section 2.1(b) above, no patent
+  license is granted: (1) for code that You delete from
+  the Original Software, or (2) for infringements
+  caused by: (i) the modification of the Original
+  Software, or (ii) the combination of the Original
+  Software with other software or devices. 
+  
+  2.2. Contributor Grant.
+  
+  Conditioned upon Your compliance with Section 3.1 below and
+  subject to third party intellectual property claims, each
+  Contributor hereby grants You a world-wide, royalty-free,
+  non-exclusive license:
+  
+  (a) under intellectual property rights (other than
+  patent or trademark) Licensable by Contributor to
+  use, reproduce, modify, display, perform, sublicense
+  and distribute the Modifications created by such
+  Contributor (or portions thereof), either on an
+  unmodified basis, with other Modifications, as
+  Covered Software and/or as part of a Larger Work; and
+  
+  (b) under Patent Claims infringed by the making,
+  using, or selling of Modifications made by that
+  Contributor either alone and/or in combination with
+  its Contributor Version (or portions of such
+  combination), to make, use, sell, offer for sale,
+  have made, and/or otherwise dispose of: (1)
+  Modifications made by that Contributor (or portions
+  thereof); and (2) the combination of Modifications
+  made by that Contributor with its Contributor Version
+  (or portions of such combination). 
+  
+  (c) The licenses granted in Sections 2.2(a) and
+  2.2(b) are effective on the date Contributor first
+  distributes or otherwise makes the Modifications
+  available to a third party. 
+  
+  (d) Notwithstanding Section 2.2(b) above, no patent
+  license is granted: (1) for any code that Contributor
+  has deleted from the Contributor Version; (2) for
+  infringements caused by: (i) third party
+  modifications of Contributor Version, or (ii) the
+  combination of Modifications made by that Contributor
+  with other software (except as part of the
+  Contributor Version) or other devices; or (3) under
+  Patent Claims infringed by Covered Software in the
+  absence of Modifications made by that Contributor. 
+  
+  3. Distribution Obligations.
+  
+  3.1. Availability of Source Code.
+  
+  Any Covered Software that You distribute or otherwise make
+  available in Executable form must also be made available in
+  Source Code form and that Source Code form must be
+  distributed only under the terms of this License. You must
+  include a copy of this License with every copy of the
+  Source Code form of the Covered Software You distribute or
+  otherwise make available. You must inform recipients of any
+  such Covered Software in Executable form as to how they can
+  obtain such Covered Software in Source Code form in a
+  reasonable manner on or through a medium customarily used
+  for software exchange.
+  
+  3.2. Modifications.
+  
+  The Modifications that You create or to which You
+  contribute are governed by the terms of this License. You
+  represent that You believe Your Modifications are Your
+  original creation(s) and/or You have sufficient rights to
+  grant the rights conveyed by this License.
+  
+  3.3. Required Notices.
+  
+  You must include a notice in each of Your Modifications
+  that identifies You as the Contributor of the Modification.
+  You may not remove or alter any copyright, patent or
+  trademark notices contained within the Covered Software, or
+  any notices of licensing or any descriptive text giving
+  attribution to any Contributor or the Initial Developer.
+  
+  3.4. Application of Additional Terms.
+  
+  You may not offer or impose any terms on any Covered
+  Software in Source Code form that alters or restricts the
+  applicable version of this License or the recipients"
+  rights hereunder. You may choose to offer, and to charge a
+  fee for, warranty, support, indemnity or liability
+  obligations to one or more recipients of Covered Software.
+  However, you may do so only on Your own behalf, and not on
+  behalf of the Initial Developer or any Contributor. You
+  must make it absolutely clear that any such warranty,
+  support, indemnity or liability obligation is offered by
+  You alone, and You hereby agree to indemnify the Initial
+  Developer and every Contributor for any liability incurred
+  by the Initial Developer or such Contributor as a result of
+  warranty, support, indemnity or liability terms You offer.
+      
+  3.5. Distribution of Executable Versions.
+  
+  You may distribute the Executable form of the Covered
+  Software under the terms of this License or under the terms
+  of a license of Your choice, which may contain terms
+  different from this License, provided that You are in
+  compliance with the terms of this License and that the
+  license for the Executable form does not attempt to limit
+  or alter the recipient"s rights in the Source Code form
+  from the rights set forth in this License. If You
+  distribute the Covered Software in Executable form under a
+  different license, You must make it absolutely clear that
+  any terms which differ from this License are offered by You
+  alone, not by the Initial Developer or Contributor. You
+  hereby agree to indemnify the Initial Developer and every
+  Contributor for any liability incurred by the Initial
+  Developer or such Contributor as a result of any such terms
+  You offer.
+  
+  3.6. Larger Works.
+  
+  You may create a Larger Work by combining Covered Software
+  with other code not governed by the terms of this License
+  and distribute the Larger Work as a single product. In such
+  a case, You must make sure the requirements of this License
+  are fulfilled for the Covered Software. 
+  
+  4. Versions of the License. 
+  
+  4.1. New Versions.
+  
+  Sun Microsystems, Inc. is the initial license steward and
+  may publish revised and/or new versions of this License
+  from time to time. Each version will be given a
+  distinguishing version number. Except as provided in
+  Section 4.3, no one other than the license steward has the
+  right to modify this License. 
+  
+  4.2. Effect of New Versions.
+  
+  You may always continue to use, distribute or otherwise
+  make the Covered Software available under the terms of the
+  version of the License under which You originally received
+  the Covered Software. If the Initial Developer includes a
+  notice in the Original Software prohibiting it from being
+  distributed or otherwise made available under any
+  subsequent version of the License, You must distribute and
+  make the Covered Software available under the terms of the
+  version of the License under which You originally received
+  the Covered Software. Otherwise, You may also choose to
+  use, distribute or otherwise make the Covered Software
+  available under the terms of any subsequent version of the
+  License published by the license steward. 
+  
+  4.3. Modified Versions.
+  
+  When You are an Initial Developer and You want to create a
+  new license for Your Original Software, You may create and
+  use a modified version of this License if You: (a) rename
+  the license and remove any references to the name of the
+  license steward (except to note that the license differs
+  from this License); and (b) otherwise make it clear that
+  the license contains terms which differ from this License.
+  
+  5. DISCLAIMER OF WARRANTY.
+  
+  COVERED SOFTWARE IS PROVIDED UNDER THIS LICENSE ON AN "AS IS"
+  BASIS, WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED,
+  INCLUDING, WITHOUT LIMITATION, WARRANTIES THAT THE COVERED
+  SOFTWARE IS FREE OF DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR
+  PURPOSE OR NON-INFRINGING. THE ENTIRE RISK AS TO THE QUALITY AND
+  PERFORMANCE OF THE COVERED SOFTWARE IS WITH YOU. SHOULD ANY
+  COVERED SOFTWARE PROVE DEFECTIVE IN ANY RESPECT, YOU (NOT THE
+  INITIAL DEVELOPER OR ANY OTHER CONTRIBUTOR) ASSUME THE COST OF
+  ANY NECESSARY SERVICING, REPAIR OR CORRECTION. THIS DISCLAIMER OF
+  WARRANTY CONSTITUTES AN ESSENTIAL PART OF THIS LICENSE. NO USE OF
+  ANY COVERED SOFTWARE IS AUTHORIZED HEREUNDER EXCEPT UNDER THIS
+  DISCLAIMER. 
+  
+  6. TERMINATION. 
+  
+  6.1. This License and the rights granted hereunder will
+  terminate automatically if You fail to comply with terms
+  herein and fail to cure such breach within 30 days of
+  becoming aware of the breach. Provisions which, by their
+  nature, must remain in effect beyond the termination of
+  this License shall survive.
+  
+  6.2. If You assert a patent infringement claim (excluding
+  declaratory judgment actions) against Initial Developer or
+  a Contributor (the Initial Developer or Contributor against
+  whom You assert such claim is referred to as "Participant")
+  alleging that the Participant Software (meaning the
+  Contributor Version where the Participant is a Contributor
+  or the Original Software where the Participant is the
+  Initial Developer) directly or indirectly infringes any
+  patent, then any and all rights granted directly or
+  indirectly to You by such Participant, the Initial
+  Developer (if the Initial Developer is not the Participant)
+  and all Contributors under Sections 2.1 and/or 2.2 of this
+  License shall, upon 60 days notice from Participant
+  terminate prospectively and automatically at the expiration
+  of such 60 day notice period, unless if within such 60 day
+  period You withdraw Your claim with respect to the
+  Participant Software against such Participant either
+  unilaterally or pursuant to a written agreement with
+  Participant.
+  
+  6.3. In the event of termination under Sections 6.1 or 6.2
+  above, all end user licenses that have been validly granted
+  by You or any distributor hereunder prior to termination
+  (excluding licenses granted to You by any distributor)
+  shall survive termination.
+  
+  7. LIMITATION OF LIABILITY.
+  
+  UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT
+  (INCLUDING NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE
+  INITIAL DEVELOPER, ANY OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF
+  COVERED SOFTWARE, OR ANY SUPPLIER OF ANY OF SUCH PARTIES, BE
+  LIABLE TO ANY PERSON FOR ANY INDIRECT, SPECIAL, INCIDENTAL, OR
+  CONSEQUENTIAL DAMAGES OF ANY CHARACTER INCLUDING, WITHOUT
+  LIMITATION, DAMAGES FOR LOST PROFITS, LOSS OF GOODWILL, WORK
+  STOPPAGE, COMPUTER FAILURE OR MALFUNCTION, OR ANY AND ALL OTHER
+  COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH PARTY SHALL HAVE BEEN
+  INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS LIMITATION OF
+  LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL
+  INJURY RESULTING FROM SUCH PARTY"S NEGLIGENCE TO THE EXTENT
+  APPLICABLE LAW PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO
+  NOT ALLOW THE EXCLUSION OR LIMITATION OF INCIDENTAL OR
+  CONSEQUENTIAL DAMAGES, SO THIS EXCLUSION AND LIMITATION MAY NOT
+  APPLY TO YOU.
+  
+  8. U.S. GOVERNMENT END USERS.
+  
+  The Covered Software is a "commercial item," as that term is
+  defined in 48 C.F.R. 2.101 (Oct. 1995), consisting of "commercial
+  computer software" (as that term is defined at 48 C.F.R. "
+  252.227-7014(a)(1)) and "commercial computer software
+  documentation" as such terms are used in 48 C.F.R. 12.212 (Sept.
+  1995). Consistent with 48 C.F.R. 12.212 and 48 C.F.R. 227.7202-1
+  through 227.7202-4 (June 1995), all U.S. Government End Users
+  acquire Covered Software with only those rights set forth herein.
+  This U.S. Government Rights clause is in lieu of, and supersedes,
+  any other FAR, DFAR, or other clause or provision that addresses
+  Government rights in computer software under this License.
+  
+  9. MISCELLANEOUS.
+  
+  This License represents the complete agreement concerning subject
+  matter hereof. If any provision of this License is held to be
+  unenforceable, such provision shall be reformed only to the
+  extent necessary to make it enforceable. This License shall be
+  governed by the law of the jurisdiction specified in a notice
+  contained within the Original Software (except to the extent
+  applicable law, if any, provides otherwise), excluding such
+  jurisdiction"s conflict-of-law provisions. Any litigation
+  relating to this License shall be subject to the jurisdiction of
+  the courts located in the jurisdiction and venue specified in a
+  notice contained within the Original Software, with the losing
+  party responsible for costs, including, without limitation, court
+  costs and reasonable attorneys" fees and expenses. The
+  application of the United Nations Convention on Contracts for the
+  International Sale of Goods is expressly excluded. Any law or
+  regulation which provides that the language of a contract shall
+  be construed against the drafter shall not apply to this License.
+  You agree that You alone are responsible for compliance with the
+  United States export administration regulations (and the export
+  control laws and regulation of any other countries) when You use,
+  distribute or otherwise make available any Covered Software.
+  
+  10. RESPONSIBILITY FOR CLAIMS.
+  
+  As between Initial Developer and the Contributors, each party is
+  responsible for claims and damages arising, directly or
+  indirectly, out of its utilization of rights under this License
+  and You agree to work with Initial Developer and Contributors to
+  distribute such responsibility on an equitable basis. Nothing
+  herein is intended or shall be deemed to constitute any admission
+  of liability.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/binary/CDDL1.1
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/CDDL1.1 b/brooklyn-dist/dist/licensing/licenses/binary/CDDL1.1
new file mode 100644
index 0000000..def9b35
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/binary/CDDL1.1
@@ -0,0 +1,304 @@
+COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.1
+
+  1. Definitions.
+  
+  1.1. “Contributor” means each individual or entity that creates or contributes
+  to the creation of Modifications.
+  
+  1.2. “Contributor Version” means the combination of the Original Software,
+  prior Modifications used by a Contributor (if any), and the Modifications made
+  by that particular Contributor.
+  
+  1.3. “Covered Software” means (a) the Original Software, or (b) Modifications,
+  or (c) the combination of files containing Original Software with files
+  containing Modifications, in each case including portions thereof.
+  
+  1.4. “Executable” means the Covered Software in any form other than Source
+  Code.
+  
+  1.5. “Initial Developer” means the individual or entity that first makes
+  Original Software available under this License.
+  
+  1.6. “Larger Work” means a work which combines Covered Software or portions
+  thereof with code not governed by the terms of this License.
+  
+  1.7. “License” means this document.
+  
+  1.8. “Licensable” means having the right to grant, to the maximum extent
+  possible, whether at the time of the initial grant or subsequently acquired,
+  any and all of the rights conveyed herein.
+  
+  1.9. “Modifications” means the Source Code and Executable form of any of the
+  following:
+  
+  A. Any file that results from an addition to, deletion from or modification of
+  the contents of a file containing Original Software or previous Modifications;
+  
+  B. Any new file that contains any part of the Original Software or previous
+  Modification; or
+  
+  C. Any new file that is contributed or otherwise made available under the terms
+  of this License.
+  
+  1.10. “Original Software” means the Source Code and Executable form of computer
+  software code that is originally released under this License.
+  
+  1.11. “Patent Claims” means any patent claim(s), now owned or hereafter
+  acquired, including without limitation, method, process, and apparatus claims,
+  in any patent Licensable by grantor.
+  
+  1.12. “Source Code” means (a) the common form of computer software code in
+  which modifications are made and (b) associated documentation included in or
+  with such code.
+  
+  1.13. “You” (or “Your”) means an individual or a legal entity exercising rights
+  under, and complying with all of the terms of, this License. For legal
+  entities, “You” includes any entity which controls, is controlled by, or is
+  under common control with You. For purposes of this definition, “control” means
+  (a) the power, direct or indirect, to cause the direction or management of such
+  entity, whether by contract or otherwise, or (b) ownership of more than fifty
+  percent (50%) of the outstanding shares or beneficial ownership of such entity.
+  
+  2. License Grants.
+  
+  2.1. The Initial Developer Grant.  Conditioned upon Your compliance with
+  Section 3.1 below and subject to third party intellectual property claims, the
+  Initial Developer hereby grants You a world-wide, royalty-free, non-exclusive
+  license:
+  
+  (a) under intellectual property rights (other than patent or trademark)
+  Licensable by Initial Developer, to use, reproduce, modify, display, perform,
+  sublicense and distribute the Original Software (or portions thereof), with or
+  without Modifications, and/or as part of a Larger Work; and
+  
+  (b) under Patent Claims infringed by the making, using or selling of Original
+  Software, to make, have made, use, practice, sell, and offer for sale, and/or
+  otherwise dispose of the Original Software (or portions thereof).
+  
+  (c) The licenses granted in Sections 2.1(a) and (b) are effective on the date
+  Initial Developer first distributes or otherwise makes the Original Software
+  available to a third party under the terms of this License.
+  
+  (d) Notwithstanding Section 2.1(b) above, no patent license is granted: (1) for
+  code that You delete from the Original Software, or (2) for infringements
+  caused by: (i) the modification of the Original Software, or (ii) the
+  combination of the Original Software with other software or devices.
+  
+  2.2. Contributor Grant.  Conditioned upon Your compliance with Section 3.1
+  below and subject to third party intellectual property claims, each Contributor
+  hereby grants You a world-wide, royalty-free, non-exclusive license:
+  
+  (a) under intellectual property rights (other than patent or trademark)
+  Licensable by Contributor to use, reproduce, modify, display, perform,
+  sublicense and distribute the Modifications created by such Contributor (or
+  portions thereof), either on an unmodified basis, with other Modifications, as
+  Covered Software and/or as part of a Larger Work; and
+  
+  (b) under Patent Claims infringed by the making, using, or selling of
+  Modifications made by that Contributor either alone and/or in combination with
+  its Contributor Version (or portions of such combination), to make, use, sell,
+  offer for sale, have made, and/or otherwise dispose of: (1) Modifications made
+  by that Contributor (or portions thereof); and (2) the combination of
+  Modifications made by that Contributor with its Contributor Version (or
+  portions of such combination).
+  
+  (c) The licenses granted in Sections 2.2(a) and 2.2(b) are effective on the
+  date Contributor first distributes or otherwise makes the Modifications
+  available to a third party.
+  
+  (d) Notwithstanding Section 2.2(b) above, no patent license is granted: (1) for
+  any code that Contributor has deleted from the Contributor Version; (2) for
+  infringements caused by: (i) third party modifications of Contributor Version,
+  or (ii) the combination of Modifications made by that Contributor with other
+  software (except as part of the Contributor Version) or other devices; or (3)
+  under Patent Claims infringed by Covered Software in the absence of
+  Modifications made by that Contributor.
+  
+  3. Distribution Obligations.
+  
+  3.1. Availability of Source Code.  Any Covered Software that You distribute or
+  otherwise make available in Executable form must also be made available in
+  Source Code form and that Source Code form must be distributed only under the
+  terms of this License. You must include a copy of this License with every copy
+  of the Source Code form of the Covered Software You distribute or otherwise
+  make available. You must inform recipients of any such Covered Software in
+  Executable form as to how they can obtain such Covered Software in Source Code
+  form in a reasonable manner on or through a medium customarily used for
+  software exchange.
+  
+  3.2. Modifications.  The Modifications that You create or to which You
+  contribute are governed by the terms of this License. You represent that You
+  believe Your Modifications are Your original creation(s) and/or You have
+  sufficient rights to grant the rights conveyed by this License.
+  
+  3.3. Required Notices.  You must include a notice in each of Your Modifications
+  that identifies You as the Contributor of the Modification. You may not remove
+  or alter any copyright, patent or trademark notices contained within the
+  Covered Software, or any notices of licensing or any descriptive text giving
+  attribution to any Contributor or the Initial Developer.
+  
+  3.4. Application of Additional Terms.  You may not offer or impose any terms on
+  any Covered Software in Source Code form that alters or restricts the
+  applicable version of this License or the recipients' rights hereunder. You may
+  choose to offer, and to charge a fee for, warranty, support, indemnity or
+  liability obligations to one or more recipients of Covered Software. However,
+  you may do so only on Your own behalf, and not on behalf of the Initial
+  Developer or any Contributor. You must make it absolutely clear that any such
+  warranty, support, indemnity or liability obligation is offered by You alone,
+  and You hereby agree to indemnify the Initial Developer and every Contributor
+  for any liability incurred by the Initial Developer or such Contributor as a
+  result of warranty, support, indemnity or liability terms You offer.
+  
+  3.5. Distribution of Executable Versions.  You may distribute the Executable
+  form of the Covered Software under the terms of this License or under the terms
+  of a license of Your choice, which may contain terms different from this
+  License, provided that You are in compliance with the terms of this License and
+  that the license for the Executable form does not attempt to limit or alter the
+  recipient's rights in the Source Code form from the rights set forth in this
+  License. If You distribute the Covered Software in Executable form under a
+  different license, You must make it absolutely clear that any terms which
+  differ from this License are offered by You alone, not by the Initial Developer
+  or Contributor. You hereby agree to indemnify the Initial Developer and every
+  Contributor for any liability incurred by the Initial Developer or such
+  Contributor as a result of any such terms You offer.
+  
+  3.6. Larger Works.  You may create a Larger Work by combining Covered Software
+  with other code not governed by the terms of this License and distribute the
+  Larger Work as a single product. In such a case, You must make sure the
+  requirements of this License are fulfilled for the Covered Software.
+  
+  4. Versions of the License.
+  
+  4.1. New Versions.  Oracle is the initial license steward and may publish
+  revised and/or new versions of this License from time to time. Each version
+  will be given a distinguishing version number. Except as provided in Section
+  4.3, no one other than the license steward has the right to modify this
+  License.
+  
+  4.2. Effect of New Versions.  You may always continue to use, distribute or
+  otherwise make the Covered Software available under the terms of the version of
+  the License under which You originally received the Covered Software. If the
+  Initial Developer includes a notice in the Original Software prohibiting it
+  from being distributed or otherwise made available under any subsequent version
+  of the License, You must distribute and make the Covered Software available
+  under the terms of the version of the License under which You originally
+  received the Covered Software. Otherwise, You may also choose to use,
+  distribute or otherwise make the Covered Software available under the terms of
+  any subsequent version of the License published by the license steward.
+  
+  4.3. Modified Versions.  When You are an Initial Developer and You want to
+  create a new license for Your Original Software, You may create and use a
+  modified version of this License if You: (a) rename the license and remove any
+  references to the name of the license steward (except to note that the license
+  differs from this License); and (b) otherwise make it clear that the license
+  contains terms which differ from this License.
+  
+  5. DISCLAIMER OF WARRANTY.  COVERED SOFTWARE IS PROVIDED UNDER THIS LICENSE ON
+  AN “AS IS” BASIS, WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED,
+  INCLUDING, WITHOUT LIMITATION, WARRANTIES THAT THE COVERED SOFTWARE IS FREE OF
+  DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR PURPOSE OR NON-INFRINGING. THE
+  ENTIRE RISK AS TO THE QUALITY AND PERFORMANCE OF THE COVERED SOFTWARE IS WITH
+  YOU. SHOULD ANY COVERED SOFTWARE PROVE DEFECTIVE IN ANY RESPECT, YOU (NOT THE
+  INITIAL DEVELOPER OR ANY OTHER CONTRIBUTOR) ASSUME THE COST OF ANY NECESSARY
+  SERVICING, REPAIR OR CORRECTION. THIS DISCLAIMER OF WARRANTY CONSTITUTES AN
+  ESSENTIAL PART OF THIS LICENSE. NO USE OF ANY COVERED SOFTWARE IS AUTHORIZED
+  HEREUNDER EXCEPT UNDER THIS DISCLAIMER.
+  
+  6. TERMINATION.
+  
+  6.1. This License and the rights granted hereunder will terminate automatically
+  if You fail to comply with terms herein and fail to cure such breach within 30
+  days of becoming aware of the breach. Provisions which, by their nature, must
+  remain in effect beyond the termination of this License shall survive.
+  
+  6.2. If You assert a patent infringement claim (excluding declaratory judgment
+  actions) against Initial Developer or a Contributor (the Initial Developer or
+  Contributor against whom You assert such claim is referred to as “Participant”)
+  alleging that the Participant Software (meaning the Contributor Version where
+  the Participant is a Contributor or the Original Software where the Participant
+  is the Initial Developer) directly or indirectly infringes any patent, then any
+  and all rights granted directly or indirectly to You by such Participant, the
+  Initial Developer (if the Initial Developer is not the Participant) and all
+  Contributors under Sections 2.1 and/or 2.2 of this License shall, upon 60 days
+  notice from Participant terminate prospectively and automatically at the
+  expiration of such 60 day notice period, unless if within such 60 day period
+  You withdraw Your claim with respect to the Participant Software against such
+  Participant either unilaterally or pursuant to a written agreement with
+  Participant.
+  
+  6.3. If You assert a patent infringement claim against Participant alleging
+  that the Participant Software directly or indirectly infringes any patent where
+  such claim is resolved (such as by license or settlement) prior to the
+  initiation of patent infringement litigation, then the reasonable value of the
+  licenses granted by such Participant under Sections 2.1 or 2.2 shall be taken
+  into account in determining the amount or value of any payment or license.
+  
+  6.4. In the event of termination under Sections 6.1 or 6.2 above, all end user
+  licenses that have been validly granted by You or any distributor hereunder
+  prior to termination (excluding licenses granted to You by any distributor)
+  shall survive termination.
+  
+  7. LIMITATION OF LIABILITY.
+  
+  UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT (INCLUDING
+  NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE INITIAL DEVELOPER, ANY
+  OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF COVERED SOFTWARE, OR ANY SUPPLIER OF
+  ANY OF SUCH PARTIES, BE LIABLE TO ANY PERSON FOR ANY INDIRECT, SPECIAL,
+  INCIDENTAL, OR CONSEQUENTIAL DAMAGES OF ANY CHARACTER INCLUDING, WITHOUT
+  LIMITATION, DAMAGES FOR LOSS OF GOODWILL, WORK STOPPAGE, COMPUTER FAILURE OR
+  MALFUNCTION, OR ANY AND ALL OTHER COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH
+  PARTY SHALL HAVE BEEN INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS
+  LIMITATION OF LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL
+  INJURY RESULTING FROM SUCH PARTY'S NEGLIGENCE TO THE EXTENT APPLICABLE LAW
+  PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO NOT ALLOW THE EXCLUSION OR
+  LIMITATION OF INCIDENTAL OR CONSEQUENTIAL DAMAGES, SO THIS EXCLUSION AND
+  LIMITATION MAY NOT APPLY TO YOU.
+  
+  8. U.S. GOVERNMENT END USERS.
+  
+  The Covered Software is a “commercial item,” as that term is defined in 48
+  C.F.R. 2.101 (Oct. 1995), consisting of “commercial computer software” (as that
+  term is defined at 48 C.F.R. § 252.227-7014(a)(1)) and “commercial computer
+  software documentation” as such terms are used in 48 C.F.R. 12.212 (Sept.
+  1995). Consistent with 48 C.F.R. 12.212 and 48 C.F.R. 227.7202-1 through
+  227.7202-4 (June 1995), all U.S. Government End Users acquire Covered Software
+  with only those rights set forth herein. This U.S. Government Rights clause is
+  in lieu of, and supersedes, any other FAR, DFAR, or other clause or provision
+  that addresses Government rights in computer software under this License.
+  
+  9. MISCELLANEOUS.
+  
+  This License represents the complete agreement concerning subject matter
+  hereof. If any provision of this License is held to be unenforceable, such
+  provision shall be reformed only to the extent necessary to make it
+  enforceable. This License shall be governed by the law of the jurisdiction
+  specified in a notice contained within the Original Software (except to the
+  extent applicable law, if any, provides otherwise), excluding such
+  jurisdiction's conflict-of-law provisions. Any litigation relating to this
+  License shall be subject to the jurisdiction of the courts located in the
+  jurisdiction and venue specified in a notice contained within the Original
+  Software, with the losing party responsible for costs, including, without
+  limitation, court costs and reasonable attorneys' fees and expenses. The
+  application of the United Nations Convention on Contracts for the International
+  Sale of Goods is expressly excluded. Any law or regulation which provides that
+  the language of a contract shall be construed against the drafter shall not
+  apply to this License. You agree that You alone are responsible for compliance
+  with the United States export administration regulations (and the export
+  control laws and regulation of any other countries) when You use, distribute or
+  otherwise make available any Covered Software.
+  
+  10. RESPONSIBILITY FOR CLAIMS.
+  
+  As between Initial Developer and the Contributors, each party is responsible
+  for claims and damages arising, directly or indirectly, out of its utilization
+  of rights under this License and You agree to work with Initial Developer and
+  Contributors to distribute such responsibility on an equitable basis. Nothing
+  herein is intended or shall be deemed to constitute any admission of liability.
+  
+  NOTICE PURSUANT TO SECTION 9 OF THE COMMON DEVELOPMENT AND DISTRIBUTION LICENSE
+  (CDDL) The code released under the CDDL shall be governed by the laws of the
+  State of California (excluding conflict-of-law provisions). Any litigation
+  relating to this License shall be subject to the jurisdiction of the Federal
+  Courts of the Northern District of California and the state courts of the State
+  of California, with venue lying in Santa Clara County, California.
+


[49/51] [abbrv] brooklyn-dist git commit: move subdir from incubator up a level as it is promoted to its own repo (first non-incubator commit!)

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/main/resources/META-INF/maven/archetype-metadata.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/main/resources/META-INF/maven/archetype-metadata.xml b/brooklyn-dist/archetypes/quickstart/src/main/resources/META-INF/maven/archetype-metadata.xml
deleted file mode 100644
index 4768945..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/main/resources/META-INF/maven/archetype-metadata.xml
+++ /dev/null
@@ -1,65 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-    
-     http://www.apache.org/licenses/LICENSE-2.0
-    
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-<archetype xmlns="http://maven.apache.org/plugins/maven-archetype-plugin/archetype/1.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-  xsi:schemaLocation="http://maven.apache.org/plugins/maven-archetype-plugin/archetype/1.0.0 http://maven.apache.org/xsd/archetype-1.0.0.xsd">
-
-  <fileSets>
-    <fileSet filtered="true" packaged="true">
-      <directory>src/main/java</directory>
-      <includes>
-        <include>**/*.java</include>
-      </includes>
-    </fileSet>
-    
-    <fileSet filtered="true" packaged="true">
-      <directory>src/test/java</directory>
-      <includes>
-        <include>**/*.java</include>
-      </includes>
-    </fileSet>
-    
-    <!-- we cannot have src/main/resources/** be "packaged" (package dirs prepended) and non-packaged;
-         so we put everything non-packaged here.
-         (also note for src/main/java, the root pom uses google-replacer to drop the "package" directory) -->
-           
-    <fileSet filtered="false" packaged="false">
-      <directory></directory>
-      <includes>
-        <include>**/*.png</include>
-        <include>**/*.sh</include>
-      </includes>
-    </fileSet>
-    <fileSet filtered="true" packaged="false">
-      <directory></directory>
-      <includes>
-        <include>**/*</include>
-        <include>*</include>
-      </includes>
-      <excludes>
-        <exclude>src/main/java/**</exclude> 
-        <exclude>src/test/java/**</exclude> 
-        <exclude>pom.xml</exclude>
-        <exclude>**.png</exclude>
-        <exclude>**.sh</exclude>
-      </excludes>
-    </fileSet>
-  </fileSets>
-
-</archetype>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/.gitignore
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/.gitignore b/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/.gitignore
deleted file mode 100644
index 25d80f5..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/.gitignore
+++ /dev/null
@@ -1 +0,0 @@
-reference

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/archetype.properties
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/archetype.properties b/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/archetype.properties
deleted file mode 100644
index d1f4da4..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/archetype.properties
+++ /dev/null
@@ -1,22 +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.
-#
-groupId=com.acme.sample
-artifactId=brooklyn-sample
-version=0.1.0-SNAPSHOT
-package=com.acme.sample.brooklyn

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/goal.txt
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/goal.txt b/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/goal.txt
deleted file mode 100644
index f7ffc47..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/test/resources/projects/integration-test-1/goal.txt
+++ /dev/null
@@ -1 +0,0 @@
-install
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/.gitignore
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/.gitignore b/brooklyn-dist/dist/licensing/.gitignore
deleted file mode 100644
index 2d17061..0000000
--- a/brooklyn-dist/dist/licensing/.gitignore
+++ /dev/null
@@ -1,2 +0,0 @@
-LICENSE.autogenerated
-notices.autogenerated

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/MAIN_LICENSE_ASL2
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/MAIN_LICENSE_ASL2 b/brooklyn-dist/dist/licensing/MAIN_LICENSE_ASL2
deleted file mode 100644
index 68c771a..0000000
--- a/brooklyn-dist/dist/licensing/MAIN_LICENSE_ASL2
+++ /dev/null
@@ -1,176 +0,0 @@
-
-                                 Apache License
-                           Version 2.0, January 2004
-                        http://www.apache.org/licenses/
-
-   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
-
-   1. Definitions.
-
-      "License" shall mean the terms and conditions for use, reproduction,
-      and distribution as defined by Sections 1 through 9 of this document.
-
-      "Licensor" shall mean the copyright owner or entity authorized by
-      the copyright owner that is granting the License.
-
-      "Legal Entity" shall mean the union of the acting entity and all
-      other entities that control, are controlled by, or are under common
-      control with that entity. For the purposes of this definition,
-      "control" means (i) the power, direct or indirect, to cause the
-      direction or management of such entity, whether by contract or
-      otherwise, or (ii) ownership of fifty percent (50%) or more of the
-      outstanding shares, or (iii) beneficial ownership of such entity.
-
-      "You" (or "Your") shall mean an individual or Legal Entity
-      exercising permissions granted by this License.
-
-      "Source" form shall mean the preferred form for making modifications,
-      including but not limited to software source code, documentation
-      source, and configuration files.
-
-      "Object" form shall mean any form resulting from mechanical
-      transformation or translation of a Source form, including but
-      not limited to compiled object code, generated documentation,
-      and conversions to other media types.
-
-      "Work" shall mean the work of authorship, whether in Source or
-      Object form, made available under the License, as indicated by a
-      copyright notice that is included in or attached to the work
-      (an example is provided in the Appendix below).
-
-      "Derivative Works" shall mean any work, whether in Source or Object
-      form, that is based on (or derived from) the Work and for which the
-      editorial revisions, annotations, elaborations, or other modifications
-      represent, as a whole, an original work of authorship. For the purposes
-      of this License, Derivative Works shall not include works that remain
-      separable from, or merely link (or bind by name) to the interfaces of,
-      the Work and Derivative Works thereof.
-
-      "Contribution" shall mean any work of authorship, including
-      the original version of the Work and any modifications or additions
-      to that Work or Derivative Works thereof, that is intentionally
-      submitted to Licensor for inclusion in the Work by the copyright owner
-      or by an individual or Legal Entity authorized to submit on behalf of
-      the copyright owner. For the purposes of this definition, "submitted"
-      means any form of electronic, verbal, or written communication sent
-      to the Licensor or its representatives, including but not limited to
-      communication on electronic mailing lists, source code control systems,
-      and issue tracking systems that are managed by, or on behalf of, the
-      Licensor for the purpose of discussing and improving the Work, but
-      excluding communication that is conspicuously marked or otherwise
-      designated in writing by the copyright owner as "Not a Contribution."
-
-      "Contributor" shall mean Licensor and any individual or Legal Entity
-      on behalf of whom a Contribution has been received by Licensor and
-      subsequently incorporated within the Work.
-
-   2. Grant of Copyright License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      copyright license to reproduce, prepare Derivative Works of,
-      publicly display, publicly perform, sublicense, and distribute the
-      Work and such Derivative Works in Source or Object form.
-
-   3. Grant of Patent License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      (except as stated in this section) patent license to make, have made,
-      use, offer to sell, sell, import, and otherwise transfer the Work,
-      where such license applies only to those patent claims licensable
-      by such Contributor that are necessarily infringed by their
-      Contribution(s) alone or by combination of their Contribution(s)
-      with the Work to which such Contribution(s) was submitted. If You
-      institute patent litigation against any entity (including a
-      cross-claim or counterclaim in a lawsuit) alleging that the Work
-      or a Contribution incorporated within the Work constitutes direct
-      or contributory patent infringement, then any patent licenses
-      granted to You under this License for that Work shall terminate
-      as of the date such litigation is filed.
-
-   4. Redistribution. You may reproduce and distribute copies of the
-      Work or Derivative Works thereof in any medium, with or without
-      modifications, and in Source or Object form, provided that You
-      meet the following conditions:
-
-      (a) You must give any other recipients of the Work or
-          Derivative Works a copy of this License; and
-
-      (b) You must cause any modified files to carry prominent notices
-          stating that You changed the files; and
-
-      (c) You must retain, in the Source form of any Derivative Works
-          that You distribute, all copyright, patent, trademark, and
-          attribution notices from the Source form of the Work,
-          excluding those notices that do not pertain to any part of
-          the Derivative Works; and
-
-      (d) If the Work includes a "NOTICE" text file as part of its
-          distribution, then any Derivative Works that You distribute must
-          include a readable copy of the attribution notices contained
-          within such NOTICE file, excluding those notices that do not
-          pertain to any part of the Derivative Works, in at least one
-          of the following places: within a NOTICE text file distributed
-          as part of the Derivative Works; within the Source form or
-          documentation, if provided along with the Derivative Works; or,
-          within a display generated by the Derivative Works, if and
-          wherever such third-party notices normally appear. The contents
-          of the NOTICE file are for informational purposes only and
-          do not modify the License. You may add Your own attribution
-          notices within Derivative Works that You distribute, alongside
-          or as an addendum to the NOTICE text from the Work, provided
-          that such additional attribution notices cannot be construed
-          as modifying the License.
-
-      You may add Your own copyright statement to Your modifications and
-      may provide additional or different license terms and conditions
-      for use, reproduction, or distribution of Your modifications, or
-      for any such Derivative Works as a whole, provided Your use,
-      reproduction, and distribution of the Work otherwise complies with
-      the conditions stated in this License.
-
-   5. Submission of Contributions. Unless You explicitly state otherwise,
-      any Contribution intentionally submitted for inclusion in the Work
-      by You to the Licensor shall be under the terms and conditions of
-      this License, without any additional terms or conditions.
-      Notwithstanding the above, nothing herein shall supersede or modify
-      the terms of any separate license agreement you may have executed
-      with Licensor regarding such Contributions.
-
-   6. Trademarks. This License does not grant permission to use the trade
-      names, trademarks, service marks, or product names of the Licensor,
-      except as required for reasonable and customary use in describing the
-      origin of the Work and reproducing the content of the NOTICE file.
-
-   7. Disclaimer of Warranty. Unless required by applicable law or
-      agreed to in writing, Licensor provides the Work (and each
-      Contributor provides its Contributions) on an "AS IS" BASIS,
-      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-      implied, including, without limitation, any warranties or conditions
-      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-      PARTICULAR PURPOSE. You are solely responsible for determining the
-      appropriateness of using or redistributing the Work and assume any
-      risks associated with Your exercise of permissions under this License.
-
-   8. Limitation of Liability. In no event and under no legal theory,
-      whether in tort (including negligence), contract, or otherwise,
-      unless required by applicable law (such as deliberate and grossly
-      negligent acts) or agreed to in writing, shall any Contributor be
-      liable to You for damages, including any direct, indirect, special,
-      incidental, or consequential damages of any character arising as a
-      result of this License or out of the use or inability to use the
-      Work (including but not limited to damages for loss of goodwill,
-      work stoppage, computer failure or malfunction, or any and all
-      other commercial damages or losses), even if such Contributor
-      has been advised of the possibility of such damages.
-
-   9. Accepting Warranty or Additional Liability. While redistributing
-      the Work or Derivative Works thereof, You may choose to offer,
-      and charge a fee for, acceptance of support, warranty, indemnity,
-      or other liability obligations and/or rights consistent with this
-      License. However, in accepting such obligations, You may act only
-      on Your own behalf and on Your sole responsibility, not on behalf
-      of any other Contributor, and only if You agree to indemnify,
-      defend, and hold each Contributor harmless for any liability
-      incurred by, or claims asserted against, such Contributor by reason
-      of your accepting any such warranty or additional liability.
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/README.md
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/README.md b/brooklyn-dist/dist/licensing/README.md
deleted file mode 100644
index 94ae070..0000000
--- a/brooklyn-dist/dist/licensing/README.md
+++ /dev/null
@@ -1,78 +0,0 @@
-
-We use a special maven plugin and scripts to automatically create the LICENSE
-files, including all notices, based on metadata in overrides.yaml and **/source-inclusions.yaml.
-
-First install  https://github.com/ahgittin/license-audit-maven-plugin 
-and then, in the usage/dist/ project of Brooklyn...
-
-
-# Quick Usage
-
-To see a tree of license info:
-
-    mvn org.heneveld.maven:license-audit-maven-plugin:report \
-        -Dformat=summary \
-        -DlicensesPreferred=ASL2,ASL,EPL1,BSD-2-Clause,BSD-3-Clause,CDDL1.1,CDDL1,CDDL \
-        -DoverridesFile=licensing/overrides.yaml \
-        -DextrasFiles=`cat licensing/extras-files`
-
-
-To create the LICENSE files needed for Apache Brooklyn
-(consisting of: one in the root for the source build, in the dist project for the binary build,
-and in `projects-with-custom-licenses` for those JARs which include other source code):
-
-    pushd licensing
-    ./make-all-licenses.sh || ( echo 'FAILED!!!' && rm LICENSE.autogenerated )
-    popd
-
-This combines the relevant `source-inclusions.yaml` files to create `extrasFile` files
-for `license-audit-maven-plugin` then runs the `notices` target for the various dists we make.
-If you need to add a new project to those which require custom LICENSE files, see below.
-
-
-# CSV License Report
-
-If you need to generate a CSV report of license usage, e.g. for use in a spreadsheet:
-
-    mvn org.heneveld.maven:license-audit-maven-plugin:report \
-        -Dformat=csv \
-        -DlistDependencyIdOnly=true \
-        -DsuppressExcludedDependencies=true \
-        -DlicensesPreferred=ASL2,ASL,EPL1,BSD-2-Clause,BSD-3-Clause,CDDL1.1,CDDL1,CDDL \
-        -DoverridesFile=licensing/overrides.yaml \
-        -DextrasFiles=`cat licensing/extras-files` \
-        -DoutputFile=dependencies-licenses.csv
-
-
-# When Projects Need Custom Licenses
-
-If a JAR includes 3rd party source code (as opposed to binary dependencies), it will typically 
-require a custom LICENSE file.
-
-To support this: 
-
-1. Add the relative path to that project to `projects-with-custom-licenses`,
-
-2. Create the necessary file structure and maven instructions:
-
-* in `src/main/license/` put a `README.md` pointing here
-* in `src/main/license/` put a `source-inclusion.yaml` listing the included 3rd-party projects by an `id:`
-  (you may need to choose an ID; this should be a meaningful name, e.g. `typeahead.js` or `Swagger UI`)
-* in `src/main/license/files` put the relevant non-LICENSE license files you want included (e.g. NOTICE)
-* in `src/test/license/files` put the standard files *including* LICENSE to include in the test JAR
-  (NB: these scripts don't generate custom licenses for test JARs, as so far that has not been needed)
-* in `pom.xml` add instructions to include `src/{main,test}/license/files` in the main and test JARs
-
-You can follow the pattern done for `cli` and `jsgui`.
-
-3. In `licensing/overrides.yaml` in this directory, add the metadata for the included projects.
-
-4. In `licensing/licenses/<your_project>/` include the relevant licenses for any included 3rd-party projects;
-   look in `licensing/licenses/binary` for samples.
-
-5. Run `make-all-licenses.sh` to auto-generate required config files and license copies,
-   and to generate the LICENSE for your project.
-
-Confirm that a LICENSE file for your project was generated, and that it is present in the JAR,
-and then open a pull-request, and confirm the changes there are appropriate.
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/extras-files
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/extras-files b/brooklyn-dist/dist/licensing/extras-files
deleted file mode 100644
index cbba9c5..0000000
--- a/brooklyn-dist/dist/licensing/extras-files
+++ /dev/null
@@ -1 +0,0 @@
-../../brooklyn-ui/src/main/license/source-inclusions.yaml:../../brooklyn-server/server-cli/src/main/license/source-inclusions.yaml

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/binary/ASL2
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/ASL2 b/brooklyn-dist/dist/licensing/licenses/binary/ASL2
deleted file mode 100644
index eccbc6a..0000000
--- a/brooklyn-dist/dist/licensing/licenses/binary/ASL2
+++ /dev/null
@@ -1,177 +0,0 @@
-Apache License, Version 2.0
-
-  Apache License
-  Version 2.0, January 2004
-  http://www.apache.org/licenses/
-  
-  TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
-  
-  1. Definitions.
-  
-  "License" shall mean the terms and conditions for use, reproduction,
-  and distribution as defined by Sections 1 through 9 of this document.
-  
-  "Licensor" shall mean the copyright owner or entity authorized by
-  the copyright owner that is granting the License.
-  
-  "Legal Entity" shall mean the union of the acting entity and all
-  other entities that control, are controlled by, or are under common
-  control with that entity. For the purposes of this definition,
-  "control" means (i) the power, direct or indirect, to cause the
-  direction or management of such entity, whether by contract or
-  otherwise, or (ii) ownership of fifty percent (50%) or more of the
-  outstanding shares, or (iii) beneficial ownership of such entity.
-  
-  "You" (or "Your") shall mean an individual or Legal Entity
-  exercising permissions granted by this License.
-  
-  "Source" form shall mean the preferred form for making modifications,
-  including but not limited to software source code, documentation
-  source, and configuration files.
-  
-  "Object" form shall mean any form resulting from mechanical
-  transformation or translation of a Source form, including but
-  not limited to compiled object code, generated documentation,
-  and conversions to other media types.
-  
-  "Work" shall mean the work of authorship, whether in Source or
-  Object form, made available under the License, as indicated by a
-  copyright notice that is included in or attached to the work
-  (an example is provided in the Appendix below).
-  
-  "Derivative Works" shall mean any work, whether in Source or Object
-  form, that is based on (or derived from) the Work and for which the
-  editorial revisions, annotations, elaborations, or other modifications
-  represent, as a whole, an original work of authorship. For the purposes
-  of this License, Derivative Works shall not include works that remain
-  separable from, or merely link (or bind by name) to the interfaces of,
-  the Work and Derivative Works thereof.
-  
-  "Contribution" shall mean any work of authorship, including
-  the original version of the Work and any modifications or additions
-  to that Work or Derivative Works thereof, that is intentionally
-  submitted to Licensor for inclusion in the Work by the copyright owner
-  or by an individual or Legal Entity authorized to submit on behalf of
-  the copyright owner. For the purposes of this definition, "submitted"
-  means any form of electronic, verbal, or written communication sent
-  to the Licensor or its representatives, including but not limited to
-  communication on electronic mailing lists, source code control systems,
-  and issue tracking systems that are managed by, or on behalf of, the
-  Licensor for the purpose of discussing and improving the Work, but
-  excluding communication that is conspicuously marked or otherwise
-  designated in writing by the copyright owner as "Not a Contribution."
-  
-  "Contributor" shall mean Licensor and any individual or Legal Entity
-  on behalf of whom a Contribution has been received by Licensor and
-  subsequently incorporated within the Work.
-  
-  2. Grant of Copyright License. Subject to the terms and conditions of
-  this License, each Contributor hereby grants to You a perpetual,
-  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-  copyright license to reproduce, prepare Derivative Works of,
-  publicly display, publicly perform, sublicense, and distribute the
-  Work and such Derivative Works in Source or Object form.
-  
-  3. Grant of Patent License. Subject to the terms and conditions of
-  this License, each Contributor hereby grants to You a perpetual,
-  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-  (except as stated in this section) patent license to make, have made,
-  use, offer to sell, sell, import, and otherwise transfer the Work,
-  where such license applies only to those patent claims licensable
-  by such Contributor that are necessarily infringed by their
-  Contribution(s) alone or by combination of their Contribution(s)
-  with the Work to which such Contribution(s) was submitted. If You
-  institute patent litigation against any entity (including a
-  cross-claim or counterclaim in a lawsuit) alleging that the Work
-  or a Contribution incorporated within the Work constitutes direct
-  or contributory patent infringement, then any patent licenses
-  granted to You under this License for that Work shall terminate
-  as of the date such litigation is filed.
-  
-  4. Redistribution. You may reproduce and distribute copies of the
-  Work or Derivative Works thereof in any medium, with or without
-  modifications, and in Source or Object form, provided that You
-  meet the following conditions:
-  
-  (a) You must give any other recipients of the Work or
-  Derivative Works a copy of this License; and
-  
-  (b) You must cause any modified files to carry prominent notices
-  stating that You changed the files; and
-  
-  (c) You must retain, in the Source form of any Derivative Works
-  that You distribute, all copyright, patent, trademark, and
-  attribution notices from the Source form of the Work,
-  excluding those notices that do not pertain to any part of
-  the Derivative Works; and
-  
-  (d) If the Work includes a "NOTICE" text file as part of its
-  distribution, then any Derivative Works that You distribute must
-  include a readable copy of the attribution notices contained
-  within such NOTICE file, excluding those notices that do not
-  pertain to any part of the Derivative Works, in at least one
-  of the following places: within a NOTICE text file distributed
-  as part of the Derivative Works; within the Source form or
-  documentation, if provided along with the Derivative Works; or,
-  within a display generated by the Derivative Works, if and
-  wherever such third-party notices normally appear. The contents
-  of the NOTICE file are for informational purposes only and
-  do not modify the License. You may add Your own attribution
-  notices within Derivative Works that You distribute, alongside
-  or as an addendum to the NOTICE text from the Work, provided
-  that such additional attribution notices cannot be construed
-  as modifying the License.
-  
-  You may add Your own copyright statement to Your modifications and
-  may provide additional or different license terms and conditions
-  for use, reproduction, or distribution of Your modifications, or
-  for any such Derivative Works as a whole, provided Your use,
-  reproduction, and distribution of the Work otherwise complies with
-  the conditions stated in this License.
-  
-  5. Submission of Contributions. Unless You explicitly state otherwise,
-  any Contribution intentionally submitted for inclusion in the Work
-  by You to the Licensor shall be under the terms and conditions of
-  this License, without any additional terms or conditions.
-  Notwithstanding the above, nothing herein shall supersede or modify
-  the terms of any separate license agreement you may have executed
-  with Licensor regarding such Contributions.
-  
-  6. Trademarks. This License does not grant permission to use the trade
-  names, trademarks, service marks, or product names of the Licensor,
-  except as required for reasonable and customary use in describing the
-  origin of the Work and reproducing the content of the NOTICE file.
-  
-  7. Disclaimer of Warranty. Unless required by applicable law or
-  agreed to in writing, Licensor provides the Work (and each
-  Contributor provides its Contributions) on an "AS IS" BASIS,
-  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-  implied, including, without limitation, any warranties or conditions
-  of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-  PARTICULAR PURPOSE. You are solely responsible for determining the
-  appropriateness of using or redistributing the Work and assume any
-  risks associated with Your exercise of permissions under this License.
-  
-  8. Limitation of Liability. In no event and under no legal theory,
-  whether in tort (including negligence), contract, or otherwise,
-  unless required by applicable law (such as deliberate and grossly
-  negligent acts) or agreed to in writing, shall any Contributor be
-  liable to You for damages, including any direct, indirect, special,
-  incidental, or consequential damages of any character arising as a
-  result of this License or out of the use or inability to use the
-  Work (including but not limited to damages for loss of goodwill,
-  work stoppage, computer failure or malfunction, or any and all
-  other commercial damages or losses), even if such Contributor
-  has been advised of the possibility of such damages.
-  
-  9. Accepting Warranty or Additional Liability. While redistributing
-  the Work or Derivative Works thereof, You may choose to offer,
-  and charge a fee for, acceptance of support, warranty, indemnity,
-  or other liability obligations and/or rights consistent with this
-  License. However, in accepting such obligations, You may act only
-  on Your own behalf and on Your sole responsibility, not on behalf
-  of any other Contributor, and only if You agree to indemnify,
-  defend, and hold each Contributor harmless for any liability
-  incurred by, or claims asserted against, such Contributor by reason
-  of your accepting any such warranty or additional liability.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/binary/BSD-2-Clause
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/BSD-2-Clause b/brooklyn-dist/dist/licensing/licenses/binary/BSD-2-Clause
deleted file mode 100644
index 832c10e..0000000
--- a/brooklyn-dist/dist/licensing/licenses/binary/BSD-2-Clause
+++ /dev/null
@@ -1,23 +0,0 @@
-The BSD 2-Clause License
-
-  Redistribution and use in source and binary forms, with or without
-  modification, are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, this
-  list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice,
-  this list of conditions and the following disclaimer in the documentation
-  and/or other materials provided with the distribution.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
-  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
-  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
-  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
-  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
-  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
-  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
-  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/binary/BSD-3-Clause
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/BSD-3-Clause b/brooklyn-dist/dist/licensing/licenses/binary/BSD-3-Clause
deleted file mode 100644
index be2692c..0000000
--- a/brooklyn-dist/dist/licensing/licenses/binary/BSD-3-Clause
+++ /dev/null
@@ -1,27 +0,0 @@
-The BSD 3-Clause License ("New BSD")
-
-  Redistribution and use in source and binary forms, with or without modification,
-  are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, 
-  this list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice, 
-  this list of conditions and the following disclaimer in the documentation 
-  and/or other materials provided with the distribution.
-  
-  3. Neither the name of the copyright holder nor the names of its contributors 
-  may be used to endorse or promote products derived from this software without 
-  specific prior written permission.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
-  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
-  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
-  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
-  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
-  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
-  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
-  POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/binary/CDDL1
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/CDDL1 b/brooklyn-dist/dist/licensing/licenses/binary/CDDL1
deleted file mode 100644
index 611d916..0000000
--- a/brooklyn-dist/dist/licensing/licenses/binary/CDDL1
+++ /dev/null
@@ -1,381 +0,0 @@
-COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.0
-
-  1. Definitions.
-  
-  1.1. "Contributor" means each individual or entity that
-  creates or contributes to the creation of Modifications.
-  
-  1.2. "Contributor Version" means the combination of the
-  Original Software, prior Modifications used by a
-  Contributor (if any), and the Modifications made by that
-  particular Contributor.
-  
-  1.3. "Covered Software" means (a) the Original Software, or
-  (b) Modifications, or (c) the combination of files
-  containing Original Software with files containing
-  Modifications, in each case including portions thereof.
-  
-  1.4. "Executable" means the Covered Software in any form
-  other than Source Code. 
-  
-  1.5. "Initial Developer" means the individual or entity
-  that first makes Original Software available under this
-  License. 
-  
-  1.6. "Larger Work" means a work which combines Covered
-  Software or portions thereof with code not governed by the
-  terms of this License.
-  
-  1.7. "License" means this document.
-  
-  1.8. "Licensable" means having the right to grant, to the
-  maximum extent possible, whether at the time of the initial
-  grant or subsequently acquired, any and all of the rights
-  conveyed herein.
-  
-  1.9. "Modifications" means the Source Code and Executable
-  form of any of the following: 
-  
-  A. Any file that results from an addition to,
-  deletion from or modification of the contents of a
-  file containing Original Software or previous
-  Modifications; 
-  
-  B. Any new file that contains any part of the
-  Original Software or previous Modification; or 
-  
-  C. Any new file that is contributed or otherwise made
-  available under the terms of this License.
-  
-  1.10. "Original Software" means the Source Code and
-  Executable form of computer software code that is
-  originally released under this License. 
-  
-  1.11. "Patent Claims" means any patent claim(s), now owned
-  or hereafter acquired, including without limitation,
-  method, process, and apparatus claims, in any patent
-  Licensable by grantor. 
-  
-  1.12. "Source Code" means (a) the common form of computer
-  software code in which modifications are made and (b)
-  associated documentation included in or with such code.
-  
-  1.13. "You" (or "Your") means an individual or a legal
-  entity exercising rights under, and complying with all of
-  the terms of, this License. For legal entities, "You"
-  includes any entity which controls, is controlled by, or is
-  under common control with You. For purposes of this
-  definition, "control" means (a) the power, direct or
-  indirect, to cause the direction or management of such
-  entity, whether by contract or otherwise, or (b) ownership
-  of more than fifty percent (50%) of the outstanding shares
-  or beneficial ownership of such entity.
-  
-  2. License Grants. 
-  
-  2.1. The Initial Developer Grant.
-  
-  Conditioned upon Your compliance with Section 3.1 below and
-  subject to third party intellectual property claims, the
-  Initial Developer hereby grants You a world-wide,
-  royalty-free, non-exclusive license: 
-  
-  (a) under intellectual property rights (other than
-  patent or trademark) Licensable by Initial Developer,
-  to use, reproduce, modify, display, perform,
-  sublicense and distribute the Original Software (or
-  portions thereof), with or without Modifications,
-  and/or as part of a Larger Work; and 
-  
-  (b) under Patent Claims infringed by the making,
-  using or selling of Original Software, to make, have
-  made, use, practice, sell, and offer for sale, and/or
-  otherwise dispose of the Original Software (or
-  portions thereof). 
-  
-  (c) The licenses granted in Sections 2.1(a) and (b)
-  are effective on the date Initial Developer first
-  distributes or otherwise makes the Original Software
-  available to a third party under the terms of this
-  License. 
-  
-  (d) Notwithstanding Section 2.1(b) above, no patent
-  license is granted: (1) for code that You delete from
-  the Original Software, or (2) for infringements
-  caused by: (i) the modification of the Original
-  Software, or (ii) the combination of the Original
-  Software with other software or devices. 
-  
-  2.2. Contributor Grant.
-  
-  Conditioned upon Your compliance with Section 3.1 below and
-  subject to third party intellectual property claims, each
-  Contributor hereby grants You a world-wide, royalty-free,
-  non-exclusive license:
-  
-  (a) under intellectual property rights (other than
-  patent or trademark) Licensable by Contributor to
-  use, reproduce, modify, display, perform, sublicense
-  and distribute the Modifications created by such
-  Contributor (or portions thereof), either on an
-  unmodified basis, with other Modifications, as
-  Covered Software and/or as part of a Larger Work; and
-  
-  (b) under Patent Claims infringed by the making,
-  using, or selling of Modifications made by that
-  Contributor either alone and/or in combination with
-  its Contributor Version (or portions of such
-  combination), to make, use, sell, offer for sale,
-  have made, and/or otherwise dispose of: (1)
-  Modifications made by that Contributor (or portions
-  thereof); and (2) the combination of Modifications
-  made by that Contributor with its Contributor Version
-  (or portions of such combination). 
-  
-  (c) The licenses granted in Sections 2.2(a) and
-  2.2(b) are effective on the date Contributor first
-  distributes or otherwise makes the Modifications
-  available to a third party. 
-  
-  (d) Notwithstanding Section 2.2(b) above, no patent
-  license is granted: (1) for any code that Contributor
-  has deleted from the Contributor Version; (2) for
-  infringements caused by: (i) third party
-  modifications of Contributor Version, or (ii) the
-  combination of Modifications made by that Contributor
-  with other software (except as part of the
-  Contributor Version) or other devices; or (3) under
-  Patent Claims infringed by Covered Software in the
-  absence of Modifications made by that Contributor. 
-  
-  3. Distribution Obligations.
-  
-  3.1. Availability of Source Code.
-  
-  Any Covered Software that You distribute or otherwise make
-  available in Executable form must also be made available in
-  Source Code form and that Source Code form must be
-  distributed only under the terms of this License. You must
-  include a copy of this License with every copy of the
-  Source Code form of the Covered Software You distribute or
-  otherwise make available. You must inform recipients of any
-  such Covered Software in Executable form as to how they can
-  obtain such Covered Software in Source Code form in a
-  reasonable manner on or through a medium customarily used
-  for software exchange.
-  
-  3.2. Modifications.
-  
-  The Modifications that You create or to which You
-  contribute are governed by the terms of this License. You
-  represent that You believe Your Modifications are Your
-  original creation(s) and/or You have sufficient rights to
-  grant the rights conveyed by this License.
-  
-  3.3. Required Notices.
-  
-  You must include a notice in each of Your Modifications
-  that identifies You as the Contributor of the Modification.
-  You may not remove or alter any copyright, patent or
-  trademark notices contained within the Covered Software, or
-  any notices of licensing or any descriptive text giving
-  attribution to any Contributor or the Initial Developer.
-  
-  3.4. Application of Additional Terms.
-  
-  You may not offer or impose any terms on any Covered
-  Software in Source Code form that alters or restricts the
-  applicable version of this License or the recipients"
-  rights hereunder. You may choose to offer, and to charge a
-  fee for, warranty, support, indemnity or liability
-  obligations to one or more recipients of Covered Software.
-  However, you may do so only on Your own behalf, and not on
-  behalf of the Initial Developer or any Contributor. You
-  must make it absolutely clear that any such warranty,
-  support, indemnity or liability obligation is offered by
-  You alone, and You hereby agree to indemnify the Initial
-  Developer and every Contributor for any liability incurred
-  by the Initial Developer or such Contributor as a result of
-  warranty, support, indemnity or liability terms You offer.
-      
-  3.5. Distribution of Executable Versions.
-  
-  You may distribute the Executable form of the Covered
-  Software under the terms of this License or under the terms
-  of a license of Your choice, which may contain terms
-  different from this License, provided that You are in
-  compliance with the terms of this License and that the
-  license for the Executable form does not attempt to limit
-  or alter the recipient"s rights in the Source Code form
-  from the rights set forth in this License. If You
-  distribute the Covered Software in Executable form under a
-  different license, You must make it absolutely clear that
-  any terms which differ from this License are offered by You
-  alone, not by the Initial Developer or Contributor. You
-  hereby agree to indemnify the Initial Developer and every
-  Contributor for any liability incurred by the Initial
-  Developer or such Contributor as a result of any such terms
-  You offer.
-  
-  3.6. Larger Works.
-  
-  You may create a Larger Work by combining Covered Software
-  with other code not governed by the terms of this License
-  and distribute the Larger Work as a single product. In such
-  a case, You must make sure the requirements of this License
-  are fulfilled for the Covered Software. 
-  
-  4. Versions of the License. 
-  
-  4.1. New Versions.
-  
-  Sun Microsystems, Inc. is the initial license steward and
-  may publish revised and/or new versions of this License
-  from time to time. Each version will be given a
-  distinguishing version number. Except as provided in
-  Section 4.3, no one other than the license steward has the
-  right to modify this License. 
-  
-  4.2. Effect of New Versions.
-  
-  You may always continue to use, distribute or otherwise
-  make the Covered Software available under the terms of the
-  version of the License under which You originally received
-  the Covered Software. If the Initial Developer includes a
-  notice in the Original Software prohibiting it from being
-  distributed or otherwise made available under any
-  subsequent version of the License, You must distribute and
-  make the Covered Software available under the terms of the
-  version of the License under which You originally received
-  the Covered Software. Otherwise, You may also choose to
-  use, distribute or otherwise make the Covered Software
-  available under the terms of any subsequent version of the
-  License published by the license steward. 
-  
-  4.3. Modified Versions.
-  
-  When You are an Initial Developer and You want to create a
-  new license for Your Original Software, You may create and
-  use a modified version of this License if You: (a) rename
-  the license and remove any references to the name of the
-  license steward (except to note that the license differs
-  from this License); and (b) otherwise make it clear that
-  the license contains terms which differ from this License.
-  
-  5. DISCLAIMER OF WARRANTY.
-  
-  COVERED SOFTWARE IS PROVIDED UNDER THIS LICENSE ON AN "AS IS"
-  BASIS, WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED,
-  INCLUDING, WITHOUT LIMITATION, WARRANTIES THAT THE COVERED
-  SOFTWARE IS FREE OF DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR
-  PURPOSE OR NON-INFRINGING. THE ENTIRE RISK AS TO THE QUALITY AND
-  PERFORMANCE OF THE COVERED SOFTWARE IS WITH YOU. SHOULD ANY
-  COVERED SOFTWARE PROVE DEFECTIVE IN ANY RESPECT, YOU (NOT THE
-  INITIAL DEVELOPER OR ANY OTHER CONTRIBUTOR) ASSUME THE COST OF
-  ANY NECESSARY SERVICING, REPAIR OR CORRECTION. THIS DISCLAIMER OF
-  WARRANTY CONSTITUTES AN ESSENTIAL PART OF THIS LICENSE. NO USE OF
-  ANY COVERED SOFTWARE IS AUTHORIZED HEREUNDER EXCEPT UNDER THIS
-  DISCLAIMER. 
-  
-  6. TERMINATION. 
-  
-  6.1. This License and the rights granted hereunder will
-  terminate automatically if You fail to comply with terms
-  herein and fail to cure such breach within 30 days of
-  becoming aware of the breach. Provisions which, by their
-  nature, must remain in effect beyond the termination of
-  this License shall survive.
-  
-  6.2. If You assert a patent infringement claim (excluding
-  declaratory judgment actions) against Initial Developer or
-  a Contributor (the Initial Developer or Contributor against
-  whom You assert such claim is referred to as "Participant")
-  alleging that the Participant Software (meaning the
-  Contributor Version where the Participant is a Contributor
-  or the Original Software where the Participant is the
-  Initial Developer) directly or indirectly infringes any
-  patent, then any and all rights granted directly or
-  indirectly to You by such Participant, the Initial
-  Developer (if the Initial Developer is not the Participant)
-  and all Contributors under Sections 2.1 and/or 2.2 of this
-  License shall, upon 60 days notice from Participant
-  terminate prospectively and automatically at the expiration
-  of such 60 day notice period, unless if within such 60 day
-  period You withdraw Your claim with respect to the
-  Participant Software against such Participant either
-  unilaterally or pursuant to a written agreement with
-  Participant.
-  
-  6.3. In the event of termination under Sections 6.1 or 6.2
-  above, all end user licenses that have been validly granted
-  by You or any distributor hereunder prior to termination
-  (excluding licenses granted to You by any distributor)
-  shall survive termination.
-  
-  7. LIMITATION OF LIABILITY.
-  
-  UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT
-  (INCLUDING NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE
-  INITIAL DEVELOPER, ANY OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF
-  COVERED SOFTWARE, OR ANY SUPPLIER OF ANY OF SUCH PARTIES, BE
-  LIABLE TO ANY PERSON FOR ANY INDIRECT, SPECIAL, INCIDENTAL, OR
-  CONSEQUENTIAL DAMAGES OF ANY CHARACTER INCLUDING, WITHOUT
-  LIMITATION, DAMAGES FOR LOST PROFITS, LOSS OF GOODWILL, WORK
-  STOPPAGE, COMPUTER FAILURE OR MALFUNCTION, OR ANY AND ALL OTHER
-  COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH PARTY SHALL HAVE BEEN
-  INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS LIMITATION OF
-  LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL
-  INJURY RESULTING FROM SUCH PARTY"S NEGLIGENCE TO THE EXTENT
-  APPLICABLE LAW PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO
-  NOT ALLOW THE EXCLUSION OR LIMITATION OF INCIDENTAL OR
-  CONSEQUENTIAL DAMAGES, SO THIS EXCLUSION AND LIMITATION MAY NOT
-  APPLY TO YOU.
-  
-  8. U.S. GOVERNMENT END USERS.
-  
-  The Covered Software is a "commercial item," as that term is
-  defined in 48 C.F.R. 2.101 (Oct. 1995), consisting of "commercial
-  computer software" (as that term is defined at 48 C.F.R. "
-  252.227-7014(a)(1)) and "commercial computer software
-  documentation" as such terms are used in 48 C.F.R. 12.212 (Sept.
-  1995). Consistent with 48 C.F.R. 12.212 and 48 C.F.R. 227.7202-1
-  through 227.7202-4 (June 1995), all U.S. Government End Users
-  acquire Covered Software with only those rights set forth herein.
-  This U.S. Government Rights clause is in lieu of, and supersedes,
-  any other FAR, DFAR, or other clause or provision that addresses
-  Government rights in computer software under this License.
-  
-  9. MISCELLANEOUS.
-  
-  This License represents the complete agreement concerning subject
-  matter hereof. If any provision of this License is held to be
-  unenforceable, such provision shall be reformed only to the
-  extent necessary to make it enforceable. This License shall be
-  governed by the law of the jurisdiction specified in a notice
-  contained within the Original Software (except to the extent
-  applicable law, if any, provides otherwise), excluding such
-  jurisdiction"s conflict-of-law provisions. Any litigation
-  relating to this License shall be subject to the jurisdiction of
-  the courts located in the jurisdiction and venue specified in a
-  notice contained within the Original Software, with the losing
-  party responsible for costs, including, without limitation, court
-  costs and reasonable attorneys" fees and expenses. The
-  application of the United Nations Convention on Contracts for the
-  International Sale of Goods is expressly excluded. Any law or
-  regulation which provides that the language of a contract shall
-  be construed against the drafter shall not apply to this License.
-  You agree that You alone are responsible for compliance with the
-  United States export administration regulations (and the export
-  control laws and regulation of any other countries) when You use,
-  distribute or otherwise make available any Covered Software.
-  
-  10. RESPONSIBILITY FOR CLAIMS.
-  
-  As between Initial Developer and the Contributors, each party is
-  responsible for claims and damages arising, directly or
-  indirectly, out of its utilization of rights under this License
-  and You agree to work with Initial Developer and Contributors to
-  distribute such responsibility on an equitable basis. Nothing
-  herein is intended or shall be deemed to constitute any admission
-  of liability.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/binary/CDDL1.1
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/CDDL1.1 b/brooklyn-dist/dist/licensing/licenses/binary/CDDL1.1
deleted file mode 100644
index def9b35..0000000
--- a/brooklyn-dist/dist/licensing/licenses/binary/CDDL1.1
+++ /dev/null
@@ -1,304 +0,0 @@
-COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.1
-
-  1. Definitions.
-  
-  1.1. “Contributor” means each individual or entity that creates or contributes
-  to the creation of Modifications.
-  
-  1.2. “Contributor Version” means the combination of the Original Software,
-  prior Modifications used by a Contributor (if any), and the Modifications made
-  by that particular Contributor.
-  
-  1.3. “Covered Software” means (a) the Original Software, or (b) Modifications,
-  or (c) the combination of files containing Original Software with files
-  containing Modifications, in each case including portions thereof.
-  
-  1.4. “Executable” means the Covered Software in any form other than Source
-  Code.
-  
-  1.5. “Initial Developer” means the individual or entity that first makes
-  Original Software available under this License.
-  
-  1.6. “Larger Work” means a work which combines Covered Software or portions
-  thereof with code not governed by the terms of this License.
-  
-  1.7. “License” means this document.
-  
-  1.8. “Licensable” means having the right to grant, to the maximum extent
-  possible, whether at the time of the initial grant or subsequently acquired,
-  any and all of the rights conveyed herein.
-  
-  1.9. “Modifications” means the Source Code and Executable form of any of the
-  following:
-  
-  A. Any file that results from an addition to, deletion from or modification of
-  the contents of a file containing Original Software or previous Modifications;
-  
-  B. Any new file that contains any part of the Original Software or previous
-  Modification; or
-  
-  C. Any new file that is contributed or otherwise made available under the terms
-  of this License.
-  
-  1.10. “Original Software” means the Source Code and Executable form of computer
-  software code that is originally released under this License.
-  
-  1.11. “Patent Claims” means any patent claim(s), now owned or hereafter
-  acquired, including without limitation, method, process, and apparatus claims,
-  in any patent Licensable by grantor.
-  
-  1.12. “Source Code” means (a) the common form of computer software code in
-  which modifications are made and (b) associated documentation included in or
-  with such code.
-  
-  1.13. “You” (or “Your”) means an individual or a legal entity exercising rights
-  under, and complying with all of the terms of, this License. For legal
-  entities, “You” includes any entity which controls, is controlled by, or is
-  under common control with You. For purposes of this definition, “control” means
-  (a) the power, direct or indirect, to cause the direction or management of such
-  entity, whether by contract or otherwise, or (b) ownership of more than fifty
-  percent (50%) of the outstanding shares or beneficial ownership of such entity.
-  
-  2. License Grants.
-  
-  2.1. The Initial Developer Grant.  Conditioned upon Your compliance with
-  Section 3.1 below and subject to third party intellectual property claims, the
-  Initial Developer hereby grants You a world-wide, royalty-free, non-exclusive
-  license:
-  
-  (a) under intellectual property rights (other than patent or trademark)
-  Licensable by Initial Developer, to use, reproduce, modify, display, perform,
-  sublicense and distribute the Original Software (or portions thereof), with or
-  without Modifications, and/or as part of a Larger Work; and
-  
-  (b) under Patent Claims infringed by the making, using or selling of Original
-  Software, to make, have made, use, practice, sell, and offer for sale, and/or
-  otherwise dispose of the Original Software (or portions thereof).
-  
-  (c) The licenses granted in Sections 2.1(a) and (b) are effective on the date
-  Initial Developer first distributes or otherwise makes the Original Software
-  available to a third party under the terms of this License.
-  
-  (d) Notwithstanding Section 2.1(b) above, no patent license is granted: (1) for
-  code that You delete from the Original Software, or (2) for infringements
-  caused by: (i) the modification of the Original Software, or (ii) the
-  combination of the Original Software with other software or devices.
-  
-  2.2. Contributor Grant.  Conditioned upon Your compliance with Section 3.1
-  below and subject to third party intellectual property claims, each Contributor
-  hereby grants You a world-wide, royalty-free, non-exclusive license:
-  
-  (a) under intellectual property rights (other than patent or trademark)
-  Licensable by Contributor to use, reproduce, modify, display, perform,
-  sublicense and distribute the Modifications created by such Contributor (or
-  portions thereof), either on an unmodified basis, with other Modifications, as
-  Covered Software and/or as part of a Larger Work; and
-  
-  (b) under Patent Claims infringed by the making, using, or selling of
-  Modifications made by that Contributor either alone and/or in combination with
-  its Contributor Version (or portions of such combination), to make, use, sell,
-  offer for sale, have made, and/or otherwise dispose of: (1) Modifications made
-  by that Contributor (or portions thereof); and (2) the combination of
-  Modifications made by that Contributor with its Contributor Version (or
-  portions of such combination).
-  
-  (c) The licenses granted in Sections 2.2(a) and 2.2(b) are effective on the
-  date Contributor first distributes or otherwise makes the Modifications
-  available to a third party.
-  
-  (d) Notwithstanding Section 2.2(b) above, no patent license is granted: (1) for
-  any code that Contributor has deleted from the Contributor Version; (2) for
-  infringements caused by: (i) third party modifications of Contributor Version,
-  or (ii) the combination of Modifications made by that Contributor with other
-  software (except as part of the Contributor Version) or other devices; or (3)
-  under Patent Claims infringed by Covered Software in the absence of
-  Modifications made by that Contributor.
-  
-  3. Distribution Obligations.
-  
-  3.1. Availability of Source Code.  Any Covered Software that You distribute or
-  otherwise make available in Executable form must also be made available in
-  Source Code form and that Source Code form must be distributed only under the
-  terms of this License. You must include a copy of this License with every copy
-  of the Source Code form of the Covered Software You distribute or otherwise
-  make available. You must inform recipients of any such Covered Software in
-  Executable form as to how they can obtain such Covered Software in Source Code
-  form in a reasonable manner on or through a medium customarily used for
-  software exchange.
-  
-  3.2. Modifications.  The Modifications that You create or to which You
-  contribute are governed by the terms of this License. You represent that You
-  believe Your Modifications are Your original creation(s) and/or You have
-  sufficient rights to grant the rights conveyed by this License.
-  
-  3.3. Required Notices.  You must include a notice in each of Your Modifications
-  that identifies You as the Contributor of the Modification. You may not remove
-  or alter any copyright, patent or trademark notices contained within the
-  Covered Software, or any notices of licensing or any descriptive text giving
-  attribution to any Contributor or the Initial Developer.
-  
-  3.4. Application of Additional Terms.  You may not offer or impose any terms on
-  any Covered Software in Source Code form that alters or restricts the
-  applicable version of this License or the recipients' rights hereunder. You may
-  choose to offer, and to charge a fee for, warranty, support, indemnity or
-  liability obligations to one or more recipients of Covered Software. However,
-  you may do so only on Your own behalf, and not on behalf of the Initial
-  Developer or any Contributor. You must make it absolutely clear that any such
-  warranty, support, indemnity or liability obligation is offered by You alone,
-  and You hereby agree to indemnify the Initial Developer and every Contributor
-  for any liability incurred by the Initial Developer or such Contributor as a
-  result of warranty, support, indemnity or liability terms You offer.
-  
-  3.5. Distribution of Executable Versions.  You may distribute the Executable
-  form of the Covered Software under the terms of this License or under the terms
-  of a license of Your choice, which may contain terms different from this
-  License, provided that You are in compliance with the terms of this License and
-  that the license for the Executable form does not attempt to limit or alter the
-  recipient's rights in the Source Code form from the rights set forth in this
-  License. If You distribute the Covered Software in Executable form under a
-  different license, You must make it absolutely clear that any terms which
-  differ from this License are offered by You alone, not by the Initial Developer
-  or Contributor. You hereby agree to indemnify the Initial Developer and every
-  Contributor for any liability incurred by the Initial Developer or such
-  Contributor as a result of any such terms You offer.
-  
-  3.6. Larger Works.  You may create a Larger Work by combining Covered Software
-  with other code not governed by the terms of this License and distribute the
-  Larger Work as a single product. In such a case, You must make sure the
-  requirements of this License are fulfilled for the Covered Software.
-  
-  4. Versions of the License.
-  
-  4.1. New Versions.  Oracle is the initial license steward and may publish
-  revised and/or new versions of this License from time to time. Each version
-  will be given a distinguishing version number. Except as provided in Section
-  4.3, no one other than the license steward has the right to modify this
-  License.
-  
-  4.2. Effect of New Versions.  You may always continue to use, distribute or
-  otherwise make the Covered Software available under the terms of the version of
-  the License under which You originally received the Covered Software. If the
-  Initial Developer includes a notice in the Original Software prohibiting it
-  from being distributed or otherwise made available under any subsequent version
-  of the License, You must distribute and make the Covered Software available
-  under the terms of the version of the License under which You originally
-  received the Covered Software. Otherwise, You may also choose to use,
-  distribute or otherwise make the Covered Software available under the terms of
-  any subsequent version of the License published by the license steward.
-  
-  4.3. Modified Versions.  When You are an Initial Developer and You want to
-  create a new license for Your Original Software, You may create and use a
-  modified version of this License if You: (a) rename the license and remove any
-  references to the name of the license steward (except to note that the license
-  differs from this License); and (b) otherwise make it clear that the license
-  contains terms which differ from this License.
-  
-  5. DISCLAIMER OF WARRANTY.  COVERED SOFTWARE IS PROVIDED UNDER THIS LICENSE ON
-  AN “AS IS” BASIS, WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED,
-  INCLUDING, WITHOUT LIMITATION, WARRANTIES THAT THE COVERED SOFTWARE IS FREE OF
-  DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR PURPOSE OR NON-INFRINGING. THE
-  ENTIRE RISK AS TO THE QUALITY AND PERFORMANCE OF THE COVERED SOFTWARE IS WITH
-  YOU. SHOULD ANY COVERED SOFTWARE PROVE DEFECTIVE IN ANY RESPECT, YOU (NOT THE
-  INITIAL DEVELOPER OR ANY OTHER CONTRIBUTOR) ASSUME THE COST OF ANY NECESSARY
-  SERVICING, REPAIR OR CORRECTION. THIS DISCLAIMER OF WARRANTY CONSTITUTES AN
-  ESSENTIAL PART OF THIS LICENSE. NO USE OF ANY COVERED SOFTWARE IS AUTHORIZED
-  HEREUNDER EXCEPT UNDER THIS DISCLAIMER.
-  
-  6. TERMINATION.
-  
-  6.1. This License and the rights granted hereunder will terminate automatically
-  if You fail to comply with terms herein and fail to cure such breach within 30
-  days of becoming aware of the breach. Provisions which, by their nature, must
-  remain in effect beyond the termination of this License shall survive.
-  
-  6.2. If You assert a patent infringement claim (excluding declaratory judgment
-  actions) against Initial Developer or a Contributor (the Initial Developer or
-  Contributor against whom You assert such claim is referred to as “Participant”)
-  alleging that the Participant Software (meaning the Contributor Version where
-  the Participant is a Contributor or the Original Software where the Participant
-  is the Initial Developer) directly or indirectly infringes any patent, then any
-  and all rights granted directly or indirectly to You by such Participant, the
-  Initial Developer (if the Initial Developer is not the Participant) and all
-  Contributors under Sections 2.1 and/or 2.2 of this License shall, upon 60 days
-  notice from Participant terminate prospectively and automatically at the
-  expiration of such 60 day notice period, unless if within such 60 day period
-  You withdraw Your claim with respect to the Participant Software against such
-  Participant either unilaterally or pursuant to a written agreement with
-  Participant.
-  
-  6.3. If You assert a patent infringement claim against Participant alleging
-  that the Participant Software directly or indirectly infringes any patent where
-  such claim is resolved (such as by license or settlement) prior to the
-  initiation of patent infringement litigation, then the reasonable value of the
-  licenses granted by such Participant under Sections 2.1 or 2.2 shall be taken
-  into account in determining the amount or value of any payment or license.
-  
-  6.4. In the event of termination under Sections 6.1 or 6.2 above, all end user
-  licenses that have been validly granted by You or any distributor hereunder
-  prior to termination (excluding licenses granted to You by any distributor)
-  shall survive termination.
-  
-  7. LIMITATION OF LIABILITY.
-  
-  UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT (INCLUDING
-  NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE INITIAL DEVELOPER, ANY
-  OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF COVERED SOFTWARE, OR ANY SUPPLIER OF
-  ANY OF SUCH PARTIES, BE LIABLE TO ANY PERSON FOR ANY INDIRECT, SPECIAL,
-  INCIDENTAL, OR CONSEQUENTIAL DAMAGES OF ANY CHARACTER INCLUDING, WITHOUT
-  LIMITATION, DAMAGES FOR LOSS OF GOODWILL, WORK STOPPAGE, COMPUTER FAILURE OR
-  MALFUNCTION, OR ANY AND ALL OTHER COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH
-  PARTY SHALL HAVE BEEN INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS
-  LIMITATION OF LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL
-  INJURY RESULTING FROM SUCH PARTY'S NEGLIGENCE TO THE EXTENT APPLICABLE LAW
-  PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO NOT ALLOW THE EXCLUSION OR
-  LIMITATION OF INCIDENTAL OR CONSEQUENTIAL DAMAGES, SO THIS EXCLUSION AND
-  LIMITATION MAY NOT APPLY TO YOU.
-  
-  8. U.S. GOVERNMENT END USERS.
-  
-  The Covered Software is a “commercial item,” as that term is defined in 48
-  C.F.R. 2.101 (Oct. 1995), consisting of “commercial computer software” (as that
-  term is defined at 48 C.F.R. § 252.227-7014(a)(1)) and “commercial computer
-  software documentation” as such terms are used in 48 C.F.R. 12.212 (Sept.
-  1995). Consistent with 48 C.F.R. 12.212 and 48 C.F.R. 227.7202-1 through
-  227.7202-4 (June 1995), all U.S. Government End Users acquire Covered Software
-  with only those rights set forth herein. This U.S. Government Rights clause is
-  in lieu of, and supersedes, any other FAR, DFAR, or other clause or provision
-  that addresses Government rights in computer software under this License.
-  
-  9. MISCELLANEOUS.
-  
-  This License represents the complete agreement concerning subject matter
-  hereof. If any provision of this License is held to be unenforceable, such
-  provision shall be reformed only to the extent necessary to make it
-  enforceable. This License shall be governed by the law of the jurisdiction
-  specified in a notice contained within the Original Software (except to the
-  extent applicable law, if any, provides otherwise), excluding such
-  jurisdiction's conflict-of-law provisions. Any litigation relating to this
-  License shall be subject to the jurisdiction of the courts located in the
-  jurisdiction and venue specified in a notice contained within the Original
-  Software, with the losing party responsible for costs, including, without
-  limitation, court costs and reasonable attorneys' fees and expenses. The
-  application of the United Nations Convention on Contracts for the International
-  Sale of Goods is expressly excluded. Any law or regulation which provides that
-  the language of a contract shall be construed against the drafter shall not
-  apply to this License. You agree that You alone are responsible for compliance
-  with the United States export administration regulations (and the export
-  control laws and regulation of any other countries) when You use, distribute or
-  otherwise make available any Covered Software.
-  
-  10. RESPONSIBILITY FOR CLAIMS.
-  
-  As between Initial Developer and the Contributors, each party is responsible
-  for claims and damages arising, directly or indirectly, out of its utilization
-  of rights under this License and You agree to work with Initial Developer and
-  Contributors to distribute such responsibility on an equitable basis. Nothing
-  herein is intended or shall be deemed to constitute any admission of liability.
-  
-  NOTICE PURSUANT TO SECTION 9 OF THE COMMON DEVELOPMENT AND DISTRIBUTION LICENSE
-  (CDDL) The code released under the CDDL shall be governed by the laws of the
-  State of California (excluding conflict-of-law provisions). Any litigation
-  relating to this License shall be subject to the jurisdiction of the Federal
-  Courts of the Northern District of California and the state courts of the State
-  of California, with venue lying in Santa Clara County, California.
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/binary/EPL1
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/EPL1 b/brooklyn-dist/dist/licensing/licenses/binary/EPL1
deleted file mode 100644
index 6891076..0000000
--- a/brooklyn-dist/dist/licensing/licenses/binary/EPL1
+++ /dev/null
@@ -1,212 +0,0 @@
-Eclipse Public License, version 1.0
-
-  THE ACCOMPANYING PROGRAM IS PROVIDED UNDER THE TERMS OF THIS ECLIPSE PUBLIC
-  LICENSE ("AGREEMENT"). ANY USE, REPRODUCTION OR DISTRIBUTION OF THE PROGRAM
-  CONSTITUTES RECIPIENT'S ACCEPTANCE OF THIS AGREEMENT.
-  
-  1. DEFINITIONS
-  
-  "Contribution" means:
-  
-  a) in the case of the initial Contributor, the initial code and documentation
-  distributed under this Agreement, and b) in the case of each subsequent
-  Contributor:
-  
-  i) changes to the Program, and
-  
-  ii) additions to the Program;
-  
-  where such changes and/or additions to the Program originate from and are
-  distributed by that particular Contributor. A Contribution 'originates' from a
-  Contributor if it was added to the Program by such Contributor itself or anyone
-  acting on such Contributor's behalf. Contributions do not include additions to
-  the Program which: (i) are separate modules of software distributed in
-  conjunction with the Program under their own license agreement, and (ii) are
-  not derivative works of the Program.
-  
-  "Contributor" means any person or entity that distributes the Program.
-  
-  "Licensed Patents " mean patent claims licensable by a Contributor which are
-  necessarily infringed by the use or sale of its Contribution alone or when
-  combined with the Program.
-  
-  "Program" means the Contributions distributed in accordance with this
-  Agreement.
-  
-  "Recipient" means anyone who receives the Program under this Agreement,
-  including all Contributors.
-  
-  2. GRANT OF RIGHTS
-  
-  a) Subject to the terms of this Agreement, each Contributor hereby grants
-  Recipient a non-exclusive, worldwide, royalty-free copyright license to
-  reproduce, prepare derivative works of, publicly display, publicly perform,
-  distribute and sublicense the Contribution of such Contributor, if any, and
-  such derivative works, in source code and object code form.
-  
-  b) Subject to the terms of this Agreement, each Contributor hereby grants
-  Recipient a non-exclusive, worldwide, royalty-free patent license under
-  Licensed Patents to make, use, sell, offer to sell, import and otherwise
-  transfer the Contribution of such Contributor, if any, in source code and
-  object code form. This patent license shall apply to the combination of the
-  Contribution and the Program if, at the time the Contribution is added by the
-  Contributor, such addition of the Contribution causes such combination to be
-  covered by the Licensed Patents. The patent license shall not apply to any
-  other combinations which include the Contribution. No hardware per se is
-  licensed hereunder.
-  
-  c) Recipient understands that although each Contributor grants the licenses to
-  its Contributions set forth herein, no assurances are provided by any
-  Contributor that the Program does not infringe the patent or other intellectual
-  property rights of any other entity. Each Contributor disclaims any liability
-  to Recipient for claims brought by any other entity based on infringement of
-  intellectual property rights or otherwise. As a condition to exercising the
-  rights and licenses granted hereunder, each Recipient hereby assumes sole
-  responsibility to secure any other intellectual property rights needed, if any.
-  For example, if a third party patent license is required to allow Recipient to
-  distribute the Program, it is Recipient's responsibility to acquire that
-  license before distributing the Program.
-  
-  d) Each Contributor represents that to its knowledge it has sufficient
-  copyright rights in its Contribution, if any, to grant the copyright license
-  set forth in this Agreement.
-  
-  3. REQUIREMENTS
-  
-  A Contributor may choose to distribute the Program in object code form under
-  its own license agreement, provided that:
-  
-  a) it complies with the terms and conditions of this Agreement; and
-  
-  b) its license agreement:
-  
-  i) effectively disclaims on behalf of all Contributors all warranties and
-  conditions, express and implied, including warranties or conditions of title
-  and non-infringement, and implied warranties or conditions of merchantability
-  and fitness for a particular purpose;
-  
-  ii) effectively excludes on behalf of all Contributors all liability for
-  damages, including direct, indirect, special, incidental and consequential
-  damages, such as lost profits;
-  
-  iii) states that any provisions which differ from this Agreement are offered by
-  that Contributor alone and not by any other party; and
-  
-  iv) states that source code for the Program is available from such Contributor,
-  and informs licensees how to obtain it in a reasonable manner on or through a
-  medium customarily used for software exchange.
-  
-  When the Program is made available in source code form:
-  
-  a) it must be made available under this Agreement; and
-  
-  b) a copy of this Agreement must be included with each copy of the Program.
-  
-  Contributors may not remove or alter any copyright notices contained within the
-  Program.
-  
-  Each Contributor must identify itself as the originator of its Contribution, if
-  any, in a manner that reasonably allows subsequent Recipients to identify the
-  originator of the Contribution.
-  
-  4. COMMERCIAL DISTRIBUTION
-  
-  Commercial distributors of software may accept certain responsibilities with
-  respect to end users, business partners and the like. While this license is
-  intended to facilitate the commercial use of the Program, the Contributor who
-  includes the Program in a commercial product offering should do so in a manner
-  which does not create potential liability for other Contributors. Therefore, if
-  a Contributor includes the Program in a commercial product offering, such
-  Contributor ("Commercial Contributor") hereby agrees to defend and indemnify
-  every other Contributor ("Indemnified Contributor") against any losses, damages
-  and costs (collectively "Losses") arising from claims, lawsuits and other legal
-  actions brought by a third party against the Indemnified Contributor to the
-  extent caused by the acts or omissions of such Commercial Contributor in
-  connection with its distribution of the Program in a commercial product
-  offering. The obligations in this section do not apply to any claims or Losses
-  relating to any actual or alleged intellectual property infringement. In order
-  to qualify, an Indemnified Contributor must: a) promptly notify the Commercial
-  Contributor in writing of such claim, and b) allow the Commercial Contributor
-  to control, and cooperate with the Commercial Contributor in, the defense and
-  any related settlement negotiations. The Indemnified Contributor may
-  participate in any such claim at its own expense.
-  
-  For example, a Contributor might include the Program in a commercial product
-  offering, Product X. That Contributor is then a Commercial Contributor. If that
-  Commercial Contributor then makes performance claims, or offers warranties
-  related to Product X, those performance claims and warranties are such
-  Commercial Contributor's responsibility alone. Under this section, the
-  Commercial Contributor would have to defend claims against the other
-  Contributors related to those performance claims and warranties, and if a court
-  requires any other Contributor to pay any damages as a result, the Commercial
-  Contributor must pay those damages.
-  
-  5. NO WARRANTY
-  
-  EXCEPT AS EXPRESSLY SET FORTH IN THIS AGREEMENT, THE PROGRAM IS PROVIDED ON AN
-  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, EITHER EXPRESS OR
-  IMPLIED INCLUDING, WITHOUT LIMITATION, ANY WARRANTIES OR CONDITIONS OF TITLE,
-  NON-INFRINGEMENT, MERCHANTABILITY OR FITNESS FOR A PARTICULAR PURPOSE. Each
-  Recipient is solely responsible for determining the appropriateness of using
-  and distributing the Program and assumes all risks associated with its exercise
-  of rights under this Agreement , including but not limited to the risks and
-  costs of program errors, compliance with applicable laws, damage to or loss of
-  data, programs or equipment, and unavailability or interruption of operations.
-  
-  6. DISCLAIMER OF LIABILITY
-  
-  EXCEPT AS EXPRESSLY SET FORTH IN THIS AGREEMENT, NEITHER RECIPIENT NOR ANY
-  CONTRIBUTORS SHALL HAVE ANY LIABILITY FOR ANY DIRECT, INDIRECT, INCIDENTAL,
-  SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING WITHOUT LIMITATION LOST
-  PROFITS), HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT,
-  STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY
-  WAY OUT OF THE USE OR DISTRIBUTION OF THE PROGRAM OR THE EXERCISE OF ANY RIGHTS
-  GRANTED HEREUNDER, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGES.
-  
-  7. GENERAL
-  
-  If any provision of this Agreement is invalid or unenforceable under applicable
-  law, it shall not affect the validity or enforceability of the remainder of the
-  terms of this Agreement, and without further action by the parties hereto, such
-  provision shall be reformed to the minimum extent necessary to make such
-  provision valid and enforceable.
-  
-  If Recipient institutes patent litigation against any entity (including a
-  cross-claim or counterclaim in a lawsuit) alleging that the Program itself
-  (excluding combinations of the Program with other software or hardware)
-  infringes such Recipient's patent(s), then such Recipient's rights granted
-  under Section 2(b) shall terminate as of the date such litigation is filed.
-  
-  All Recipient's rights under this Agreement shall terminate if it fails to
-  comply with any of the material terms or conditions of this Agreement and does
-  not cure such failure in a reasonable period of time after becoming aware of
-  such noncompliance. If all Recipient's rights under this Agreement terminate,
-  Recipient agrees to cease use and distribution of the Program as soon as
-  reasonably practicable. However, Recipient's obligations under this Agreement
-  and any licenses granted by Recipient relating to the Program shall continue
-  and survive.
-  
-  Everyone is permitted to copy and distribute copies of this Agreement, but in
-  order to avoid inconsistency the Agreement is copyrighted and may only be
-  modified in the following manner. The Agreement Steward reserves the right to
-  publish new versions (including revisions) of this Agreement from time to time.
-  No one other than the Agreement Steward has the right to modify this Agreement.
-  The Eclipse Foundation is the initial Agreement Steward. The Eclipse Foundation
-  may assign the responsibility to serve as the Agreement Steward to a suitable
-  separate entity. Each new version of the Agreement will be given a
-  distinguishing version number. The Program (including Contributions) may always
-  be distributed subject to the version of the Agreement under which it was
-  received. In addition, after a new version of the Agreement is published,
-  Contributor may elect to distribute the Program (including its Contributions)
-  under the new version. Except as expressly stated in Sections 2(a) and 2(b)
-  above, Recipient receives no rights or licenses to the intellectual property of
-  any Contributor under this Agreement, whether expressly, by implication,
-  estoppel or otherwise. All rights in the Program not expressly granted under
-  this Agreement are reserved.
-  
-  This Agreement is governed by the laws of the State of New York and the
-  intellectual property laws of the United States of America. No party to this
-  Agreement will bring a legal action under this Agreement more than one year
-  after the cause of action arose. Each party waives its rights to a jury trial
-  in any resulting litigation.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/binary/MIT
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/MIT b/brooklyn-dist/dist/licensing/licenses/binary/MIT
deleted file mode 100644
index 71dfb45..0000000
--- a/brooklyn-dist/dist/licensing/licenses/binary/MIT
+++ /dev/null
@@ -1,20 +0,0 @@
-The MIT License ("MIT")
-
-  Permission is hereby granted, free of charge, to any person obtaining a copy
-  of this software and associated documentation files (the "Software"), to deal
-  in the Software without restriction, including without limitation the rights
-  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
-  copies of the Software, and to permit persons to whom the Software is
-  furnished to do so, subject to the following conditions:
-  
-  The above copyright notice and this permission notice shall be included in
-  all copies or substantial portions of the Software.
-  
-  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
-  THE SOFTWARE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/binary/WTFPL
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/WTFPL b/brooklyn-dist/dist/licensing/licenses/binary/WTFPL
deleted file mode 100644
index 03c1695..0000000
--- a/brooklyn-dist/dist/licensing/licenses/binary/WTFPL
+++ /dev/null
@@ -1,15 +0,0 @@
-WTF Public License
-
-  DO WHAT THE FUCK YOU WANT TO PUBLIC LICENSE, Version 2, December 2004 
- 
-  Copyright (C) 2004 Sam Hocevar <sa...@hocevar.net> 
- 
-  Everyone is permitted to copy and distribute verbatim or modified 
-  copies of this license document, and changing it is allowed as long 
-  as the name is changed. 
- 
-             DO WHAT THE FUCK YOU WANT TO PUBLIC LICENSE 
-    TERMS AND CONDITIONS FOR COPYING, DISTRIBUTION AND MODIFICATION 
- 
-   0. You just DO WHAT THE FUCK YOU WANT TO.
- 

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/binary/bouncycastle
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/bouncycastle b/brooklyn-dist/dist/licensing/licenses/binary/bouncycastle
deleted file mode 100644
index 8589a0b..0000000
--- a/brooklyn-dist/dist/licensing/licenses/binary/bouncycastle
+++ /dev/null
@@ -1,23 +0,0 @@
-Bouncy Castle License
-  
-  Copyright (c) 2000 - 2015 The Legion of the Bouncy Castle Inc.
-  (http://www.bouncycastle.org)
-  
-  Permission is hereby granted, free of charge, to any person obtaining a copy of
-  this software and associated documentation files (the "Software"), to deal in
-  the Software without restriction, including without limitation the rights to
-  use, copy, modify, merge, publish, distribute, sublicense, and/or sell copies
-  of the Software, and to permit persons to whom the Software is furnished to do
-  so, subject to the following conditions:
-  
-  The above copyright notice and this permission notice shall be included in all
-  copies or substantial portions of the Software.
-  
-  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE
-  SOFTWARE.
-  


[13/51] [abbrv] brooklyn-dist git commit: Merge commit 'e430723' into reorg2

Posted by he...@apache.org.
Merge commit 'e430723' into reorg2

Newer PR's moved to the right place.

Conflicts:
	brooklyn-library/sandbox/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastCluster.java
	brooklyn-library/sandbox/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastClusterImpl.java
	brooklyn-library/sandbox/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastNode.java
	brooklyn-library/sandbox/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastNodeDriver.java
	brooklyn-library/sandbox/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastNodeImpl.java
	brooklyn-library/sandbox/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastNodeSshDriver.java
	brooklyn-library/sandbox/nosql/src/main/resources/org/apache/brooklyn/entity/nosql/hazelcast/hazelcast-brooklyn.xml
	brooklyn-library/sandbox/nosql/src/test/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastClusterEc2LiveTest.java
	brooklyn-library/sandbox/nosql/src/test/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastClusterSoftlayerLiveTest.java
	sandbox/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastCluster.java
	sandbox/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastClusterImpl.java
	sandbox/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastNode.java
	sandbox/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastNodeDriver.java
	sandbox/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastNodeImpl.java
	sandbox/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastNodeSshDriver.java
	sandbox/nosql/src/main/resources/org/apache/brooklyn/entity/nosql/hazelcast/hazelcast-brooklyn.xml
	sandbox/nosql/src/test/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastClusterEc2LiveTest.java
	sandbox/nosql/src/test/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastClusterSoftlayerLiveTest.java
	software/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastCluster.java
	software/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastClusterImpl.java
	software/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastNode.java
	software/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastNodeDriver.java
	software/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastNodeImpl.java
	software/nosql/src/main/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastNodeSshDriver.java
	software/nosql/src/main/resources/org/apache/brooklyn/entity/nosql/hazelcast/hazelcast-brooklyn.xml
	software/nosql/src/test/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastClusterSoftlayerLiveTest.java
	software/nosql/src/test/java/org/apache/brooklyn/entity/nosql/hazelcast/HazelcastTestHelper.java


Project: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/repo
Commit: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/commit/16b72507
Tree: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/tree/16b72507
Diff: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/diff/16b72507

Branch: refs/heads/master
Commit: 16b72507275fa87fe1b1b198c091acb34c27f5ed
Parents: f5c7339 29757ee
Author: Alex Heneveld <al...@cloudsoftcorp.com>
Authored: Mon Dec 21 12:09:30 2015 +0000
Committer: Alex Heneveld <al...@cloudsoftcorp.com>
Committed: Mon Dec 21 12:09:30 2015 +0000

----------------------------------------------------------------------
 brooklyn-dist/.gitattributes                    |    6 +
 brooklyn-dist/.gitignore                        |   32 +
 brooklyn-dist/LICENSE                           |  455 ++++
 brooklyn-dist/NOTICE                            |    5 +
 brooklyn-dist/README.md                         |   21 +
 brooklyn-dist/all/pom.xml                       |  117 +
 brooklyn-dist/archetypes/quickstart/NOTES.txt   |   76 +
 brooklyn-dist/archetypes/quickstart/pom.xml     |  232 ++
 .../quickstart/src/brooklyn-sample/README.md    |   73 +
 .../quickstart/src/brooklyn-sample/pom.xml      |  102 +
 .../src/main/assembly/assembly.xml              |   88 +
 .../src/main/assembly/files/README.txt          |   96 +
 .../src/main/assembly/files/conf/logback.xml    |   11 +
 .../src/main/assembly/scripts/start.sh          |   40 +
 .../com/acme/sample/brooklyn/SampleMain.java    |   81 +
 .../app/ClusterWebServerDatabaseSample.java     |  137 ++
 .../sample/app/SingleWebServerSample.java       |   32 +
 .../src/main/resources/logback-custom.xml       |   10 +
 .../src/main/resources/sample-icon.png          |  Bin 0 -> 46490 bytes
 .../main/resources/visitors-creation-script.sql |   35 +
 .../app/SampleLocalhostIntegrationTest.java     |   81 +
 .../brooklyn/sample/app/SampleUnitTest.java     |   69 +
 .../quickstart/src/main/resources/.gitignore    |    1 +
 .../META-INF/maven/archetype-metadata.xml       |   65 +
 .../projects/integration-test-1/.gitignore      |    1 +
 .../integration-test-1/archetype.properties     |   22 +
 .../projects/integration-test-1/goal.txt        |    1 +
 brooklyn-dist/dist/licensing/.gitignore         |    2 +
 brooklyn-dist/dist/licensing/MAIN_LICENSE_ASL2  |  176 ++
 brooklyn-dist/dist/licensing/README.md          |   78 +
 brooklyn-dist/dist/licensing/extras-files       |    1 +
 .../dist/licensing/licenses/binary/ASL2         |  177 ++
 .../dist/licensing/licenses/binary/BSD-2-Clause |   23 +
 .../dist/licensing/licenses/binary/BSD-3-Clause |   27 +
 .../dist/licensing/licenses/binary/CDDL1        |  381 ++++
 .../dist/licensing/licenses/binary/CDDL1.1      |  304 +++
 .../dist/licensing/licenses/binary/EPL1         |  212 ++
 .../dist/licensing/licenses/binary/MIT          |   20 +
 .../dist/licensing/licenses/binary/WTFPL        |   15 +
 .../dist/licensing/licenses/binary/bouncycastle |   23 +
 .../dist/licensing/licenses/binary/jtidy        |   53 +
 .../dist/licensing/licenses/binary/jython       |   27 +
 .../licenses/binary/metastuff-bsd-style         |   43 +
 .../licenses/binary/xpp3_indiana_university     |   45 +
 brooklyn-dist/dist/licensing/licenses/cli/MIT   |   20 +
 .../dist/licensing/licenses/jsgui/BSD-2-Clause  |   23 +
 .../dist/licensing/licenses/jsgui/BSD-3-Clause  |   27 +
 brooklyn-dist/dist/licensing/licenses/jsgui/MIT |   20 +
 .../dist/licensing/licenses/source/BSD-2-Clause |   23 +
 .../dist/licensing/licenses/source/BSD-3-Clause |   27 +
 .../dist/licensing/licenses/source/MIT          |   20 +
 .../dist/licensing/make-all-licenses.sh         |   61 +
 .../dist/licensing/make-one-license.sh          |   79 +
 brooklyn-dist/dist/licensing/overrides.yaml     |  383 ++++
 .../licensing/projects-with-custom-licenses     |    2 +
 brooklyn-dist/dist/pom.xml                      |  158 ++
 .../dist/src/main/config/build-distribution.xml |   96 +
 .../dist/src/main/dist/bin/.gitattributes       |    3 +
 brooklyn-dist/dist/src/main/dist/bin/brooklyn   |   51 +
 .../dist/src/main/dist/bin/brooklyn.bat         |  111 +
 .../dist/src/main/dist/bin/brooklyn.ps1         |  135 ++
 .../dist/src/main/dist/conf/logback.xml         |   14 +
 brooklyn-dist/dist/src/main/license/README.md   |    2 +
 .../dist/src/main/license/files/DISCLAIMER      |    8 +
 .../dist/src/main/license/files/LICENSE         | 2149 ++++++++++++++++++
 .../dist/src/main/license/files/NOTICE          |    5 +
 .../brooklyn/cli/BaseCliIntegrationTest.java    |  189 ++
 .../apache/brooklyn/cli/CliIntegrationTest.java |  219 ++
 brooklyn-dist/downstream-parent/pom.xml         |  519 +++++
 brooklyn-dist/release/.gitignore                |    2 +
 brooklyn-dist/release/README.md                 |   50 +
 brooklyn-dist/release/Vagrantfile               |   66 +
 brooklyn-dist/release/change-version.sh         |   70 +
 brooklyn-dist/release/gpg-agent.conf            |    2 +
 brooklyn-dist/release/make-release-artifacts.sh |  257 +++
 brooklyn-dist/release/print-vote-email.sh       |  130 ++
 .../release/pull-request-reports/Gemfile        |    5 +
 .../release/pull-request-reports/Gemfile.lock   |   38 +
 .../release/pull-request-reports/pr_report.rb   |   12 +
 brooklyn-dist/release/settings.xml              |   29 +
 brooklyn-dist/scripts/buildAndTest              |  102 +
 brooklyn-dist/scripts/grep-in-poms.sh           |   25 +
 .../scripts/release-branch-from-master          |  114 +
 brooklyn-dist/scripts/release-make              |   83 +
 release/.gitignore                              |    2 -
 release/README.md                               |   50 -
 release/Vagrantfile                             |   66 -
 release/change-version.sh                       |   70 -
 release/gpg-agent.conf                          |    2 -
 release/make-release-artifacts.sh               |  257 ---
 release/print-vote-email.sh                     |  130 --
 release/pull-request-reports/Gemfile            |    5 -
 release/pull-request-reports/Gemfile.lock       |   38 -
 release/pull-request-reports/pr_report.rb       |   12 -
 release/settings.xml                            |   29 -
 usage/all/pom.xml                               |  117 -
 usage/archetypes/quickstart/NOTES.txt           |   76 -
 usage/archetypes/quickstart/pom.xml             |  232 --
 .../quickstart/src/brooklyn-sample/README.md    |   73 -
 .../quickstart/src/brooklyn-sample/pom.xml      |  102 -
 .../src/main/assembly/assembly.xml              |   88 -
 .../src/main/assembly/files/README.txt          |   96 -
 .../src/main/assembly/files/conf/logback.xml    |   11 -
 .../src/main/assembly/scripts/start.sh          |   40 -
 .../com/acme/sample/brooklyn/SampleMain.java    |   81 -
 .../app/ClusterWebServerDatabaseSample.java     |  137 --
 .../sample/app/SingleWebServerSample.java       |   32 -
 .../src/main/resources/logback-custom.xml       |   10 -
 .../src/main/resources/sample-icon.png          |  Bin 46490 -> 0 bytes
 .../main/resources/visitors-creation-script.sql |   35 -
 .../app/SampleLocalhostIntegrationTest.java     |   81 -
 .../brooklyn/sample/app/SampleUnitTest.java     |   69 -
 .../quickstart/src/main/resources/.gitignore    |    1 -
 .../META-INF/maven/archetype-metadata.xml       |   65 -
 .../projects/integration-test-1/.gitignore      |    1 -
 .../integration-test-1/archetype.properties     |   22 -
 .../projects/integration-test-1/goal.txt        |    1 -
 usage/dist/licensing/.gitignore                 |    2 -
 usage/dist/licensing/MAIN_LICENSE_ASL2          |  176 --
 usage/dist/licensing/README.md                  |   78 -
 usage/dist/licensing/extras-files               |    1 -
 usage/dist/licensing/licenses/binary/ASL2       |  177 --
 .../dist/licensing/licenses/binary/BSD-2-Clause |   23 -
 .../dist/licensing/licenses/binary/BSD-3-Clause |   27 -
 usage/dist/licensing/licenses/binary/CDDL1      |  381 ----
 usage/dist/licensing/licenses/binary/CDDL1.1    |  304 ---
 usage/dist/licensing/licenses/binary/EPL1       |  212 --
 usage/dist/licensing/licenses/binary/MIT        |   20 -
 usage/dist/licensing/licenses/binary/WTFPL      |   15 -
 .../dist/licensing/licenses/binary/bouncycastle |   23 -
 usage/dist/licensing/licenses/binary/jtidy      |   53 -
 usage/dist/licensing/licenses/binary/jython     |   27 -
 .../licenses/binary/metastuff-bsd-style         |   43 -
 .../licenses/binary/xpp3_indiana_university     |   45 -
 usage/dist/licensing/licenses/cli/MIT           |   20 -
 .../dist/licensing/licenses/jsgui/BSD-2-Clause  |   23 -
 .../dist/licensing/licenses/jsgui/BSD-3-Clause  |   27 -
 usage/dist/licensing/licenses/jsgui/MIT         |   20 -
 .../dist/licensing/licenses/source/BSD-2-Clause |   23 -
 .../dist/licensing/licenses/source/BSD-3-Clause |   27 -
 usage/dist/licensing/licenses/source/MIT        |   20 -
 usage/dist/licensing/make-all-licenses.sh       |   61 -
 usage/dist/licensing/make-one-license.sh        |   79 -
 usage/dist/licensing/overrides.yaml             |  383 ----
 .../licensing/projects-with-custom-licenses     |    2 -
 usage/dist/pom.xml                              |  158 --
 .../dist/src/main/config/build-distribution.xml |   96 -
 usage/dist/src/main/dist/bin/.gitattributes     |    3 -
 usage/dist/src/main/dist/bin/brooklyn           |   51 -
 usage/dist/src/main/dist/bin/brooklyn.bat       |  111 -
 usage/dist/src/main/dist/bin/brooklyn.ps1       |  135 --
 usage/dist/src/main/dist/conf/logback.xml       |   14 -
 usage/dist/src/main/license/README.md           |    2 -
 usage/dist/src/main/license/files/DISCLAIMER    |    8 -
 usage/dist/src/main/license/files/LICENSE       | 2149 ------------------
 usage/dist/src/main/license/files/NOTICE        |    5 -
 .../brooklyn/cli/BaseCliIntegrationTest.java    |  189 --
 .../apache/brooklyn/cli/CliIntegrationTest.java |  219 --
 usage/downstream-parent/pom.xml                 |  519 -----
 usage/jsgui/src/main/license/files/LICENSE      |  482 ----
 usage/jsgui/src/main/license/files/NOTICE       |    5 -
 usage/jsgui/src/test/license/DISCLAIMER         |    8 -
 usage/jsgui/src/test/license/NOTICE             |    5 -
 usage/scripts/buildAndTest                      |  102 -
 usage/scripts/grep-in-poms.sh                   |   25 -
 usage/scripts/release-branch-from-master        |  114 -
 usage/scripts/release-make                      |   83 -
 167 files changed, 8825 insertions(+), 8806 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/16b72507/brooklyn-dist/downstream-parent/pom.xml
----------------------------------------------------------------------
diff --cc brooklyn-dist/downstream-parent/pom.xml
index 0000000,6580281..c1731fd
mode 000000,100644..100644
--- a/brooklyn-dist/downstream-parent/pom.xml
+++ b/brooklyn-dist/downstream-parent/pom.xml
@@@ -1,0 -1,506 +1,519 @@@
+ <?xml version="1.0" encoding="UTF-8"?>
+ <!--
+     Licensed to the Apache Software Foundation (ASF) under one
+     or more contributor license agreements.  See the NOTICE file
+     distributed with this work for additional information
+     regarding copyright ownership.  The ASF licenses this file
+     to you under the Apache License, Version 2.0 (the
+     "License"); you may not use this file except in compliance
+     with the License.  You may obtain a copy of the License at
+ 
+      http://www.apache.org/licenses/LICENSE-2.0
+ 
+     Unless required by applicable law or agreed to in writing,
+     software distributed under the License is distributed on an
+     "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+     KIND, either express or implied.  See the License for the
+     specific language governing permissions and limitations
+     under the License.
+ -->
+ <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+   <modelVersion>4.0.0</modelVersion>
+ 
+   <parent>
+     <groupId>org.apache.brooklyn</groupId>
+     <artifactId>brooklyn</artifactId>
+     <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+     <relativePath>../../pom.xml</relativePath>
+   </parent>
+ 
+   <artifactId>brooklyn-downstream-parent</artifactId>
+   <packaging>pom</packaging>
+   <name>Brooklyn Downstream Project Parent</name>
+   <description>
+       Parent pom that can be used by downstream projects that use Brooklyn,
+       or that contribute additional functionality to Brooklyn.
+   </description>
+ 
+   <properties>
+     <!-- Compilation -->
+     <java.version>1.7</java.version>
+     <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>
+     <project.reporting.outputEncoding>UTF-8</project.reporting.outputEncoding>
+ 
+     <!-- Testing -->
+     <testng.version>6.8.8</testng.version>
+     <surefire.version>2.18.1</surefire.version>
+     <includedTestGroups />
+     <excludedTestGroups>Integration,Acceptance,Live,Live-sanity,WIP</excludedTestGroups>
+ 
+     <!-- Dependencies -->
+     <brooklyn.version>0.9.0-SNAPSHOT</brooklyn.version>  <!-- BROOKLYN_VERSION -->
+     <jclouds.groupId>org.apache.jclouds</jclouds.groupId> <!-- JCLOUDS_GROUPID_VERSION -->
+ 
+     <!-- versions should match those used by Brooklyn, to avoid conflicts -->
+     <jclouds.version>1.9.1</jclouds.version> <!-- JCLOUDS_VERSION -->
+     <logback.version>1.0.7</logback.version>
+     <slf4j.version>1.6.6</slf4j.version>  <!-- used for java.util.logging jul-to-slf4j interception -->
+     <guava.version>17.0</guava.version>
+     <xstream.version>1.4.7</xstream.version>
+     <jackson.version>1.9.13</jackson.version>  <!-- codehaus jackson, used by brooklyn rest server -->
+     <fasterxml.jackson.version>2.4.5</fasterxml.jackson.version>  <!-- more recent jackson, but not compatible with old annotations! -->
+     <jersey.version>1.19</jersey.version>
+     <httpclient.version>4.4.1</httpclient.version>
+     <commons-lang3.version>3.1</commons-lang3.version>
+     <groovy.version>2.3.7</groovy.version> <!-- Version supported by https://github.com/groovy/groovy-eclipse/wiki/Groovy-Eclipse-2.9.1-Release-Notes -->
+     <jsr305.version>2.0.1</jsr305.version>
+     <snakeyaml.version>1.11</snakeyaml.version>
+   </properties>
+ 
+   <dependencyManagement>
+     <dependencies>
+       <dependency>
+         <!-- this would pull in all brooklyn entities and clouds;
+              you can cherry pick selected ones instead (for a smaller build) -->
+         <groupId>org.apache.brooklyn</groupId>
+         <artifactId>brooklyn-all</artifactId>
+         <version>${brooklyn.version}</version>
+       </dependency>
+     </dependencies>
+   </dependencyManagement>
+ 
+   <dependencies>
+     <dependency>
+       <!-- this gives us flexible and easy-to-use logging; just edit logback-custom.xml! -->
+       <groupId>org.apache.brooklyn</groupId>
+       <artifactId>brooklyn-logback-xml</artifactId>
+       <version>${brooklyn.version}</version>
+       <!-- optional so that this project has logging; dependencies may redeclare or supply their own;
+            provided so that it isn't put into the assembly (as it supplies its own explicit logback.xml);
+            see Logging in the Brooklyn website/userguide for more info -->
+       <optional>true</optional>
+       <scope>provided</scope>
+     </dependency>
+     <dependency>
+       <!-- includes testng and useful logging for tests -->
+       <groupId>org.apache.brooklyn</groupId>
+       <artifactId>brooklyn-test-support</artifactId>
+       <version>${brooklyn.version}</version>
+       <scope>test</scope>
+     </dependency>
+     <dependency>
+       <!-- includes org.apache.brooklyn.test.support.LoggingVerboseReporter -->
+       <groupId>org.apache.brooklyn</groupId>
+       <artifactId>brooklyn-utils-test-support</artifactId>
+       <version>${brooklyn.version}</version>
+       <scope>test</scope>
+     </dependency>
+   </dependencies>
+ 
+   <build>
+     <testSourceDirectory>src/test/java</testSourceDirectory>
+     <testResources>
+       <testResource>
+         <directory>src/test/resources</directory>
+       </testResource>
+     </testResources>
+ 
+     <pluginManagement>
+       <plugins>
+         <plugin>
+           <artifactId>maven-assembly-plugin</artifactId>
+           <version>2.5.4</version>
+           <configuration>
+             <tarLongFileMode>gnu</tarLongFileMode>
+           </configuration>
+         </plugin>
+         <plugin>
+           <artifactId>maven-clean-plugin</artifactId>
+           <version>2.6.1</version>
+         </plugin>
+         <plugin>
+           <artifactId>maven-compiler-plugin</artifactId>
+           <version>3.3</version>
+           <configuration>
+             <source>${java.version}</source>
+             <target>${java.version}</target>
+           </configuration>
+         </plugin>
+         <plugin>
+           <artifactId>maven-deploy-plugin</artifactId>
+           <version>2.8.2</version>
+         </plugin>
+         <plugin>
+           <artifactId>maven-eclipse-plugin</artifactId>
+           <version>2.10</version>
+         </plugin>
+         <plugin>
+           <artifactId>maven-enforcer-plugin</artifactId>
+           <version>1.4</version>
+         </plugin>
+         <plugin>
+           <artifactId>maven-failsafe-plugin</artifactId>
+           <version>2.18.1</version>
+         </plugin>
+         <plugin>
+           <artifactId>maven-gpg-plugin</artifactId>
+           <version>1.6</version>
+         </plugin>
+         <plugin>
+           <artifactId>maven-jar-plugin</artifactId>
+           <version>2.6</version>
+         </plugin>
+         <plugin>
+           <artifactId>maven-javadoc-plugin</artifactId>
+           <version>2.10.3</version>
+         </plugin>
+         <plugin>
+           <artifactId>maven-resources-plugin</artifactId>
+           <version>2.7</version>
+         </plugin>
+         <plugin>
+           <artifactId>maven-source-plugin</artifactId>
+           <version>2.4</version>
+         </plugin>
+         <plugin>
+           <artifactId>maven-surefire-plugin</artifactId>
+           <version>2.18.1</version>
+         </plugin>
+         <plugin>
+           <groupId>org.apache.felix</groupId>
+           <artifactId>maven-bundle-plugin</artifactId>
+           <version>2.3.4</version>
+         </plugin>
+         <!--This plugin's configuration is used to store Eclipse m2e settings only. It has no influence on the Maven build itself.-->
+         <plugin>
+           <groupId>org.eclipse.m2e</groupId>
+           <artifactId>lifecycle-mapping</artifactId>
+           <version>1.0.0</version>
+           <configuration>
+             <lifecycleMappingMetadata>
+               <pluginExecutions>
+                 <pluginExecution>
+                   <pluginExecutionFilter>
+                     <groupId>org.apache.maven.plugins</groupId>
+                     <artifactId>maven-assembly-plugin</artifactId>
+                     <versionRange>[2.4.1,)</versionRange>
+                     <goals>
+                       <goal>single</goal>
+                     </goals>
+                   </pluginExecutionFilter>
+                   <action>
+                     <ignore />
+                   </action>
+                 </pluginExecution>
+                 <pluginExecution>
+                   <pluginExecutionFilter>
+                     <groupId>org.codehaus.mojo</groupId>
+                     <artifactId>build-helper-maven-plugin</artifactId>
+                     <versionRange>[1.7,)</versionRange>
+                     <goals>
+                       <goal>attach-artifact</goal>
+                     </goals>
+                   </pluginExecutionFilter>
+                   <action>
+                     <ignore />
+                   </action>
+                 </pluginExecution>
+                 <pluginExecution>
+                   <pluginExecutionFilter>
+                     <groupId>org.apache.maven.plugins</groupId>
+                     <artifactId>maven-enforcer-plugin</artifactId>
+                     <versionRange>[1.3.1,)</versionRange>
+                     <goals>
+                       <goal>enforce</goal>
+                     </goals>
+                   </pluginExecutionFilter>
+                   <action>
+                     <ignore />
+                   </action>
+                 </pluginExecution>
+                 <pluginExecution>
+                   <pluginExecutionFilter>
+                     <groupId>org.apache.maven.plugins</groupId>
+                     <artifactId>maven-remote-resources-plugin</artifactId>
+                     <versionRange>[1.5,)</versionRange>
+                     <goals>
+                       <goal>process</goal>
+                     </goals>
+                   </pluginExecutionFilter>
+                   <action>
+                     <ignore />
+                   </action>
+                 </pluginExecution>
+                 <pluginExecution>
+                   <pluginExecutionFilter>
+                     <groupId>org.apache.maven.plugins</groupId>
+                     <artifactId>maven-dependency-plugin</artifactId>
+                     <versionRange>[2.8,)</versionRange>
+                     <goals>
+                       <goal>unpack</goal>
+                       <goal>copy</goal>
+                     </goals>
+                   </pluginExecutionFilter>
+                   <action>
+                     <ignore />
+                   </action>
+                 </pluginExecution>
+                 <pluginExecution>
+                   <pluginExecutionFilter>
+                     <groupId>com.github.skwakman.nodejs-maven-plugin</groupId>
+                     <artifactId>nodejs-maven-plugin</artifactId>
+                     <versionRange>[1.0.3,)</versionRange>
+                     <goals>
+                       <goal>extract</goal>
+                     </goals>
+                   </pluginExecutionFilter>
+                   <action>
+                     <ignore />
+                   </action>
+                 </pluginExecution>
+                 <pluginExecution>
+                   <pluginExecutionFilter>
+                     <groupId>org.apache.maven.plugins</groupId>
+                     <artifactId>maven-war-plugin</artifactId>
+                     <versionRange>[2.4,)</versionRange>
+                     <goals>
+                       <goal>exploded</goal>
+                     </goals>
+                   </pluginExecutionFilter>
+                   <action>
+                     <ignore />
+                   </action>
+                 </pluginExecution>
+               </pluginExecutions>
+              </lifecycleMappingMetadata>
+            </configuration>
+         </plugin>
+       </plugins>
+     </pluginManagement>
+ 
+     <plugins>
+       <plugin>
+         <artifactId>maven-clean-plugin</artifactId>
+         <configuration>
+           <filesets>
+             <fileset>
+               <directory>.</directory>
+               <includes>
+                 <include>brooklyn*.log</include>
+                 <include>brooklyn*.log.*</include>
+                 <include>stacktrace.log</include>
+                 <include>test-output</include>
+                 <include>prodDb.*</include>
+               </includes>
+             </fileset>
+           </filesets>
+         </configuration>
+       </plugin>
+ 
+       <plugin>
+         <artifactId>maven-resources-plugin</artifactId>
+       </plugin>
+ 
+       <plugin>
+         <artifactId>maven-eclipse-plugin</artifactId>
+         <configuration>
+           <additionalProjectnatures>
+             <projectnature>org.maven.ide.eclipse.maven2Nature</projectnature>
+           </additionalProjectnatures>
+         </configuration>
+       </plugin>
+ 
+       <plugin>
+         <artifactId>maven-surefire-plugin</artifactId>
+         <configuration>
+           <argLine>-Xms256m -Xmx512m -XX:MaxPermSize=512m</argLine>
+           <properties>
+             <property>
+               <name>listener</name>
+               <value>org.apache.brooklyn.test.support.LoggingVerboseReporter</value>
+             </property>
+           </properties>
+           <enableAssertions>true</enableAssertions>
+           <groups>${includedTestGroups}</groups>
+           <excludedGroups>${excludedTestGroups}</excludedGroups>
+           <testFailureIgnore>false</testFailureIgnore>
+           <systemPropertyVariables>
+             <verbose>-1</verbose>
+             <net.sourceforge.cobertura.datafile>${project.build.directory}/cobertura/cobertura.ser</net.sourceforge.cobertura.datafile>
+             <cobertura.user.java.nio>false</cobertura.user.java.nio>
+           </systemPropertyVariables>
+           <printSummary>true</printSummary>
+         </configuration>
+       </plugin>
+     </plugins>
+   </build>
+ 
+   <profiles>
+ 
+     <profile>
+       <id>Tests</id>
+       <activation>
+         <file> <exists>${basedir}/src/test</exists> </file>
+       </activation>
+       <build>
+         <plugins>
+           <plugin>
+             <artifactId>maven-jar-plugin</artifactId>
+             <inherited>true</inherited>
+             <executions>
+               <execution>
+                 <id>test-jar-creation</id>
+                 <goals>
+                   <goal>test-jar</goal>
+                 </goals>
+                 <configuration>
+                   <forceCreation>true</forceCreation>
+                   <archive combine.self="override" />
+                 </configuration>
+               </execution>
+             </executions>
+           </plugin>
+         </plugins>
+       </build>
+     </profile>
+ 
+     <!-- run Integration tests with -PIntegration -->
+     <profile>
+       <id>Integration</id>
+       <properties>
+         <includedTestGroups>Integration</includedTestGroups>
+         <excludedTestGroups>Acceptance,Live,Live-sanity,WIP</excludedTestGroups>
+       </properties>
+     </profile>
+ 
+     <!-- run Live tests with -PLive -->
+     <profile>
+       <id>Live</id>
+       <properties>
+         <includedTestGroups>Live,Live-sanity</includedTestGroups>
+         <excludedTestGroups>Acceptance,WIP</excludedTestGroups>
+       </properties>
+     </profile>
+ 
+     <!-- run Live-sanity tests with -PLive-sanity -->
+     <profile>
+       <id>Live-sanity</id>
+       <properties>
+         <includedTestGroups>Live-sanity</includedTestGroups>
+         <excludedTestGroups>Acceptance,WIP</excludedTestGroups>
+       </properties>
+       <build>
+         <plugins>
+           <plugin>
+             <artifactId>maven-jar-plugin</artifactId>
+             <executions>
+               <execution>
+                 <id>test-jar-creation</id>
+                 <configuration>
+                   <skip>true</skip>
+                 </configuration>
+               </execution>
+             </executions>
+           </plugin>
+         </plugins>
+       </build>
+     </profile>
+ 
+     <profile>
+       <id>Bundle</id>
+       <activation>
+         <file>
+           <!-- NB - this is all the leaf projects, including logback-* (with no src);
+                the archetype project neatly ignores this however -->
+           <exists>${basedir}/src</exists>
+         </file>
+       </activation>
+       <build>
+         <plugins>
+           <plugin>
+             <groupId>org.apache.felix</groupId>
+             <artifactId>maven-bundle-plugin</artifactId>
+             <extensions>true</extensions>
+             <!-- configure plugin to generate MANIFEST.MF
+                  adapted from http://blog.knowhowlab.org/2010/06/osgi-tutorial-from-project-structure-to.html -->
+             <executions>
+               <execution>
+                 <id>bundle-manifest</id>
+                 <phase>process-classes</phase>
+                 <goals>
+                   <goal>manifest</goal>
+                 </goals>
+               </execution>
+             </executions>
+             <configuration>
+               <supportedProjectTypes>
+                 <supportedProjectType>jar</supportedProjectType>
+               </supportedProjectTypes>
+               <instructions>
 -                <!-- OSGi specific instruction -->
+                 <!--
 -                    By default packages containing impl and internal
 -                    are not included in the export list. Setting an
 -                    explicit wildcard will include all packages
 -                    regardless of name.
 -                    In time we should minimize our export lists to
 -                    what is really needed.
++                  Exclude packages used by Brooklyn that are not OSGi bundles. Including any
++                  of the below may cause bundles to fail to load into the catalogue with
++                  messages like "Unable to resolve 150.0: missing requirement [150.0]
++                  osgi.wiring.package; (osgi.wiring.package=com.maxmind.geoip2)".
++                -->
++                <Import-Package>
++                  !com.maxmind.geoip2.*,
++                  !io.airlift.command.*,
++                  !io.cloudsoft.winrm4j.*,
++                  !javax.inject.*,
++                  !org.apache.felix.framework.*,
++                  !org.apache.http.*,
++                  !org.jclouds.googlecomputeengine.*,
++                  !org.osgi.jmx,
++                  !org.python.*,
++                  !org.reflections.*,
++                  !org.w3c.tidy.*,
++                  *
++                </Import-Package>
++                <!--
++                  Brooklyn-Feature prefix triggers inclusion of the project's metadata in the
++                  server's features list.
+                 -->
 -                <Export-Package>brooklyn.*,org.apache.brooklyn.*</Export-Package>
 -                <!-- Brooklyn-Feature prefix triggers inclusion of the project's metadata in the server's features list. -->
+                 <Brooklyn-Feature-Name>${project.name}</Brooklyn-Feature-Name>
+               </instructions>
+             </configuration>
+           </plugin>
+           <plugin>
+             <groupId>org.apache.maven.plugins</groupId>
+             <artifactId>maven-jar-plugin</artifactId>
+             <configuration>
+               <archive>
+                 <manifestFile>${project.build.outputDirectory}/META-INF/MANIFEST.MF</manifestFile>
+               </archive>
+             </configuration>
+           </plugin>
+         </plugins>
+       </build>
+     </profile>
+ 
+     <!-- different properties used to deploy to different locations depending on profiles;
+          default is cloudsoft filesystem repo, but some sources still use cloudsoft artifactory as source
+          and soon we will support artifactory. use this profile for the ASF repositories and
+          sonatype-oss-release profile for the Sonatype OSS repositories.
+     -->
+     <!-- profile>
+       <id>apache-release</id>
+       <activation>
+         <property>
+           <name>brooklyn.deployTo</name>
+           <value>apache</value>
+         </property>
+       </activation>
+       <distributionManagement>
+         <repository>
+           <id>apache.releases.https</id>
+           <name>Apache Release Distribution Repository</name>
+           <url>https://repository.apache.org/service/local/staging/deploy/maven2</url>
+         </repository>
+         <snapshotRepository>
+           <id>apache.snapshots.https</id>
+           <name>Apache Development Snapshot Repository</name>
+           <url>https://repository.apache.org/content/repositories/snapshots</url>
+         </snapshotRepository>
+       </distributionManagement>
+     </profile -->
+   </profiles>
+ 
+ </project>


[24/51] [abbrv] brooklyn-dist git commit: update licenses with latest metadata and dependencies

Posted by he...@apache.org.
update licenses with latest metadata and dependencies


Project: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/repo
Commit: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/commit/04235abb
Tree: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/tree/04235abb
Diff: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/diff/04235abb

Branch: refs/heads/master
Commit: 04235abbf0585cae60f8326caacb8af4b2e3f065
Parents: f61d6ac
Author: Alex Heneveld <al...@cloudsoftcorp.com>
Authored: Fri Jan 15 15:07:50 2016 +0000
Committer: Alex Heneveld <al...@cloudsoftcorp.com>
Committed: Fri Jan 15 15:07:50 2016 +0000

----------------------------------------------------------------------
 LICENSE                                         | 23 +++--
 .../dist/src/main/license/files/LICENSE         | 88 +++++++++++++-------
 2 files changed, 67 insertions(+), 44 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/04235abb/LICENSE
----------------------------------------------------------------------
diff --git a/LICENSE b/LICENSE
index ca60394..ef288dc 100644
--- a/LICENSE
+++ b/LICENSE
@@ -282,6 +282,13 @@ This project includes the software: js-yaml.js
   Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
   Copyright (c) Vitaly Puzrin (2011-2015)
 
+This project includes the software: marked.js
+  Available at: https://github.com/chjj/marked
+  Developed by: Christopher Jeffrey (https://github.com/chjj)
+  Version used: 0.3.1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Christopher Jeffrey (2011-2014)
+
 This project includes the software: moment.js
   Available at: http://momentjs.com
   Developed by: Tim Wood (http://momentjs.com)
@@ -323,19 +330,11 @@ This project includes the software: RequireJS (r.js maven plugin)
       Arpad Borsos (2012)
     Used under the BSD 2-Clause license.
 
-This project includes the software: Swagger JS
-  Available at: https://github.com/wordnik/swagger-js
-  Inclusive of: swagger.js
-  Version used: 1.0.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-  Copyright (c) SmartBear Software (2011-2015)
+This project includes the software: swagger
+  Used under the following license: <no license info>
 
-This project includes the software: Swagger UI
-  Available at: https://github.com/wordnik/swagger-ui
-  Inclusive of: swagger-ui.js
-  Version used: 1.0.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-  Copyright (c) SmartBear Software (2011-2015)
+This project includes the software: swagger-ui
+  Used under the following license: <no license info>
 
 This project includes the software: typeahead.js
   Available at: https://github.com/twitter/typeahead.js

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/04235abb/brooklyn-dist/dist/src/main/license/files/LICENSE
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/license/files/LICENSE b/brooklyn-dist/dist/src/main/license/files/LICENSE
index b280a7d..39db9db 100644
--- a/brooklyn-dist/dist/src/main/license/files/LICENSE
+++ b/brooklyn-dist/dist/src/main/license/files/LICENSE
@@ -232,21 +232,33 @@ This project includes the software: ch.qos.logback
   Used under the following license: Eclipse Public License, version 1.0 (http://www.eclipse.org/legal/epl-v10.html)
 
 This project includes the software: com.fasterxml.jackson.core
-  Available at: http://wiki.fasterxml.com/JacksonHome
+  Available at: http://github.com/FasterXML/jackson https://github.com/FasterXML/jackson
+  Developed by: FasterXML (http://fasterxml.com/)
+  Version used: 2.4.5
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.fasterxml.jackson.dataformat
+  Available at: https://github.com/FasterXML/jackson http://wiki.fasterxml.com/JacksonExtensionXmlDataBinding
+  Developed by: FasterXML (http://fasterxml.com/)
+  Version used: 2.4.5
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.fasterxml.jackson.datatype
+  Available at: http://wiki.fasterxml.com/JacksonModuleJoda
   Developed by: FasterXML (http://fasterxml.com/)
-  Version used: 2.4.2; 2.4.0
+  Version used: 2.4.5
   Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
 
 This project includes the software: com.fasterxml.jackson.jaxrs
   Available at: http://wiki.fasterxml.com/JacksonHome
   Developed by: FasterXML (http://fasterxml.com/)
-  Version used: 2.4.2
+  Version used: 2.4.5
   Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
 
 This project includes the software: com.fasterxml.jackson.module
   Available at: http://wiki.fasterxml.com/JacksonJAXBAnnotations
   Developed by: FasterXML (http://fasterxml.com/)
-  Version used: 2.4.2
+  Version used: 2.4.5
   Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
 
 This project includes the software: com.google.code.findbugs
@@ -329,13 +341,13 @@ This project includes the software: com.squareup.okio
 This project includes the software: com.sun.jersey
   Available at: https://jersey.java.net/
   Developed by: Oracle Corporation (http://www.oracle.com/)
-  Version used: 1.18.1
+  Version used: 1.19
   Used under the following license: Common Development and Distribution License, version 1.1 (http://glassfish.java.net/public/CDDL+GPL_1_1.html)
 
 This project includes the software: com.sun.jersey.contribs
   Available at: https://jersey.java.net/
   Developed by: Oracle Corporation (http://www.oracle.com/)
-  Version used: 1.18.1
+  Version used: 1.19
   Used under the following license: Common Development and Distribution License, version 1.1 (http://glassfish.java.net/public/CDDL+GPL_1_1.html)
 
 This project includes the software: com.thoughtworks.xstream
@@ -344,11 +356,6 @@ This project includes the software: com.thoughtworks.xstream
   Version used: 1.4.7
   Used under the following license: BSD License (http://xstream.codehaus.org/license.html)
 
-This project includes the software: com.wordnik
-  Available at: https://github.com/wordnik/swagger-core
-  Version used: 1.0.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.html)
-
 This project includes the software: commons-beanutils
   Available at: http://commons.apache.org/proper/commons-beanutils/
   Developed by: The Apache Software Foundation (http://www.apache.org/)
@@ -409,6 +416,11 @@ This project includes the software: io.cloudsoft.windows
   Version used: 0.1.0
   Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
 
+This project includes the software: io.swagger
+  Available at: https://github.com/swagger-api/swagger-core
+  Version used: 1.5.3
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.html)
+
 This project includes the software: javax.annotation
   Available at: https://jcp.org/en/jsr/detail?id=250
   Version used: 1.0
@@ -426,8 +438,9 @@ This project includes the software: javax.servlet
   Used under the following license: CDDL + GPLv2 with classpath exception (https://glassfish.dev.java.net/nonav/public/CDDL+GPL.html)
 
 This project includes the software: javax.validation
-  Version used: 1.0.0.GA
-  Used under the following license: Apache License, version 2.0 (in-project reference: license.txt)
+  Available at: http://beanvalidation.org
+  Version used: 1.1.0.Final
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
 
 This project includes the software: javax.ws.rs
   Available at: https://jsr311.java.net/
@@ -435,6 +448,12 @@ This project includes the software: javax.ws.rs
   Version used: 1.1.1
   Used under the following license: CDDL License (http://www.opensource.org/licenses/cddl1.php)
 
+This project includes the software: joda-time
+  Available at: http://joda-time.sourceforge.net
+  Developed by: Joda.org (http://www.joda.org)
+  Version used: 2.2
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
 This project includes the software: jQuery JavaScript Library
   Available at: http://jquery.com/
   Developed by: The jQuery Foundation (http://jquery.org/)
@@ -495,6 +514,13 @@ This project includes the software: js-yaml.js
   Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
   Copyright (c) Vitaly Puzrin (2011-2015)
 
+This project includes the software: marked.js
+  Available at: https://github.com/chjj/marked
+  Developed by: Christopher Jeffrey (https://github.com/chjj)
+  Version used: 0.3.1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Christopher Jeffrey (2011-2014)
+
 This project includes the software: moment.js
   Available at: http://momentjs.com
   Developed by: Tim Wood (http://momentjs.com)
@@ -532,7 +558,7 @@ This project includes the software: org.99soft.guice
 This project includes the software: org.apache.commons
   Available at: http://commons.apache.org/
   Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 3.1; 1.4
+  Version used: 3.3.2; 1.4
   Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
 
 This project includes the software: org.apache.felix
@@ -604,12 +630,24 @@ This project includes the software: org.codehaus.jettison
   Version used: 1.1
   Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
 
+This project includes the software: org.codehaus.woodstox
+  Available at: http://wiki.fasterxml.com/WoodstoxStax2
+  Developed by: fasterxml.com (http://fasterxml.com)
+  Version used: 3.1.4
+  Used under the following license: BSD License (http://www.opensource.org/licenses/bsd-license.php)
+
 This project includes the software: org.eclipse.jetty
   Available at: http://www.eclipse.org/jetty
   Developed by: Webtide (http://webtide.com)
   Version used: 9.2.13.v20150730
   Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
 
+This project includes the software: org.eclipse.jetty.toolchain
+  Available at: http://www.eclipse.org/jetty
+  Developed by: Mort Bay Consulting (http://www.mortbay.com)
+  Version used: 3.1.M0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+
 This project includes the software: org.freemarker
   Available at: http://freemarker.org/
   Version used: 2.3.22
@@ -650,12 +688,6 @@ This project includes the software: org.reflections
   Version used: 0.9.9-RC1
   Used under the following license: WTFPL (http://www.wtfpl.net/)
 
-This project includes the software: org.scala-lang
-  Available at: http://www.scala-lang.org/
-  Developed by: LAMP/EPFL (http://lamp.epfl.ch/)
-  Version used: 2.9.1-1
-  Used under the following license: BSD License (http://www.scala-lang.org/downloads/license.html)
-
 This project includes the software: org.slf4j
   Available at: http://www.slf4j.org
   Developed by: QOS.ch (http://www.qos.ch)
@@ -706,19 +738,11 @@ This project includes the software: RequireJS (r.js maven plugin)
       Arpad Borsos (2012)
     Used under the BSD 2-Clause license.
 
-This project includes the software: Swagger JS
-  Available at: https://github.com/wordnik/swagger-js
-  Inclusive of: swagger.js
-  Version used: 1.0.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-  Copyright (c) SmartBear Software (2011-2015)
+This project includes the software: swagger
+  Used under the following license: <no license info>
 
-This project includes the software: Swagger UI
-  Available at: https://github.com/wordnik/swagger-ui
-  Inclusive of: swagger-ui.js
-  Version used: 1.0.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-  Copyright (c) SmartBear Software (2011-2015)
+This project includes the software: swagger-ui
+  Used under the following license: <no license info>
 
 This project includes the software: typeahead.js
   Available at: https://github.com/twitter/typeahead.js


[29/51] [abbrv] brooklyn-dist git commit: load locations from catalog, strip unnecessary properties - vagrant-catalog.bom loaded on startup in the systemd service unit

Posted by he...@apache.org.
load locations from catalog, strip unnecessary properties
- vagrant-catalog.bom loaded on startup in the systemd service unit


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

Branch: refs/heads/master
Commit: c81f48359d899ff071c838f084ca15a37dae9bea
Parents: e9fd416
Author: John McCabe <jo...@johnmccabe.net>
Authored: Fri Jan 22 15:48:14 2016 +0000
Committer: John McCabe <jo...@johnmccabe.net>
Committed: Fri Jan 22 15:48:14 2016 +0000

----------------------------------------------------------------------
 .../src/main/vagrant/files/brooklyn.properties  | 323 +------------------
 .../src/main/vagrant/files/brooklyn.service     |   2 +-
 .../src/main/vagrant/files/vagrant-catalog.bom  |  82 +++++
 3 files changed, 84 insertions(+), 323 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/c81f4835/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties b/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties
index e68f9a6..22f8688 100644
--- a/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties
+++ b/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.properties
@@ -1,325 +1,4 @@
-#
-# 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.
-#
-# This is Brooklyn's dot-properties file.
-# It should be located at "~/.brooklyn/brooklyn.properties" for automatic loading,
-# or can be specified as a CLI option with --localProperties /path/to/these.properties.
-
-##################################  Welcome!  ############################################
-
-# It's great to have you here.
-
-# Getting Started options have been pulled to the top. There's a formatting guide at the
-# very bottom.
-
-############################ Getting Started Options  ####################################
-
-## GUI Security
-
-## NOTE: in production it is highly recommended to set this, as otherwise it will not require login,
-## not will it be encrypted (though for safety if security is not set it will only bind to loopback)
-
-## Edit the name(s) and passwords as appropriate to your system:
-
-# brooklyn.webconsole.security.users=admin,bob
-# brooklyn.webconsole.security.user.admin.password=password
-# brooklyn.webconsole.security.user.bob.password=bobsword
-
-## If you prefer to run with https (on port 8443 by default), uncomment this:
-
-# brooklyn.webconsole.security.https.required=true
-
-
-# By default we have AWS set up (but with invalid credentials!).  Many, many other
-# providers are supported.
-
-## Amazon EC2 Credentials
-# These should be an "Access Key ID" and "Secret Access Key" for your account.
-# This is configured at https://console.aws.amazon.com/iam/home?#security_credential .
-
-brooklyn.location.jclouds.aws-ec2.identity = AKA_YOUR_ACCESS_KEY_ID
-brooklyn.location.jclouds.aws-ec2.credential = <access-key-hex-digits>
-
-# Beware of trailing spaces in your cloud credentials. This will cause unexpected
-# 401: unauthorized responses.
-
-## Using Other Clouds
-# 1. Cast your eyes down this document to find your preferred cloud in the Named Locations
-#    section, and the examples.
-# 2. Uncomment the relevant line(s) for your provider.
-# 3. ADD  -.identity and -.credential lines for your provider, similar to the AWS ones above,
-#    replacing 'aws-ec2' with jcloud's id for your cloud.
-
-
-## Deploying to Localhost
-## see: info on locations at brooklyn.io
-#
-## ~/.ssh/id_rsa is Brooklyn's default location
-# brooklyn.location.localhost.privateKeyFile = ~/.ssh/id_rsa
-## Passphrases are supported, but not required
-# brooklyn.location.localhost.privateKeyPassphrase = s3cr3tpassphrase
-
-## Geoscaling Service - used for the Global Web Fabric demo
-## see: the global web example at brooklyn.io
-## https://www.geoscaling.com/dns2/
-## other services may take similar configuration similarly; or can usually be set in YAML
-# brooklyn.geoscaling.username = USERNAME
-# brooklyn.geoscaling.password = PASSWORD
-# brooklyn.geoscaling.primaryDomain = DOMAIN
-
-
-##########################  Getting Started Complete!  ###################################
-
-# That's it, although you may want to read through these options...
-
-################################ Brooklyn Options ########################################
-
-## Brooklyn Management Base Directory: specify where management data should be stored on this server;
-## ~/.brooklyn/ is the default but you could use something like /opt/brooklyn/state/
-## (provided this process has write permissions)
-# brooklyn.base.dir=~/.brooklyn/
-
-## Brooklyn On-Box Directory: specify where data should be stored on managed hosts;
-## for most locations a directory off home is the default (but using /tmp/brooklyn-user/ on localhost),
-## however you could specify something like /opt/brooklyn-managed-process/ (creation and permissions are handled)
-# onbox.base.dir=~/brooklyn-managed-process/
-
-## Additional security: Allow all - if you know what you are doing!
-## (Or you can also plug in e.g. LDAP security etc here)
 # Disabling security on the Vagrant Brooklyn instance for training purposes
 brooklyn.webconsole.security.provider = org.apache.brooklyn.rest.security.provider.AnyoneSecurityProvider
 
-## Optionally disallow deployment to localhost (or any other location)
-# brooklyn.location.localhost.enabled=false
-
-## Scripting Behaviour
-
-## keep scripts around after running them (usually in /tmp)
-# brooklyn.ssh.config.noDeleteAfterExec = true
-
-## Misc Cloud Settings
-## brooklyn will fail a node if the cloud machine doesn't come up, but you can tell it to retry:
-# brooklyn.location.jclouds.machineCreateAttempts = 3
-## many cloud machines don't have sufficient entropy for lots of encrypted networking, so fake it:
-# brooklyn.location.jclouds.installDevUrandom=true
-
-## Sets a minimium ram property for all jclouds locations. Recommended to avoid getting m1.micros on AWS!
-brooklyn.location.jclouds.minRam = 2048
-
-## When setting up a new cloud machine Brooklyn creates a user with the same name as the user running
-## Brooklyn on the management server, but you can force a different user here:
-# brooklyn.location.jclouds.user=brooklyn
-## And you can force a password or key (by default it will use the keys in ~/.ssh/id_rsa{,.pub}
-# brooklyn.location.jclouds.password=s3cr3t
-
-################################ Named Locations ########################################
-
-# Named locations appear in the web console. If using the command line or YAML it may be
-# just as easy to use the jclouds:<provider> locations and specify additional properties there.
-
-## Example: AWS Virginia using Rightscale 6.3 64bit Centos AMI and Large Instances
-# brooklyn.location.named.aws-va-centos-large = jclouds:aws-ec2:us-east-1
-# brooklyn.location.named.aws-va-centos-large.imageId=us-east-1/ami-7d7bfc14
-# brooklyn.location.named.aws-va-centos-large.user=brooklyn
-# brooklyn.location.named.aws-va-centos-large.minRam=4096
-
-## You can also nest these:
-# brooklyn.location.named.aws-acct-two = jclouds:aws-ec2
-# brooklyn.location.named.aws-acct-two.identity = AKA_ACCT_TWO
-# brooklyn.location.named.aws-acct-two.credential = <access-key-hex-digits>
-# brooklyn.location.named.aws-acct-two-singapore = named:aws-acct-two
-# brooklyn.location.named.aws-acct-two-singapore.region = ap-southeast-1
-# brooklyn.location.named.aws-acct-two-singapore.displayName = AWS Singapore (Acct Two)
-
-# For convenience some common defaults:
-brooklyn.location.named.aws-california = jclouds:aws-ec2:us-west-1
-brooklyn.location.named.aws-oregon = jclouds:aws-ec2:us-west-2
-brooklyn.location.named.aws-ireland = jclouds:aws-ec2:eu-west-1
-brooklyn.location.named.aws-tokyo = jclouds:aws-ec2:ap-northeast-1
-
-## Google Compute
-## The credentials for GCE come from the "APIs & auth -> Credentials" page,
-## creating a "Service Account" of type JSON, then extracting
-## the client_email as the identity and private_key as the identity,
-## keeping new lines as \n (exactly as in the JSON supplied)
-# brooklyn.location.jclouds.google-compute-engine.identity=1234567890-somet1mesArand0mU1Dhere@developer.gserviceaccount.com
-# brooklyn.location.jclouds.google-compute-engine.credential=-----BEGIN PRIVATE KEY----- \nMIIblahablahblah \nblahblahblah \n-----END PRIVATE KEY-----
-# brooklyn.location.named.Google\ US = jclouds:google-compute-engine
-# brooklyn.location.named.Google\ US.region=us-central1-a
-# brooklyn.location.named.Google\ EU = jclouds:google-compute-engine
-# brooklyn.location.named.Google\ EU.region=europe-west1-a
-## the following flags for GCE are recommended
-## specify the network to use - otherwise it creates new networks each time and you hit quotas pretty quickly
-## you may have to manually create this network AND enable a firewall rule EG  tcp:1-65535;udp:1-65535;icmp
-## (fix for this is in progress)
-# brooklyn.location.jclouds.google-compute-engine.networkName=brooklyn-default-network
-## gce images have bad entropy, this ensures they have noisy /dev/random (even if the "randomness" is not quite as random)
-# brooklyn.location.jclouds.google-compute-engine.installDevUrandom=true
-## gce images often start with iptables turned on; turn it off unless your blueprints are iptables-aware
-# brooklyn.location.jclouds.google-compute-engine.stopIptables=true
-
-## HP Cloud - also Ubuntu 12.04 LTS
-## You specify your HP Credentials like this:
-# brooklyn.location.jclouds.hpcloud-compute.identity = projectname:username
-# brooklyn.location.jclouds.hpcloud-compute.credential = password
-## where username and password are the same as logging in to the web console, and
-## projectname can be found here: https://account.hpcloud.com/projects
-#�brooklyn.location.named.HP\ Cloud\ Arizona-1 = jclouds:hpcloud-compute:az-1.region-a.geo-1
-# brooklyn.location.named.HP\ Cloud\ Arizona-1.imageId = az-1.region-a.geo-1/75845
-# brooklyn.location.named.HP\ Cloud\ Arizona-1.user = ubuntu
-
-## Softlayer - need a key from the gui, under "administrative -> user administration -> api-access
-# brooklyn.location.jclouds.softlayer.identity=username
-# brooklyn.location.jclouds.softlayer.credential=<private-key-hex-digits>
-## locations
-# brooklyn.location.named.Softlayer\ Dallas=jclouds:softlayer:dal05
-# brooklyn.location.named.Softlayer\ Seattle=jclouds:softlayer:sea01
-# brooklyn.location.named.Softlayer\ Washington\ DC=jclouds:softlayer:wdc01
-# brooklyn.location.named.Softlayer\ Singapore\ 1=jclouds:softlayer:sng01
-# brooklyn.location.named.Softlayer\ Amsterdam\ 1=jclouds:softlayer:ams01
-
-
-## Brooklyn uses the jclouds multi-cloud library to access many clouds.
-## http://www.jclouds.org/documentation/reference/supported-providers/
-
-## Templates for many other clouds, but remember to add identity and credentials:
-
-# brooklyn.location.named.Bluelock = jclouds:bluelock-vcloud-zone01
-
-# brooklyn.location.named.CloudSigma\ Nevada = jclouds:cloudsigma-lvs
-# brooklyn.location.named.CloudSigma\ Zurich = jclouds:cloudsigma-zrh
-
-# brooklyn.location.named.ElasticHosts\ London = jclouds:elastichosts-lon-p
-# brooklyn.location.named.ElasticHosts\ Texas = jclouds:elastichosts-sat-p
-
-# brooklyn.location.named.GleSYS = jclouds:glesys
-
-# brooklyn.location.named.Go2Cloud = jclouds:go2cloud-jhb1
-
-# brooklyn.location.named.GoGrid = jclouds:gogrid
-
-# brooklyn.location.named.Green\ House\ Data = jclouds:greenhousedata-element-vcloud
-
-# brooklyn.location.named.Ninefold = jclouds:ninefold-compute
-
-# brooklyn.location.named.OpenHosting = jclouds:openhosting-east1
-
-# brooklyn.location.named.Rackspace\ Chicago\ (ord) = jclouds:rackspace-cloudservers-us:ORD
-# brooklyn.location.named.Rackspace\ Dallas\ (dfw) = jclouds:rackspace-cloudservers-us:DFW
-# brooklyn.location.named.Rackspace\ Hong\ Kong\ (hkg) = jclouds:rackspace-cloudservers-us:HKG
-# brooklyn.location.named.Rackspace\ Northern\ Virginia\ (iad) = jclouds:rackspace-cloudservers-us:IAD
-# brooklyn.location.named.Rackspace\ Sydney\ (syd) = jclouds:rackspace-cloudservers-us:SYD
-## for UK you will need a separate account with rackspace.co.uk
-# brooklyn.location.named.Rackspace\ London\ (lon) = jclouds:rackspace-cloudservers-uk
-
-## if you need to use Rackspace "first gen" API
-## (note the "next gen" api configured above seems to be faster)
-# brooklyn.location.jclouds.cloudservers-us.identity = YOURAPIKEY
-# brooklyn.location.jclouds.cloudservers-us.credential = YOURSECRETKEY
-# brooklyn.location.named.Rackspace\ US\ (First Gen) = jclouds:cloudservers-us
-## and as with next gen, first gen requires a separate acct for the UK:
-# brooklyn.location.jclouds.cloudservers-uk.identity = YOURAPIKEY
-# brooklyn.location.jclouds.cloudservers-uk.credential = YOURSECRETKEY
-# brooklyn.location.named.Rackspace\ UK\ (First Gen) = jclouds:cloudservers-uk
-
-# brooklyn.location.named.SeverLove = jclouds:serverlove-z1-man
-
-# brooklyn.location.named.SkaliCloud = jclouds:skalicloud-sdg-my
-
-# brooklyn.location.named.Stratogen = jclouds:stratogen-vcloud-mycloud
-
-# brooklyn.location.named.TryStack\ (Openstack) = jclouds:trystack-nova
-
-
-## Production pool of machines for my application (deploy to named:On-Prem\ Iron\ Example)
-# brooklyn.location.named.On-Prem\ Iron\ Example=byon:(hosts="10.9.1.1,10.9.1.2,produser2@10.9.2.{10,11,20-29}")
-# brooklyn.location.named.On-Prem\ Iron\ Example.user=produser1
-# brooklyn.location.named.On-Prem\ Iron\ Example.privateKeyFile=~/.ssh/produser_id_rsa
-# brooklyn.location.named.On-Prem\ Iron\ Example.privateKeyPassphrase=s3cr3tpassphrase
-
-## Various Private Clouds
-
-## Example: OpenStack Nova
-
-## openstack identity and credential are random strings of letters and numbers (TBC - still the case?)
-# brooklyn.location.named.My\ Openstack=jclouds:openstack-nova:https://9.9.9.9:9999/v2.0/
-
-## OpenStack Nova access information can be downloaded from the openstack web interface; for example, as openrc.sh file
-# brooklyn.location.named.My\ Openstack=jclouds:openstack-nova:keystone-url
-# brooklyn.location.named.My\ OpenStack.identity=your-tenant-name:your-user-name
-# brooklyn.location.named.My\ OpenStack.credential=your-password
-# brooklyn.location.named.My\ OpenStack.endpoint=your-keystone-url
-
-## The ID of the image must be configured according to the local OpenStack settings
-## Use the command nova image-list to list all the available images
-## Use the command nova show <image-name> to get more details
-# brooklyn.location.named.My\ OpenStack.imageId=the-region-name/the-image-id
-
-## Virtual Machine flavors must match the ones created upfront according to the local OpenStack settings
-## Use the command nova flavor-list to list all the available options
-## Use the command nova flavor-show <flavor-name> to get more details
-# brooklyn.location.named.My\ OpenStack.hardwareId=the-region-name/the-flavor-id
-
-## (Optional) Configurations
-
-# brooklyn.location.named.My\ OpenStack.user=user-name-inside-the-instance
-
-## The keyPair must by created upfront. Both the following two options are required at the same time.
-# brooklyn.location.named.My\ OpenStack.keyPair=the-key-pair-name
-# brooklyn.location.named.My\ OpenStack.loginUser.privateKeyFile=/path/to/keypair.pem
-
-## Security groups must be created upfront (TBC - How to specify many security groups at one ?)
-# brooklyn.location.named.My\ OpenStack.securityGroups=universal
-
-# brooklyn.location.named.My\ OpenStack.openIptables=true
-# brooklyn.location.named.My\ OpenStack.selinux.disabled=true
-# brooklyn.location.named.My\ OpenStack.auto-create-floating-ips=true
-# brooklyn.location.named.My\ OpenStack.openstack-nova.auto-generate-keypairs=false
-
-## cloudstack identity and credential are rather long random strings of letters and numbers
-## you generate this in the cloudstack gui, under accounts, then "view users", then "generate key"
-## use the "api key" as the identity and "secret key" as the credential
-# brooklyn.location.named.My\ Cloudstack=jclouds:cloudstack:http://9.9.9.9:9999/client/api/
-
-## abiquo identity and credential are your login username/passed
-# brooklyn.location.named.My\ Abiquo=jclouds:abiquo:http://demonstration.abiquo.com/api/
-
-###############################  Formatting Guide  #######################################
-
-! Both # and ! mark lines as comments
-# The follow syntax are ALL valid.
-# example_key example_value
-# example_key : example_value
-# example_key = example_value
-# example_key=example_value
-
-# The backslash below tells Brooklyn to continue reading the value onto the next line.
-# example_key = A very \
-#          	long string!
-# Note all white space before 'long...' is ignored. Also '!' is kept as part of the string
-
-
-# Keys with spaces should be escaped with backslashes.
-# This is useful for named locations, as the name displayed in Brooklyn's web
-# interface is derived from the key name.
-# key\ with\ spaces = some\ value
-
-# Encoding for .properties must be ISO-8859-1, aka Latin-1.
-# All non-latin1 characters must be entered using unicode escape characters
-# polish_pangram = P\u00F3jd\u017A\u017Ce, ki\u0144 \
-#                  t\u0119 chmurno\u015B\u0107 w g\u0142\u0105b flaszy!
\ No newline at end of file
+# Note: BYON locations are loaded from the files/vagrant-catalog.bom on startup
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/c81f4835/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service b/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service
index 04384a1..5fe2767 100644
--- a/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service
+++ b/brooklyn-dist/vagrant/src/main/vagrant/files/brooklyn.service
@@ -3,7 +3,7 @@ Description=Apache Brooklyn service
 Documentation=http://brooklyn.apache.org/documentation/index.html
 
 [Service]
-ExecStart=/home/vagrant/apache-brooklyn/bin/brooklyn launch --persist auto --persistenceDir /vagrant/brooklyn-persisted-state
+ExecStart=/home/vagrant/apache-brooklyn/bin/brooklyn launch --persist auto --persistenceDir /vagrant/brooklyn-persisted-state --catalogAdd /vagrant/files/vagrant-catalog.bom
 WorkingDirectory=/home/vagrant/apache-brooklyn
 Restart=on-abort
 User=vagrant

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/c81f4835/brooklyn-dist/vagrant/src/main/vagrant/files/vagrant-catalog.bom
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/files/vagrant-catalog.bom b/brooklyn-dist/vagrant/src/main/vagrant/files/vagrant-catalog.bom
new file mode 100644
index 0000000..d8b8450
--- /dev/null
+++ b/brooklyn-dist/vagrant/src/main/vagrant/files/vagrant-catalog.bom
@@ -0,0 +1,82 @@
+#
+# 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.
+#
+brooklyn.catalog:
+  items:
+  - id: byon1
+    name: Vagrant BYON VM 1
+    version: 0.9.0-SNAPSHOT  # BROOKLYN_VERSION
+    itemType: location
+    item:
+      type: byon
+      brooklyn.config:
+        user: vagrant
+        password: vagrant
+        hosts:
+        - 10.10.10.101
+
+  - id: byon2
+    name: Vagrant BYON VM 2
+    version: 0.9.0-SNAPSHOT  # BROOKLYN_VERSION
+    itemType: location
+    item:
+      type: byon
+      brooklyn.config:
+        user: vagrant
+        password: vagrant
+        hosts:
+        - 10.10.10.102
+
+  - id: byon3
+    name: Vagrant BYON VM 3
+    version: 0.9.0-SNAPSHOT  # BROOKLYN_VERSION
+    itemType: location
+    item:
+      type: byon
+      brooklyn.config:
+        user: vagrant
+        password: vagrant
+        hosts:
+        - 10.10.10.103
+
+  - id: byon4
+    name: Vagrant BYON VM 4
+    version: 0.9.0-SNAPSHOT  # BROOKLYN_VERSION
+    itemType: location
+    item:
+      type: byon
+      brooklyn.config:
+        user: vagrant
+        password: vagrant
+        hosts:
+        - 10.10.10.104
+
+  - id: byon-all
+    name: Vagrant BYON VM 1-4
+    version: 0.9.0-SNAPSHOT  # BROOKLYN_VERSION
+    itemType: location
+    item:
+      type: byon
+      brooklyn.config:
+        user: vagrant
+        password: vagrant
+        hosts:
+        - 10.10.10.101
+        - 10.10.10.102
+        - 10.10.10.103
+        - 10.10.10.104


[33/51] [abbrv] brooklyn-dist git commit: Updated license for Glossarizer MIT statement

Posted by he...@apache.org.
Updated license for Glossarizer MIT statement


Project: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/repo
Commit: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/commit/97df1e75
Tree: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/tree/97df1e75
Diff: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/diff/97df1e75

Branch: refs/heads/master
Commit: 97df1e7514f029781fe269d8f965695cf641480f
Parents: 00d8f4c
Author: Duncan Godwin <du...@cloudsoftcorp.com>
Authored: Mon Jan 25 13:52:47 2016 +0000
Committer: Duncan Godwin <du...@cloudsoftcorp.com>
Committed: Mon Jan 25 13:52:47 2016 +0000

----------------------------------------------------------------------
 LICENSE | 7 +++++++
 1 file changed, 7 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/97df1e75/LICENSE
----------------------------------------------------------------------
diff --git a/LICENSE b/LICENSE
index ca60394..6dc5e35 100644
--- a/LICENSE
+++ b/LICENSE
@@ -250,6 +250,13 @@ This project includes the software: DataTables Table plug-in for jQuery
   Used under the following license: The BSD 3-Clause (New BSD) License (http://opensource.org/licenses/BSD-3-Clause)
   Copyright (c) Allan Jardine (2008-2012)
 
+This project includes the software: glossarizer
+  Available at: https://github.com/PebbleRoad/glossarizer
+  Developed by: Vinay M, PebbleRoad Pte Ltd (http://www.pebbleroad.com)
+  Version used: 1.5
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Vinay M, PebbleRoad Pte Ltd (2004-2016)
+
 This project includes the software: jQuery Form Plugin
   Available at: https://github.com/malsup/form
   Developed by: Mike Alsup (http://malsup.com/)


[38/51] [abbrv] brooklyn-dist git commit: update license generation to put a file in each project root

Posted by he...@apache.org.
update license generation to put a file in each project root

and  correct some version mismatches


Project: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/repo
Commit: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/commit/92947c9c
Tree: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/tree/92947c9c
Diff: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/diff/92947c9c

Branch: refs/heads/master
Commit: 92947c9c4556e69ae5cf0793159e23330ee2ae45
Parents: 71b379c
Author: Alex Heneveld <al...@cloudsoftcorp.com>
Authored: Sat Jan 30 03:32:38 2016 +0000
Committer: Alex Heneveld <al...@cloudsoftcorp.com>
Committed: Sat Jan 30 03:32:38 2016 +0000

----------------------------------------------------------------------
 .../dist/licensing/make-all-licenses.sh         | 34 +++++++++++---------
 brooklyn-dist/dist/licensing/overrides.yaml     | 10 +++---
 2 files changed, 25 insertions(+), 19 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/92947c9c/brooklyn-dist/dist/licensing/make-all-licenses.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/make-all-licenses.sh b/brooklyn-dist/dist/licensing/make-all-licenses.sh
index 3b62f96..b08d17f 100755
--- a/brooklyn-dist/dist/licensing/make-all-licenses.sh
+++ b/brooklyn-dist/dist/licensing/make-all-licenses.sh
@@ -29,26 +29,14 @@ unset BROOKLYN_LICENSE_SPECIALS
 unset BROOKLYN_LICENSE_EXTRAS_FILES
 unset BROOKLYN_LICENSE_MODE
 
-# individual projects
-for x in `cat projects-with-custom-licenses` ; do
-  export BROOKLYN_LICENSE_MODE=`basename $x`
-  echo MAKING LICENSES FOR: ${BROOKLYN_LICENSE_MODE}
-  export BROOKLYN_LICENSE_SPECIALS=-DonlyExtras=true
-  export BROOKLYN_LICENSE_EXTRAS_FILES=$x/src/main/license/source-inclusions.yaml
-  cp licenses/`basename $x`/* licenses/source
-  ./make-one-license.sh > LICENSE.autogenerated || ( echo FAILED. See details in tmp_stdout/err. && false )
-  cp LICENSE.autogenerated ../$x/src/main/license/files/LICENSE
-  unset BROOKLYN_LICENSE_SPECIALS
-  unset BROOKLYN_LICENSE_EXTRAS_FILES
-  unset BROOKLYN_LICENSE_MODE
-done
-
-# source build, at root
+# source build, at root and each sub-project
 export BROOKLYN_LICENSE_MODE=source
 echo MAKING LICENSES FOR: ${BROOKLYN_LICENSE_MODE}
 export BROOKLYN_LICENSE_SPECIALS=-DonlyExtras=true 
 ./make-one-license.sh > LICENSE.autogenerated
 cp LICENSE.autogenerated ../../../LICENSE
+# overwrite any existing licenses at root
+for x in ../../../brooklyn-*/LICENSE ; do cp LICENSE.autogenerated $x ; done
 unset BROOKLYN_LICENSE_SPECIALS
 unset BROOKLYN_LICENSE_MODE
 
@@ -59,3 +47,19 @@ echo MAKING LICENSES FOR: ${BROOKLYN_LICENSE_MODE}
 cp LICENSE.autogenerated ../src/main/license/files/LICENSE
 unset BROOKLYN_LICENSE_MODE
 
+# individual projects
+for x in `cat projects-with-custom-licenses` ; do
+  export BROOKLYN_LICENSE_MODE=`basename $x`
+  echo MAKING LICENSES FOR: ${BROOKLYN_LICENSE_MODE}
+  export BROOKLYN_LICENSE_SPECIALS=-DonlyExtras=true
+  export BROOKLYN_LICENSE_EXTRAS_FILES=$x/src/main/license/source-inclusions.yaml
+  cp licenses/`basename $x`/* licenses/source
+  ./make-one-license.sh > LICENSE.autogenerated || ( echo FAILED. See details in tmp_stdout/err. && false )
+  cp LICENSE.autogenerated ../$x/src/main/license/files/LICENSE
+  # also copy to root of that project *if* there is already a LICENSE file there
+  [ -f ../$x/LICENSE ] && cp LICENSE.autogenerated ../$x/LICENSE || true
+  unset BROOKLYN_LICENSE_SPECIALS
+  unset BROOKLYN_LICENSE_EXTRAS_FILES
+  unset BROOKLYN_LICENSE_MODE
+done
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/92947c9c/brooklyn-dist/dist/licensing/overrides.yaml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/overrides.yaml b/brooklyn-dist/dist/licensing/overrides.yaml
index a2f6107..1285df4 100644
--- a/brooklyn-dist/dist/licensing/overrides.yaml
+++ b/brooklyn-dist/dist/licensing/overrides.yaml
@@ -99,7 +99,8 @@
 
 # info on non-maven projects
 
-- id: jquery-core
+# used in UI
+- id: jquery-core:1.7.2
   url: http://jquery.com/
   description: JS library for manipulating HTML and eventing
   name: jQuery JavaScript Library
@@ -146,6 +147,7 @@
   - "  Available at http://sizzlejs.com"
   - "  Used under the MIT license"
 
+# not used anymore? swagger-ui includes what it needs, it seems.
 - id: swagger:2.1.6
   name: Swagger JS
   files: swagger-client.js
@@ -154,10 +156,10 @@
   license: ASL2
   notice: Copyright (c) SmartBear Software (2011-2015)
 
-- id: swagger-ui:2.1.3
-  files: swagger-ui.js
+- id: swagger-ui:2.1.4
+  files: swagger*.{js,css,html}
   name: Swagger UI
-  version: 2.1.3
+  version: 2.1.4
   url: https://github.com/swagger-api/swagger-ui
   license: ASL2
   notice: Copyright (c) SmartBear Software (2011-2015)


[46/51] [abbrv] brooklyn-dist git commit: move subdir from incubator up a level as it is promoted to its own repo (first non-incubator commit!)

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/src/main/license/files/NOTICE
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/license/files/NOTICE b/brooklyn-dist/dist/src/main/license/files/NOTICE
deleted file mode 100644
index f790f13..0000000
--- a/brooklyn-dist/dist/src/main/license/files/NOTICE
+++ /dev/null
@@ -1,5 +0,0 @@
-Apache Brooklyn
-Copyright 2014-2015 The Apache Software Foundation
-
-This product includes software developed at
-The Apache Software Foundation (http://www.apache.org/).

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/src/test/java/org/apache/brooklyn/cli/BaseCliIntegrationTest.java
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/test/java/org/apache/brooklyn/cli/BaseCliIntegrationTest.java b/brooklyn-dist/dist/src/test/java/org/apache/brooklyn/cli/BaseCliIntegrationTest.java
deleted file mode 100644
index 4cb2d2b..0000000
--- a/brooklyn-dist/dist/src/test/java/org/apache/brooklyn/cli/BaseCliIntegrationTest.java
+++ /dev/null
@@ -1,189 +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.brooklyn.cli;
-
-import static org.testng.Assert.assertEquals;
-import static org.testng.Assert.assertFalse;
-import static org.testng.Assert.assertTrue;
-import static org.testng.Assert.fail;
-
-import java.io.InputStream;
-import java.io.OutputStream;
-import java.util.NoSuchElementException;
-import java.util.Scanner;
-import java.util.concurrent.Callable;
-import java.util.concurrent.ExecutionException;
-import java.util.concurrent.ExecutorService;
-import java.util.concurrent.Executors;
-import java.util.concurrent.Future;
-import java.util.concurrent.TimeUnit;
-import java.util.concurrent.TimeoutException;
-
-import org.apache.brooklyn.core.entity.factory.ApplicationBuilder;
-import org.testng.annotations.AfterMethod;
-import org.testng.annotations.BeforeMethod;
-
-import com.google.common.collect.Lists;
-
-/**
- * Command line interface test support.
- */
-public class BaseCliIntegrationTest {
-
-    // TODO does this need to be hard-coded?
-    private static final String BROOKLYN_BIN_PATH = "./target/brooklyn-dist/bin/brooklyn";
-    private static final String BROOKLYN_CLASSPATH = "./target/test-classes/:./target/classes/";
-
-    // Times in seconds to allow Brooklyn to run and produce output
-    private static final long DELAY = 10l;
-    private static final long TIMEOUT = DELAY + 30l;
-
-    private ExecutorService executor;
-
-    @BeforeMethod(alwaysRun = true)
-    public void setup() {
-        executor = Executors.newCachedThreadPool();
-    }
-
-    @AfterMethod(alwaysRun = true)
-    public void teardown() {
-        executor.shutdownNow();
-    }
-
-    /** Invoke the brooklyn script with arguments. */
-    public Process startBrooklyn(String...argv) throws Throwable {
-        ProcessBuilder pb = new ProcessBuilder();
-        pb.environment().remove("BROOKLYN_HOME");
-        pb.environment().put("BROOKLYN_CLASSPATH", BROOKLYN_CLASSPATH);
-        pb.command(Lists.asList(BROOKLYN_BIN_PATH, argv));
-        return pb.start();
-    }
-
-    public void testBrooklyn(Process brooklyn, BrooklynCliTest test, int expectedExit) throws Throwable {
-        testBrooklyn(brooklyn, test, expectedExit, false);
-    }
-
-    /** Tests the operation of the Brooklyn CLI. */
-    public void testBrooklyn(Process brooklyn, BrooklynCliTest test, int expectedExit, boolean stop) throws Throwable {
-        try {
-            Future<Integer> future = executor.submit(test);
-
-            // Send CR to stop if required
-            if (stop) {
-                OutputStream out = brooklyn.getOutputStream();
-                out.write('\n');
-                out.flush();
-            }
-
-            int exitStatus = future.get(TIMEOUT, TimeUnit.SECONDS);
-
-            // Check error code from process
-            assertEquals(exitStatus, expectedExit, "Command returned wrong status");
-        } catch (TimeoutException te) {
-            fail("Timed out waiting for process to complete", te);
-        } catch (ExecutionException ee) {
-            if (ee.getCause() instanceof AssertionError) {
-                throw ee.getCause();
-            } else throw ee;
-        } finally {
-            brooklyn.destroy();
-        }
-    }
-
-    /** A {@link Callable} that encapsulates Brooklyn CLI test logic. */
-    public static abstract class BrooklynCliTest implements Callable<Integer> {
-
-        private final Process brooklyn;
-
-        private String consoleOutput;
-        private String consoleError;
-
-        public BrooklynCliTest(Process brooklyn) {
-            this.brooklyn = brooklyn;
-        }
-
-        @Override
-        public Integer call() throws Exception {
-            // Wait for initial output
-            Thread.sleep(TimeUnit.SECONDS.toMillis(DELAY));
-
-            // Get the console output of running that command
-            consoleOutput = convertStreamToString(brooklyn.getInputStream());
-            consoleError = convertStreamToString(brooklyn.getErrorStream());
-
-            // Check if the output looks as expected
-            checkConsole();
-
-            // Return exit status on completion
-            return brooklyn.waitFor();
-        }
-
-        /** Perform test assertions on console output and error streams. */
-        public abstract void checkConsole();
-
-        private String convertStreamToString(InputStream is) {
-            try {
-                return new Scanner(is).useDelimiter("\\A").next();
-            } catch (NoSuchElementException e) {
-                return "";
-            }
-        }
-
-        protected void assertConsoleOutput(String...expected) {
-            for (String e : expected) {
-                assertTrue(consoleOutput.contains(e), "Execution output not logged; output=" + consoleOutput);
-            }
-        }
-
-        protected void assertNoConsoleOutput(String...expected) {
-            for (String e : expected) {
-                assertFalse(consoleOutput.contains(e), "Execution output logged; output=" + consoleOutput);
-            }
-        }
-
-        protected void assertConsoleError(String...expected) {
-            for (String e : expected) {
-                assertTrue(consoleError.contains(e), "Execution error not logged; error=" + consoleError);
-            }
-        }
-
-        protected void assertNoConsoleError(String...expected) {
-            for (String e : expected) {
-                assertFalse(consoleError.contains(e), "Execution error logged; error=" + consoleError);
-            }
-        }
-
-        protected void assertConsoleOutputEmpty() {
-            assertTrue(consoleOutput.isEmpty(), "Output present; output=" + consoleOutput);
-        }
-
-        protected void assertConsoleErrorEmpty() {
-            assertTrue(consoleError.isEmpty(), "Error present; error=" + consoleError);
-        }
-    };
-
-    /** An empty application for testing. */
-    public static class TestApplication extends ApplicationBuilder {
-        @Override
-        protected void doBuild() {
-            // Empty, for testing
-        }
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/src/test/java/org/apache/brooklyn/cli/CliIntegrationTest.java
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/test/java/org/apache/brooklyn/cli/CliIntegrationTest.java b/brooklyn-dist/dist/src/test/java/org/apache/brooklyn/cli/CliIntegrationTest.java
deleted file mode 100644
index adf9559..0000000
--- a/brooklyn-dist/dist/src/test/java/org/apache/brooklyn/cli/CliIntegrationTest.java
+++ /dev/null
@@ -1,219 +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.brooklyn.cli;
-
-import org.testng.annotations.Test;
-
-/**
- * Test the command line interface operation.
- */
-public class CliIntegrationTest extends BaseCliIntegrationTest {
-
-    /**
-     * Checks if running {@code brooklyn help} produces the expected output.
-     */
-    @Test(groups = {"Integration","Broken"})
-    public void testLaunchCliHelp() throws Throwable {
-        final Process brooklyn = startBrooklyn("help");
-
-        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
-            @Override
-            public void checkConsole() {
-                assertConsoleOutput("usage: brooklyn"); // Usage info not present
-                assertConsoleOutput("The most commonly used brooklyn commands are:");
-                assertConsoleOutput("help     Display help for available commands",
-                                    "info     Display information about brooklyn",
-                                    "launch   Starts a brooklyn application"); // List of common commands not present
-                assertConsoleOutput("See 'brooklyn help <command>' for more information on a specific command.");
-                assertConsoleErrorEmpty();
-            }
-        };
-
-        testBrooklyn(brooklyn, test, 0);
-    }
-
-    /*
-        Exception java.io.IOException
-        
-        Message: Cannot run program "./target/brooklyn-dist/bin/brooklyn": error=2, No such file or directory
-        Stacktrace:
-        
-        
-        at java.lang.ProcessBuilder.start(ProcessBuilder.java:1047)
-        at org.apache.brooklyn.cli.BaseCliIntegrationTest.startBrooklyn(BaseCliIntegrationTest.java:75)
-        at org.apache.brooklyn.cli.CliIntegrationTest.testLaunchCliApp(CliIntegrationTest.java:56)
-        at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
-        at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:57)
-        at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
-        at java.lang.reflect.Method.invoke(Method.java:606)
-        at org.testng.internal.MethodInvocationHelper.invokeMethod(MethodInvocationHelper.java:84)
-        at org.testng.internal.Invoker.invokeMethod(Invoker.java:714)
-        at org.testng.internal.Invoker.invokeTestMethod(Invoker.java:901)
-        at org.testng.internal.Invoker.invokeTestMethods(Invoker.java:1231)
-        at org.testng.internal.TestMethodWorker.invokeTestMethods(TestMethodWorker.java:127)
-        at org.testng.internal.TestMethodWorker.run(TestMethodWorker.java:111)
-        at org.testng.TestRunner.privateRun(TestRunner.java:767)
-        at org.testng.TestRunner.run(TestRunner.java:617)
-        at org.testng.SuiteRunner.runTest(SuiteRunner.java:348)
-        at org.testng.SuiteRunner.runSequentially(SuiteRunner.java:343)
-        at org.testng.SuiteRunner.privateRun(SuiteRunner.java:305)
-        at org.testng.SuiteRunner.run(SuiteRunner.java:254)
-        at org.testng.SuiteRunnerWorker.runSuite(SuiteRunnerWorker.java:52)
-        at org.testng.SuiteRunnerWorker.run(SuiteRunnerWorker.java:86)
-        at org.testng.TestNG.runSuitesSequentially(TestNG.java:1224)
-        at org.testng.TestNG.runSuitesLocally(TestNG.java:1149)
-        at org.testng.TestNG.run(TestNG.java:1057)
-        at org.apache.maven.surefire.testng.TestNGExecutor.run(TestNGExecutor.java:115)
-        at org.apache.maven.surefire.testng.TestNGDirectoryTestSuite.executeMulti(TestNGDirectoryTestSuite.java:205)
-        at org.apache.maven.surefire.testng.TestNGDirectoryTestSuite.execute(TestNGDirectoryTestSuite.java:108)
-        at org.apache.maven.surefire.testng.TestNGProvider.invoke(TestNGProvider.java:111)
-        at org.apache.maven.surefire.booter.ForkedBooter.invokeProviderInSameClassLoader(ForkedBooter.java:203)
-        at org.apache.maven.surefire.booter.ForkedBooter.runSuitesInProcess(ForkedBooter.java:155)
-        at org.apache.maven.surefire.booter.ForkedBooter.main(ForkedBooter.java:103)
-        Caused by: java.io.IOException: error=2, No such file or directory
-        at java.lang.UNIXProcess.forkAndExec(Native Method)
-        at java.lang.UNIXProcess.<init>(UNIXProcess.java:186)
-        at java.lang.ProcessImpl.start(ProcessImpl.java:130)
-        at java.lang.ProcessBuilder.start(ProcessBuilder.java:1028)
-        ... 30 more
-     */
-    /**
-     * Checks if launching an application using {@code brooklyn launch} produces the expected output.
-     */
-    @Test(groups = {"Integration","Broken"})
-    public void testLaunchCliApp() throws Throwable {
-        final Process brooklyn = startBrooklyn("--verbose", "launch", "--stopOnKeyPress", "--app", "org.apache.brooklyn.cli.BaseCliIntegrationTest$TestApplication", "--location", "localhost", "--noConsole");
-
-        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
-            @Override
-            public void checkConsole() {
-                assertConsoleOutput("Launching brooklyn app:"); // Launch message not output
-                assertNoConsoleOutput("Initiating Jersey application"); // Web console started
-                assertConsoleOutput("Started application BasicApplicationImpl"); // Application not started
-                assertConsoleOutput("Server started. Press return to stop."); // Server started message not output
-                assertConsoleErrorEmpty();
-            }
-        };
-
-        testBrooklyn(brooklyn, test, 0, true);
-    }
-
-    /**
-     * Checks if a correct error and help message is given if using incorrect param.
-     */
-    @Test(groups = {"Integration","Broken"})
-    public void testLaunchCliAppParamError() throws Throwable {
-        final Process brooklyn = startBrooklyn("launch", "nothing", "--app");
-
-        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
-            @Override
-            public void checkConsole() {
-                assertConsoleError("Parse error: Required values for option 'application class or file' not provided");
-                assertConsoleError("NAME", "SYNOPSIS", "OPTIONS", "COMMANDS");
-                assertConsoleOutputEmpty();
-            }
-        };
-
-        testBrooklyn(brooklyn, test, 1);
-    }
-
-    /*
-        Exception java.io.IOException
-        
-        Message: Cannot run program "./target/brooklyn-dist/bin/brooklyn": error=2, No such file or directory
-        Stacktrace:
-        
-        
-        at java.lang.ProcessBuilder.start(ProcessBuilder.java:1047)
-        at org.apache.brooklyn.cli.BaseCliIntegrationTest.startBrooklyn(BaseCliIntegrationTest.java:75)
-        at org.apache.brooklyn.cli.CliIntegrationTest.testLaunchCliAppCommandError(CliIntegrationTest.java:96)
-        at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
-        at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:57)
-        at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
-        at java.lang.reflect.Method.invoke(Method.java:606)
-        at org.testng.internal.MethodInvocationHelper.invokeMethod(MethodInvocationHelper.java:84)
-        at org.testng.internal.Invoker.invokeMethod(Invoker.java:714)
-        at org.testng.internal.Invoker.invokeTestMethod(Invoker.java:901)
-        at org.testng.internal.Invoker.invokeTestMethods(Invoker.java:1231)
-        at org.testng.internal.TestMethodWorker.invokeTestMethods(TestMethodWorker.java:127)
-        at org.testng.internal.TestMethodWorker.run(TestMethodWorker.java:111)
-        at org.testng.TestRunner.privateRun(TestRunner.java:767)
-        at org.testng.TestRunner.run(TestRunner.java:617)
-        at org.testng.SuiteRunner.runTest(SuiteRunner.java:348)
-        at org.testng.SuiteRunner.runSequentially(SuiteRunner.java:343)
-        at org.testng.SuiteRunner.privateRun(SuiteRunner.java:305)
-        at org.testng.SuiteRunner.run(SuiteRunner.java:254)
-        at org.testng.SuiteRunnerWorker.runSuite(SuiteRunnerWorker.java:52)
-        at org.testng.SuiteRunnerWorker.run(SuiteRunnerWorker.java:86)
-        at org.testng.TestNG.runSuitesSequentially(TestNG.java:1224)
-        at org.testng.TestNG.runSuitesLocally(TestNG.java:1149)
-        at org.testng.TestNG.run(TestNG.java:1057)
-        at org.apache.maven.surefire.testng.TestNGExecutor.run(TestNGExecutor.java:115)
-        at org.apache.maven.surefire.testng.TestNGDirectoryTestSuite.executeMulti(TestNGDirectoryTestSuite.java:205)
-        at org.apache.maven.surefire.testng.TestNGDirectoryTestSuite.execute(TestNGDirectoryTestSuite.java:108)
-        at org.apache.maven.surefire.testng.TestNGProvider.invoke(TestNGProvider.java:111)
-        at org.apache.maven.surefire.booter.ForkedBooter.invokeProviderInSameClassLoader(ForkedBooter.java:203)
-        at org.apache.maven.surefire.booter.ForkedBooter.runSuitesInProcess(ForkedBooter.java:155)
-        at org.apache.maven.surefire.booter.ForkedBooter.main(ForkedBooter.java:103)
-        Caused by: java.io.IOException: error=2, No such file or directory
-        at java.lang.UNIXProcess.forkAndExec(Native Method)
-        at java.lang.UNIXProcess.<init>(UNIXProcess.java:186)
-        at java.lang.ProcessImpl.start(ProcessImpl.java:130)
-        at java.lang.ProcessBuilder.start(ProcessBuilder.java:1028)
-        ... 30 more
-     */
-    /**
-     * Checks if a correct error and help message is given if using incorrect command.
-     */
-    @Test(groups = "Integration")
-    public void testLaunchCliAppCommandError() throws Throwable {
-        final Process brooklyn = startBrooklyn("biscuit");
-
-        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
-            @Override
-            public void checkConsole() {
-                assertConsoleError("Parse error: No command specified");
-                assertConsoleError("NAME", "SYNOPSIS", "OPTIONS", "COMMANDS");
-                assertConsoleOutputEmpty();
-            }
-        };
-
-        testBrooklyn(brooklyn, test, 1);
-    }
-
-    /**
-     * Checks if a correct error and help message is given if using incorrect application.
-     */
-    @Test(groups = {"Integration","Broken"})
-    public void testLaunchCliAppLaunchError() throws Throwable {
-        final String app = "org.eample.DoesNotExist";
-        final Process brooklyn = startBrooklyn("launch", "--app", app, "--location", "nowhere");
-
-        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
-            @Override
-            public void checkConsole() {
-                assertConsoleOutput(app, "not found");
-                assertConsoleError("ERROR", "Fatal", "getting resource", app);
-            }
-        };
-
-        testBrooklyn(brooklyn, test, 2);
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/downstream-parent/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/downstream-parent/pom.xml b/brooklyn-dist/downstream-parent/pom.xml
deleted file mode 100644
index f97dba3..0000000
--- a/brooklyn-dist/downstream-parent/pom.xml
+++ /dev/null
@@ -1,524 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-  <modelVersion>4.0.0</modelVersion>
-
-  <parent>
-    <groupId>org.apache.brooklyn</groupId>
-    <artifactId>brooklyn-server</artifactId>
-    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-    <relativePath>../../brooklyn-server/pom.xml</relativePath>
-    <!-- TODO this uses server root pom as a way to get version info without rat check;
-         it means it inherits apache pom, which might not be desired.
-         probably cleaner NOT to have a downstream-parent, instead for project to redeclare their tasks.
-         (yes it violates DRY, but until Maven 4 supporting Mixins that is probably better than
-         hacks in a parent hierarchy to which people won't have visibility. -->
-  </parent>
-
-  <artifactId>brooklyn-downstream-parent</artifactId>
-  <packaging>pom</packaging>
-  <name>Brooklyn Downstream Project Parent</name>
-  <description>
-      Parent pom that can be used by downstream projects that use Brooklyn,
-      or that contribute additional functionality to Brooklyn.
-  </description>
-
-  <properties>
-    <!-- Compilation -->
-    <java.version>1.7</java.version>
-    <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>
-    <project.reporting.outputEncoding>UTF-8</project.reporting.outputEncoding>
-
-    <!-- Testing -->
-    <testng.version>6.8.8</testng.version>
-    <surefire.version>2.18.1</surefire.version>
-    <includedTestGroups />
-    <excludedTestGroups>Integration,Acceptance,Live,Live-sanity,WIP</excludedTestGroups>
-
-    <!-- Dependencies -->
-    <brooklyn.version>0.9.0-SNAPSHOT</brooklyn.version>  <!-- BROOKLYN_VERSION -->
-    <jclouds.groupId>org.apache.jclouds</jclouds.groupId> <!-- JCLOUDS_GROUPID_VERSION -->
-
-    <!-- versions should match those used by Brooklyn, to avoid conflicts -->
-    <jclouds.version>1.9.2</jclouds.version> <!-- JCLOUDS_VERSION -->
-    <logback.version>1.0.7</logback.version>
-    <slf4j.version>1.6.6</slf4j.version>  <!-- used for java.util.logging jul-to-slf4j interception -->
-    <guava.version>17.0</guava.version>
-    <xstream.version>1.4.7</xstream.version>
-    <jackson.version>1.9.13</jackson.version>  <!-- codehaus jackson, used by brooklyn rest server -->
-    <fasterxml.jackson.version>2.4.5</fasterxml.jackson.version>  <!-- more recent jackson, but not compatible with old annotations! -->
-    <jersey.version>1.19</jersey.version>
-    <httpclient.version>4.4.1</httpclient.version>
-    <commons-lang3.version>3.1</commons-lang3.version>
-    <groovy.version>2.3.7</groovy.version> <!-- Version supported by https://github.com/groovy/groovy-eclipse/wiki/Groovy-Eclipse-2.9.1-Release-Notes -->
-    <jsr305.version>2.0.1</jsr305.version>
-    <snakeyaml.version>1.11</snakeyaml.version>
-  </properties>
-
-  <dependencyManagement>
-    <dependencies>
-      <dependency>
-        <!-- this would pull in all brooklyn entities and clouds;
-             you can cherry pick selected ones instead (for a smaller build) -->
-        <groupId>org.apache.brooklyn</groupId>
-        <artifactId>brooklyn-all</artifactId>
-        <version>${brooklyn.version}</version>
-      </dependency>
-    </dependencies>
-  </dependencyManagement>
-
-  <dependencies>
-    <dependency>
-      <!-- this gives us flexible and easy-to-use logging; just edit logback-custom.xml! -->
-      <groupId>org.apache.brooklyn</groupId>
-      <artifactId>brooklyn-logback-xml</artifactId>
-      <version>${brooklyn.version}</version>
-      <!-- optional so that this project has logging; dependencies may redeclare or supply their own;
-           provided so that it isn't put into the assembly (as it supplies its own explicit logback.xml);
-           see Logging in the Brooklyn website/userguide for more info -->
-      <optional>true</optional>
-      <scope>provided</scope>
-    </dependency>
-    <dependency>
-      <!-- includes testng and useful logging for tests -->
-      <groupId>org.apache.brooklyn</groupId>
-      <artifactId>brooklyn-test-support</artifactId>
-      <version>${brooklyn.version}</version>
-      <scope>test</scope>
-    </dependency>
-    <dependency>
-      <!-- includes org.apache.brooklyn.test.support.LoggingVerboseReporter -->
-      <groupId>org.apache.brooklyn</groupId>
-      <artifactId>brooklyn-utils-test-support</artifactId>
-      <version>${brooklyn.version}</version>
-      <scope>test</scope>
-    </dependency>
-  </dependencies>
-
-  <build>
-    <testSourceDirectory>src/test/java</testSourceDirectory>
-    <testResources>
-      <testResource>
-        <directory>src/test/resources</directory>
-      </testResource>
-    </testResources>
-
-    <pluginManagement>
-      <plugins>
-        <plugin>
-          <artifactId>maven-assembly-plugin</artifactId>
-          <version>2.5.4</version>
-          <configuration>
-            <tarLongFileMode>gnu</tarLongFileMode>
-          </configuration>
-        </plugin>
-        <plugin>
-          <artifactId>maven-clean-plugin</artifactId>
-          <version>2.6.1</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-compiler-plugin</artifactId>
-          <version>3.3</version>
-          <configuration>
-            <source>${java.version}</source>
-            <target>${java.version}</target>
-          </configuration>
-        </plugin>
-        <plugin>
-          <artifactId>maven-deploy-plugin</artifactId>
-          <version>2.8.2</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-eclipse-plugin</artifactId>
-          <version>2.10</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-enforcer-plugin</artifactId>
-          <version>1.4</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-failsafe-plugin</artifactId>
-          <version>2.18.1</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-gpg-plugin</artifactId>
-          <version>1.6</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-jar-plugin</artifactId>
-          <version>2.6</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-javadoc-plugin</artifactId>
-          <version>2.10.3</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-resources-plugin</artifactId>
-          <version>2.7</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-source-plugin</artifactId>
-          <version>2.4</version>
-        </plugin>
-        <plugin>
-          <artifactId>maven-surefire-plugin</artifactId>
-          <version>2.18.1</version>
-        </plugin>
-        <plugin>
-          <groupId>org.apache.felix</groupId>
-          <artifactId>maven-bundle-plugin</artifactId>
-          <version>2.3.4</version>
-        </plugin>
-        <!--This plugin's configuration is used to store Eclipse m2e settings only. It has no influence on the Maven build itself.-->
-        <plugin>
-          <groupId>org.eclipse.m2e</groupId>
-          <artifactId>lifecycle-mapping</artifactId>
-          <version>1.0.0</version>
-          <configuration>
-            <lifecycleMappingMetadata>
-              <pluginExecutions>
-                <pluginExecution>
-                  <pluginExecutionFilter>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-assembly-plugin</artifactId>
-                    <versionRange>[2.4.1,)</versionRange>
-                    <goals>
-                      <goal>single</goal>
-                    </goals>
-                  </pluginExecutionFilter>
-                  <action>
-                    <ignore />
-                  </action>
-                </pluginExecution>
-                <pluginExecution>
-                  <pluginExecutionFilter>
-                    <groupId>org.codehaus.mojo</groupId>
-                    <artifactId>build-helper-maven-plugin</artifactId>
-                    <versionRange>[1.7,)</versionRange>
-                    <goals>
-                      <goal>attach-artifact</goal>
-                    </goals>
-                  </pluginExecutionFilter>
-                  <action>
-                    <ignore />
-                  </action>
-                </pluginExecution>
-                <pluginExecution>
-                  <pluginExecutionFilter>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-enforcer-plugin</artifactId>
-                    <versionRange>[1.3.1,)</versionRange>
-                    <goals>
-                      <goal>enforce</goal>
-                    </goals>
-                  </pluginExecutionFilter>
-                  <action>
-                    <ignore />
-                  </action>
-                </pluginExecution>
-                <pluginExecution>
-                  <pluginExecutionFilter>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-remote-resources-plugin</artifactId>
-                    <versionRange>[1.5,)</versionRange>
-                    <goals>
-                      <goal>process</goal>
-                    </goals>
-                  </pluginExecutionFilter>
-                  <action>
-                    <ignore />
-                  </action>
-                </pluginExecution>
-                <pluginExecution>
-                  <pluginExecutionFilter>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-dependency-plugin</artifactId>
-                    <versionRange>[2.8,)</versionRange>
-                    <goals>
-                      <goal>unpack</goal>
-                      <goal>copy</goal>
-                    </goals>
-                  </pluginExecutionFilter>
-                  <action>
-                    <ignore />
-                  </action>
-                </pluginExecution>
-                <pluginExecution>
-                  <pluginExecutionFilter>
-                    <groupId>com.github.skwakman.nodejs-maven-plugin</groupId>
-                    <artifactId>nodejs-maven-plugin</artifactId>
-                    <versionRange>[1.0.3,)</versionRange>
-                    <goals>
-                      <goal>extract</goal>
-                    </goals>
-                  </pluginExecutionFilter>
-                  <action>
-                    <ignore />
-                  </action>
-                </pluginExecution>
-                <pluginExecution>
-                  <pluginExecutionFilter>
-                    <groupId>org.apache.maven.plugins</groupId>
-                    <artifactId>maven-war-plugin</artifactId>
-                    <versionRange>[2.4,)</versionRange>
-                    <goals>
-                      <goal>exploded</goal>
-                    </goals>
-                  </pluginExecutionFilter>
-                  <action>
-                    <ignore />
-                  </action>
-                </pluginExecution>
-              </pluginExecutions>
-             </lifecycleMappingMetadata>
-           </configuration>
-        </plugin>
-      </plugins>
-    </pluginManagement>
-
-    <plugins>
-      <plugin>
-        <artifactId>maven-clean-plugin</artifactId>
-        <configuration>
-          <filesets>
-            <fileset>
-              <directory>.</directory>
-              <includes>
-                <include>brooklyn*.log</include>
-                <include>brooklyn*.log.*</include>
-                <include>stacktrace.log</include>
-                <include>test-output</include>
-                <include>prodDb.*</include>
-              </includes>
-            </fileset>
-          </filesets>
-        </configuration>
-      </plugin>
-
-      <plugin>
-        <artifactId>maven-resources-plugin</artifactId>
-      </plugin>
-
-      <plugin>
-        <artifactId>maven-eclipse-plugin</artifactId>
-        <configuration>
-          <additionalProjectnatures>
-            <projectnature>org.maven.ide.eclipse.maven2Nature</projectnature>
-          </additionalProjectnatures>
-        </configuration>
-      </plugin>
-
-      <plugin>
-        <artifactId>maven-surefire-plugin</artifactId>
-        <configuration>
-          <argLine>-Xms256m -Xmx512m -XX:MaxPermSize=512m</argLine>
-          <properties>
-            <property>
-              <name>listener</name>
-              <value>org.apache.brooklyn.test.support.LoggingVerboseReporter</value>
-            </property>
-          </properties>
-          <enableAssertions>true</enableAssertions>
-          <groups>${includedTestGroups}</groups>
-          <excludedGroups>${excludedTestGroups}</excludedGroups>
-          <testFailureIgnore>false</testFailureIgnore>
-          <systemPropertyVariables>
-            <verbose>-1</verbose>
-            <net.sourceforge.cobertura.datafile>${project.build.directory}/cobertura/cobertura.ser</net.sourceforge.cobertura.datafile>
-            <cobertura.user.java.nio>false</cobertura.user.java.nio>
-          </systemPropertyVariables>
-          <printSummary>true</printSummary>
-        </configuration>
-      </plugin>
-    </plugins>
-  </build>
-
-  <profiles>
-
-    <profile>
-      <id>Tests</id>
-      <activation>
-        <file> <exists>${basedir}/src/test</exists> </file>
-      </activation>
-      <build>
-        <plugins>
-          <plugin>
-            <artifactId>maven-jar-plugin</artifactId>
-            <inherited>true</inherited>
-            <executions>
-              <execution>
-                <id>test-jar-creation</id>
-                <goals>
-                  <goal>test-jar</goal>
-                </goals>
-                <configuration>
-                  <forceCreation>true</forceCreation>
-                  <archive combine.self="override" />
-                </configuration>
-              </execution>
-            </executions>
-          </plugin>
-        </plugins>
-      </build>
-    </profile>
-
-    <!-- run Integration tests with -PIntegration -->
-    <profile>
-      <id>Integration</id>
-      <properties>
-        <includedTestGroups>Integration</includedTestGroups>
-        <excludedTestGroups>Acceptance,Live,Live-sanity,WIP</excludedTestGroups>
-      </properties>
-    </profile>
-
-    <!-- run Live tests with -PLive -->
-    <profile>
-      <id>Live</id>
-      <properties>
-        <includedTestGroups>Live,Live-sanity</includedTestGroups>
-        <excludedTestGroups>Acceptance,WIP</excludedTestGroups>
-      </properties>
-    </profile>
-
-    <!-- run Live-sanity tests with -PLive-sanity -->
-    <profile>
-      <id>Live-sanity</id>
-      <properties>
-        <includedTestGroups>Live-sanity</includedTestGroups>
-        <excludedTestGroups>Acceptance,WIP</excludedTestGroups>
-      </properties>
-      <build>
-        <plugins>
-          <plugin>
-            <artifactId>maven-jar-plugin</artifactId>
-            <executions>
-              <execution>
-                <id>test-jar-creation</id>
-                <configuration>
-                  <skip>true</skip>
-                </configuration>
-              </execution>
-            </executions>
-          </plugin>
-        </plugins>
-      </build>
-    </profile>
-
-    <profile>
-      <id>Bundle</id>
-      <activation>
-        <file>
-          <!-- NB - this is all the leaf projects, including logback-* (with no src);
-               the archetype project neatly ignores this however -->
-          <exists>${basedir}/src</exists>
-        </file>
-      </activation>
-      <build>
-        <plugins>
-          <plugin>
-            <groupId>org.apache.felix</groupId>
-            <artifactId>maven-bundle-plugin</artifactId>
-            <extensions>true</extensions>
-            <!-- configure plugin to generate MANIFEST.MF
-                 adapted from http://blog.knowhowlab.org/2010/06/osgi-tutorial-from-project-structure-to.html -->
-            <executions>
-              <execution>
-                <id>bundle-manifest</id>
-                <phase>process-classes</phase>
-                <goals>
-                  <goal>manifest</goal>
-                </goals>
-              </execution>
-            </executions>
-            <configuration>
-              <supportedProjectTypes>
-                <supportedProjectType>jar</supportedProjectType>
-              </supportedProjectTypes>
-              <instructions>
-                <!--
-                  Exclude packages used by Brooklyn that are not OSGi bundles. Including any
-                  of the below may cause bundles to fail to load into the catalogue with
-                  messages like "Unable to resolve 150.0: missing requirement [150.0]
-                  osgi.wiring.package; (osgi.wiring.package=com.maxmind.geoip2)".
-                -->
-                <Import-Package>
-                  !com.maxmind.geoip2.*,
-                  !io.airlift.command.*,
-                  !io.cloudsoft.winrm4j.*,
-                  !javax.inject.*,
-                  !org.apache.felix.framework.*,
-                  !org.apache.http.*,
-                  !org.jclouds.googlecomputeengine.*,
-                  !org.osgi.jmx,
-                  !org.python.*,
-                  !org.reflections.*,
-                  !org.w3c.tidy.*,
-                  *
-                </Import-Package>
-                <!--
-                  Brooklyn-Feature prefix triggers inclusion of the project's metadata in the
-                  server's features list.
-                -->
-                <Brooklyn-Feature-Name>${project.name}</Brooklyn-Feature-Name>
-              </instructions>
-            </configuration>
-          </plugin>
-          <plugin>
-            <groupId>org.apache.maven.plugins</groupId>
-            <artifactId>maven-jar-plugin</artifactId>
-            <configuration>
-              <archive>
-                <manifestFile>${project.build.outputDirectory}/META-INF/MANIFEST.MF</manifestFile>
-              </archive>
-            </configuration>
-          </plugin>
-        </plugins>
-      </build>
-    </profile>
-
-    <!-- different properties used to deploy to different locations depending on profiles;
-         default is cloudsoft filesystem repo, but some sources still use cloudsoft artifactory as source
-         and soon we will support artifactory. use this profile for the ASF repositories and
-         sonatype-oss-release profile for the Sonatype OSS repositories.
-    -->
-    <!-- profile>
-      <id>apache-release</id>
-      <activation>
-        <property>
-          <name>brooklyn.deployTo</name>
-          <value>apache</value>
-        </property>
-      </activation>
-      <distributionManagement>
-        <repository>
-          <id>apache.releases.https</id>
-          <name>Apache Release Distribution Repository</name>
-          <url>https://repository.apache.org/service/local/staging/deploy/maven2</url>
-        </repository>
-        <snapshotRepository>
-          <id>apache.snapshots.https</id>
-          <name>Apache Development Snapshot Repository</name>
-          <url>https://repository.apache.org/content/repositories/snapshots</url>
-        </snapshotRepository>
-      </distributionManagement>
-    </profile -->
-  </profiles>
-
-</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/pom.xml b/brooklyn-dist/pom.xml
deleted file mode 100644
index 12ebdd9..0000000
--- a/brooklyn-dist/pom.xml
+++ /dev/null
@@ -1,83 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-	xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-
-    <modelVersion>4.0.0</modelVersion>
-    <parent>
-        <groupId>org.apache.brooklyn</groupId>
-        <artifactId>brooklyn-parent</artifactId>
-        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-        <relativePath>../brooklyn-server/parent/pom.xml</relativePath>
-    </parent>
-
-    <groupId>org.apache.brooklyn</groupId>
-    <artifactId>brooklyn-dist-root</artifactId>
-    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-    <packaging>pom</packaging>
-
-    <name>Brooklyn Dist Root</name>
-    <description>
-        Brooklyn Dist project root, serving as the ancestor POM for dist projects --
-        declaring modules to build
-    </description>
-    <url>https://brooklyn.apache.org/</url>
-    <inceptionYear>2012</inceptionYear>
-
-    <developers>
-        <!-- TODO update with PMC members and committers -->
-    </developers>
-
-    <scm>
-        <connection>scm:git:https://git-wip-us.apache.org/repos/asf/incubator-brooklyn.git</connection>
-        <developerConnection>scm:git:https://git-wip-us.apache.org/repos/asf/incubator-brooklyn.git</developerConnection>
-        <url>https://git-wip-us.apache.org/repos/asf?p=incubator-brooklyn.git</url>
-        <tag>HEAD</tag>
-    </scm>
-
-    <issueManagement>
-        <system>JIRA</system>
-        <url>https://issues.apache.org/jira/browse/BROOKLYN</url>
-    </issueManagement>
-    <ciManagement>
-        <system>Jenkins</system>
-        <url>https://builds.apache.org/job/incubator-brooklyn-master-build/</url>
-    </ciManagement>
-    <mailingLists>
-        <mailingList>
-            <name>Brooklyn Developer List</name>
-            <subscribe>dev-subscribe@brooklyn.apache.org</subscribe>
-            <unsubscribe>dev-unsubscribe@brooklyn.apache.org</unsubscribe>
-            <post>dev@brooklyn.apache.org</post>
-            <archive>
-                http://mail-archives.apache.org/mod_mbox/brooklyn-dev/
-            </archive>
-        </mailingList>
-    </mailingLists>
-
-    <modules>
-        <module>downstream-parent</module>
-        <module>all</module>
-        <module>dist</module>
-        <module>vagrant</module>
-        <module>archetypes/quickstart</module>
-    </modules>
-
-</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/release/.gitignore
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/.gitignore b/brooklyn-dist/release/.gitignore
deleted file mode 100644
index 16d63d3..0000000
--- a/brooklyn-dist/release/.gitignore
+++ /dev/null
@@ -1,2 +0,0 @@
-.vagrant
-tmp

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/release/README.md
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/README.md b/brooklyn-dist/release/README.md
deleted file mode 100644
index 325b165..0000000
--- a/brooklyn-dist/release/README.md
+++ /dev/null
@@ -1,50 +0,0 @@
-Release Scripts and Helpers
-===========================
-
-This folder contains a number of items that will assist in the production of Brooklyn releases.
-
-
-Release scripts - change-version.sh and make-release-artifacts.sh
------------------------------------------------------------------
-
-`change-version.sh` will update version numbers across the whole distribution.  It is recommended to use this script
-rather than "rolling your own" or using a manual process, as you risk missing out some version numbers (and
-accidentally changing some that should not be changed).
-
-`make-release-artifacts.sh` will produce the release artifacts with appropriate signatures. It is recommended to use
-this script rather than "rolling your own" or using a manual process, as this script codifies several Apache
-requirements about the release artifacts.
-
-These scripts are fully documented in **Release Process** pages on the website.
-
-
-Vagrant configuration
----------------------
-
-The `Vagrantfile` and associated files `settings.xml` and `gpg-agent.conf` are for setting up a virtual machine hosting
-a complete and clean development environment. You may benefit from using this environment when making the release, but
-it is not required that you do so.
-
-The environment is a single VM that configured with all the tools needed to make the release. It also configures GnuPG
-by copying your `gpg.conf`, `secring.gpg` and `pubring.gpg` into the VM; also copied is your `.gitconfig`. The
-GnuPG agent is configured to assist with the release signing by caching your passphrase, so you will only need to enter
-it once during the build process. A Maven `settings.xml` is provided to assist with the upload to Apache's Nexus server.
-Finally the canonical Git repository for Apache Brooklyn is cloned into the home directory.
-
-You should edit `settings.xml` before deployment, or `~/.m2/settings.xml` inside the VM after deployment, to include
-your Apache credentials.
-
-Assuming you have VirtualBox and Vagrant already installed, you should simply be able to run `vagrant up` to create the
-VM, and then `vagrant ssh` to get a shell prompt inside the VM. Finally run `vagrant destroy` to clean up afterwards.
-
-This folder is mounted at `/vagrant` inside the VM - this means the release helpers are close to hand, so you can
-run for example `/vagrant/make-release/artifacts.sh`.
-
-
-Pull request reporting
-----------------------
-
-The files in `pull-request-reports`, mainly `pr_report.rb` 
-(and associated files `Gemfile` and `Gemfile.lock`) uses the GitHub API to extract a list of open pull
-requests, and writes a summary into `pr_report.tsv`. This could then be imported into Google Sheets to provide a handy
-way of classifying and managing outstanding PRs ahead of making a release.

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/release/Vagrantfile
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/Vagrantfile b/brooklyn-dist/release/Vagrantfile
deleted file mode 100644
index 016c48f..0000000
--- a/brooklyn-dist/release/Vagrantfile
+++ /dev/null
@@ -1,66 +0,0 @@
-# -*- mode: ruby -*-
-# vi: set ft=ruby :
-#
-# 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.
-#
-
-# Vagrantfile that creates a basic workstation for compiling Brooklyn and
-# running tests. Particularly useful for running integration tests, as you
-# can clean up any failed tests simply by destroying and rebuilding the
-# Vagrant instance.
-
-# All Vagrant configuration is done below. The "2" in Vagrant.configure
-# configures the configuration version (we support older styles for
-# backwards compatibility). Please don't change it unless you know what
-# you're doing.
-Vagrant.configure(2) do |config|
-
-  # Base on Ubuntu 14.04 LTS
-  config.vm.box = "ubuntu/trusty64"
-
-  # Provider-specific configuration so you can fine-tune various
-  # backing providers for Vagrant. These expose provider-specific options.
-  config.vm.provider "virtualbox" do |vb|
-    vb.memory = "2048"
-  end
-
-  config.vm.network "forwarded_port", guest: 8008, host: 8008
-
-  config.vm.provision "file", source: "~/.gitconfig", destination: ".gitconfig"
-  config.vm.provision "file", source: "~/.gnupg/gpg.conf", destination: ".gnupg/gpg.conf"
-  config.vm.provision "file", source: "~/.gnupg/pubring.gpg", destination: ".gnupg/pubring.gpg"
-  config.vm.provision "file", source: "~/.gnupg/secring.gpg", destination: ".gnupg/secring.gpg"
-  config.vm.provision "file", source: "gpg-agent.conf", destination: ".gnupg/gpg-agent.conf"
-  config.vm.provision "file", source: "settings.xml", destination: ".m2/settings.xml"
-
-  # Update the VM, install Java and Maven, enable passwordless-ssh-to-localhost,
-  # clone the canonical repository
-  config.vm.provision "shell", inline: <<-SHELL
-    apt-get update
-    apt-get upgrade -y
-    apt-get install -y default-jdk maven git xmlstarlet zip unzip language-pack-en vim-nox gnupg2 gnupg-agent pinentry-curses
-    wget -q -O /tmp/artifactory.zip http://bit.ly/Hqv9aj
-    mkdir -p /opt
-    unzip /tmp/artifactory.zip -d /opt
-    sudo sed -i -e '/Connector port=/ s/=\".*\"/=\"'"8008"'\"/' /opt/artifactory*/tomcat/conf/server.xml
-    /opt/artifactory*/bin/installService.sh
-    service artifactory start
-    chmod -R go= ~vagrant/.gnupg
-    cat /etc/ssh/ssh_host_*_key.pub | awk '{print "localhost,127.0.0.1 "$0}' >> /etc/ssh/ssh_known_hosts
-    su -c 'ssh-keygen -t rsa -b 2048 -N "" -f ~/.ssh/id_rsa; cat ~/.ssh/*.pub >> ~/.ssh/authorized_keys' vagrant
-    su -c 'git clone https://git-wip-us.apache.org/repos/asf/incubator-brooklyn.git apache-brooklyn-git' vagrant
-  SHELL
-end

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/release/change-version.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/change-version.sh b/brooklyn-dist/release/change-version.sh
deleted file mode 100755
index 4b77749..0000000
--- a/brooklyn-dist/release/change-version.sh
+++ /dev/null
@@ -1,70 +0,0 @@
-#!/usr/bin/env bash
-#
-# 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.
-#
-
-set -e
-
-# changes the version everywhere
-# usage, e.g.:  change-version.sh 0.3.0-SNAPSHOT 0.3.0-RC1
-#          or:  change-version.sh MARKER 0.3.0-SNAPSHOT 0.3.0-RC1
-
-[ -d .git ] || {
-  echo "Must run in brooklyn project root directory"
-  exit 1
-}
-
-if [ "$#" -eq 2 ]; then
-  VERSION_MARKER=BROOKLYN_VERSION
-elif [ "$#" -eq 3 ]; then
-  VERSION_MARKER=$1_VERSION
-  shift;
-else
-  echo "Usage:  "$0" [VERSION_MARKER] CURRENT_VERSION NEW_VERSION"
-  echo " e.g.:  "$0" BROOKLYN 0.3.0-SNAPSHOT 0.3.0-RC1"
-  exit 1
-fi
-
-# remove binaries and stuff
-if [ -f pom.xml ] && [ -d target ] ; then mvn clean ; fi
-
-VERSION_MARKER_NL=${VERSION_MARKER}_BELOW
-CURRENT_VERSION=$1
-NEW_VERSION=$2
-
-# grep --exclude-dir working only in recent versions, not on all platforms, replace with find;
-# skip folders named "ignored" or .xxx (but not the current folder ".");
-# exclude log, war, etc. files;
-# use null delimiters so files containing spaces are supported;
-# pass /dev/null as the first file to search in, so the command doesn't fail if find doesn't match any files;
-# add || true for the case where grep doesn't have matches, so the script doesn't halt
-# If there's an error "Argument list too long" add -n20 to xargs arguments and loop over $FILE around sed
-FILES=`find . -type d \( -name ignored -or -name .?\* \) -prune \
-       -o -type f -not \( -name \*.log -or -name '*.war' -or -name '*.min.js' -or -name '*.min.css' \) -print0 | \
-       xargs -0 grep -l "${VERSION_MARKER}\|${VERSION_MARKER_NL}" /dev/null || true`
-
-FILES_COUNT=`echo $FILES | wc | awk '{print $2}'`
-
-if [ ${FILES_COUNT} -ne 0 ]; then
-    # search for files containing version markers
-    sed -i.bak -e "/${VERSION_MARKER}/s/${CURRENT_VERSION}/${NEW_VERSION}/g" $FILES
-    sed -i.bak -e "/${VERSION_MARKER_NL}/{n;s/${CURRENT_VERSION}/${NEW_VERSION}/g;}" $FILES
-fi
-
-echo "Changed ${VERSION_MARKER} from ${CURRENT_VERSION} to ${NEW_VERSION} for "${FILES_COUNT}" files"
-echo "(Do a \`find . -name \"*.bak\" -delete\`  to delete the backup files.)"

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/release/gpg-agent.conf
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/gpg-agent.conf b/brooklyn-dist/release/gpg-agent.conf
deleted file mode 100644
index 3cd0291..0000000
--- a/brooklyn-dist/release/gpg-agent.conf
+++ /dev/null
@@ -1,2 +0,0 @@
-default-cache-ttl 7200
-max-cache-ttl 86400

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/release/make-release-artifacts.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/make-release-artifacts.sh b/brooklyn-dist/release/make-release-artifacts.sh
deleted file mode 100755
index 90f138e..0000000
--- a/brooklyn-dist/release/make-release-artifacts.sh
+++ /dev/null
@@ -1,273 +0,0 @@
-#!/bin/bash
-#
-# 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.
-#
-
-# Creates the following releases with archives (.tar.gz/.zip), signatures and checksums:
-#   binary  (-bin)     - contains the brooklyn dist binary release
-#   source  (-src)     - contains all the source code files that are permitted to be released
-#   vagrant (-vagrant) - contains a Vagrantfile/scripts to start a Brooklyn getting started environment
-
-set -e
-
-###############################################################################
-fail() {
-    echo >&2 "$@"
-    exit 1
-}
-
-###############################################################################
-show_help() {
-    cat >&2 <<END
-Usage: make-release-artifacts.sh [-v version] [-r rc_number]
-Prepares and builds the source and binary distribution artifacts of a Brooklyn
-release.
-
-  -vVERSION                  overrides the name of this version, if detection
-                             from pom.xml is not accurate for any reason.
-  -rRC_NUMBER                specifies the release candidate number. The
-                             produced artifact names include the 'rc' suffix,
-                             but the contents of the archive artifact do *not*
-                             include the suffix. Therefore, turning a release
-                             candidate into a release requires only renaming
-                             the artifacts.
-  -y                         answers "y" to all questions automatically, to
-                             use defaults and make this suitable for batch mode
-
-Specifying the RC number is required. Specifying the version number is
-discouraged; if auto detection is not working, then this script is buggy.
-
-Additionally if APACHE_DIST_SVN_DIR is set, this will transfer artifacts to
-that directory and svn commit them.
-END
-# ruler                      --------------------------------------------------
-}
-
-###############################################################################
-confirm() {
-    # call with a prompt string or use a default
-    if [ "${batch_confirm_y}" == "true" ] ; then
-        true
-    else
-      read -r -p "${1:-Are you sure? [y/N]} " response
-      case $response in
-        [yY][eE][sS]|[yY]) 
-            true
-            ;;
-        *)
-            false
-            ;;
-      esac
-    fi
-}
-
-###############################################################################
-detect_version() {
-    if [ \! -z "${current_version}" ]; then
-        return
-    fi
-
-    set +e
-    current_version=$( xmlstarlet select -t -v '/_:project/_:version/text()' pom.xml 2>/dev/null )
-    success=$?
-    set -e
-    if [ "${success}" -ne 0 -o -z "${current_version}" ]; then
-        fail Could not detect version number
-    fi
-}
-
-###############################################################################
-# Argument parsing
-rc_suffix=
-OPTIND=1
-while getopts "h?v:r:y?" opt; do
-    case "$opt" in
-        h|\?)
-            show_help
-            exit 0
-            ;;
-        v)
-            current_version=$OPTARG
-            ;;
-        r)
-            rc_suffix=$OPTARG
-            ;;
-        y)
-            batch_confirm_y=true
-            ;;
-        *)
-            show_help
-            exit 1
-    esac
-done
-
-shift $((OPTIND-1))
-[ "$1" = "--" ] && shift
-
-###############################################################################
-# Prerequisite checks
-[ -d .git ] || fail Must run in brooklyn project root directory
-
-detect_version
-
-###############################################################################
-# Determine all filenames and paths, and confirm
-
-release_name=apache-brooklyn-${current_version}
-if [ -z "$rc_suffix" ]; then
-    fail Specifying the RC number is required
-else
-    artifact_name=${release_name}-rc${rc_suffix}
-fi
-
-release_script_dir=$( cd $( dirname $0 ) && pwd )
-brooklyn_dir=$( pwd )
-rm -rf ${release_script_dir}/tmp
-staging_dir="${release_script_dir}/tmp/source/"
-src_staging_dir="${release_script_dir}/tmp/source/${release_name}-src"
-bin_staging_dir="${release_script_dir}/tmp/bin/"
-artifact_dir="${release_script_dir}/tmp/${artifact_name}"
-
-echo "The version is ${current_version}"
-echo "The rc suffix is rc${rc_suffix}"
-echo "The release name is ${release_name}"
-echo "The artifact name is ${artifact_name}"
-echo "The artifact directory is ${artifact_dir}"
-if [ ! -z "${APACHE_DIST_SVN_DIR}" ] ; then
-  echo "The artifacts will be copied and uploaded via ${APACHE_DIST_SVN_DIR}"
-else
-  echo "The artifacts will not be copied and uploaded to the svn repo"
-fi
-echo ""
-confirm "Is this information correct? [y/N]" || exit
-echo ""
-echo "WARNING! This script will run 'git clean -dxf' to remove ALL files that are not under Git source control."
-echo "This includes build artifacts and all uncommitted local files and directories."
-echo "If you want to check what will happen, answer no and run 'git clean -dxn' to dry run."
-echo ""
-confirm || exit
-echo ""
-echo "This script will cause uploads to be made to a staging repository on the Apache Nexus server."
-echo ""
-confirm "Shall I continue?  [y/N]" || exit
-
-###############################################################################
-# Clean the workspace
-git clean -dxf
-
-###############################################################################
-# Source release
-echo "Creating source release folder ${release_name}"
-set -x
-mkdir -p ${src_staging_dir}
-mkdir -p ${bin_staging_dir}
-# exclude: 
-# * docs (which isn't part of the release, and adding license headers to js files is cumbersome)
-# * sandbox (which hasn't been vetted so thoroughly)
-# * release (where this is running, and people who *have* the release don't need to make it)
-# * jars and friends (these are sometimes included for tests, but those are marked as skippable,
-#     and apache convention does not allow them in source builds; see PR #365
-rsync -rtp --exclude .git\* --exclude brooklyn-docs/ --exclude brooklyn-library/sandbox/ --exclude brooklyn-dist/release/ --exclude '**/*.[ejw]ar' . ${staging_dir}/${release_name}-src
-
-rm -rf ${artifact_dir}
-mkdir -p ${artifact_dir}
-set +x
-echo "Creating artifact ${artifact_dir}/${artifact_name}-src.tar.gz and .zip"
-set -x
-( cd ${staging_dir} && tar czf ${artifact_dir}/${artifact_name}-src.tar.gz ${release_name}-src )
-( cd ${staging_dir} && zip -qr ${artifact_dir}/${artifact_name}-src.zip ${release_name}-src )
-
-###############################################################################
-# Binary release
-set +x
-echo "Proceeding to build binary release"
-set -x
-
-# Set up GPG agent
-if ps x | grep [g]pg-agent ; then
-  echo "gpg-agent already running; assuming it is set up and exported correctly."
-else
-  eval $(gpg-agent --daemon --no-grab --write-env-file $HOME/.gpg-agent-info)
-  GPG_TTY=$(tty)
-  export GPG_TTY GPG_AGENT_INFO
-fi
-
-# Workaround for bug BROOKLYN-1
-( cd ${src_staging_dir} && mvn clean --projects :brooklyn-archetype-quickstart )
-
-# Perform the build and deploy to Nexus staging repository
-( cd ${src_staging_dir} && mvn deploy -Papache-release )
-## To test the script without a big deploy, use the line below instead of above
-#( cd ${src_staging_dir} && mvn clean install )
-
-# Re-pack the archive with the correct names
-tar xzf ${src_staging_dir}/brooklyn-dist/dist/target/brooklyn-dist-${current_version}-dist.tar.gz -C ${bin_staging_dir}
-mv ${bin_staging_dir}/brooklyn-dist-${current_version} ${bin_staging_dir}/${release_name}-bin
-
-( cd ${bin_staging_dir} && tar czf ${artifact_dir}/${artifact_name}-bin.tar.gz ${release_name}-bin )
-( cd ${bin_staging_dir} && zip -qr ${artifact_dir}/${artifact_name}-bin.zip ${release_name}-bin )
-
-###############################################################################
-# Vagrant release
-set +x
-echo "Proceeding to rename and repackage vagrant environment release"
-set -x
-
-# Re-pack the archive with the correct names
-tar xzf ${src_staging_dir}/brooklyn-dist/vagrant/target/brooklyn-vagrant-${current_version}-dist.tar.gz -C ${bin_staging_dir}
-mv ${bin_staging_dir}/brooklyn-vagrant-${current_version} ${bin_staging_dir}/${release_name}-vagrant
-
-( cd ${bin_staging_dir} && tar czf ${artifact_dir}/${artifact_name}-vagrant.tar.gz ${release_name}-vagrant )
-( cd ${bin_staging_dir} && zip -qr ${artifact_dir}/${artifact_name}-vagrant.zip ${release_name}-vagrant )
-
-###############################################################################
-# Signatures and checksums
-
-# OSX doesn't have sha256sum, even if MacPorts md5sha1sum package is installed.
-# Easy to fake it though.
-which sha256sum >/dev/null || alias sha256sum='shasum -a 256' && shopt -s expand_aliases
-
-( cd ${artifact_dir} &&
-    for a in *.tar.gz *.zip; do
-        md5sum -b ${a} > ${a}.md5
-        sha1sum -b ${a} > ${a}.sha1
-        sha256sum -b ${a} > ${a}.sha256
-        gpg2 --armor --output ${a}.asc --detach-sig ${a}
-    done
-)
-
-###############################################################################
-
-if [ ! -z "${APACHE_DIST_SVN_DIR}" ] ; then
-  pushd ${APACHE_DIST_SVN_DIR}
-  rm -rf ${artifact_name}
-  cp -r ${artifact_dir} ${artifact_name}
-  svn add ${artifact_name}
-  svn commit --message "Add ${artifact_name} artifacts for incubator/brooklyn"
-  artifact_dir=${APACHE_DIST_SVN_DIR}/${artifact_name}
-  popd
-fi
-
-###############################################################################
-# Conclusion
-
-set +x
-echo "The release is done - here is what has been created:"
-ls ${artifact_dir}
-echo "You can find these files in: ${artifact_dir}"
-echo "The git commit ID for the voting emails is: $( git rev-parse HEAD )"

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/release/print-vote-email.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/print-vote-email.sh b/brooklyn-dist/release/print-vote-email.sh
deleted file mode 100755
index 5fd2256..0000000
--- a/brooklyn-dist/release/print-vote-email.sh
+++ /dev/null
@@ -1,130 +0,0 @@
-#!/bin/bash
-#
-# 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.
-#
-
-# prints a sample email with all the correct information
-
-set +x
-
-fail() {
-    echo >&2 "$@"
-    exit 1
-}
-
-if [ -z "${VERSION_NAME}" ] ; then fail VERSION_NAME must be set ; fi
-if [ -z "${RC_NUMBER}" ] ; then fail RC_NUMBER must be set ; fi
-
-base=apache-brooklyn-${VERSION_NAME}-rc${RC_NUMBER}
-
-if [ -z "$1" ] ; then fail "A single argument being the staging repo ID must be supplied, e.g. orgapachebrooklyn-1234" ; fi
-
-staging_repo_id=$1
-archetype_check=`curl https://repository.apache.org/content/repositories/${staging_repo_id}/archetype-catalog.xml 2> /dev/null`
-if ! echo $archetype_check | grep brooklyn-archetype-quickstart > /dev/null ; then
-  fail staging repo looks wrong at https://repository.apache.org/content/repositories/${staging_repo_id}
-fi
-if ! echo $archetype_check | grep ${VERSION_NAME} > /dev/null ; then
-  fail wrong version at https://repository.apache.org/content/repositories/${staging_repo_id}
-fi
-
-artifact=release/tmp/${base}/${base}-bin.tar.gz
-if [ ! -f $artifact ] ; then
-  fail could not find artifact $artifact
-fi
-if [ -z "$APACHE_ID" ] ; then
-  APACHE_ID=`gpg2 --verify ${artifact}.asc ${artifact} 2>&1 | egrep -o '[^<]*...@apache.org>' | cut -d @ -f 1`
-fi
-if [ -z "$APACHE_ID" ] ; then
-  fail "could not deduce APACHE_ID (your apache username); are files signed correctly?"
-fi
-if ! ( gpg2 --verify ${artifact}.asc ${artifact} 2>&1 | grep ${APACHE_ID}@apache.org > /dev/null ) ; then
-  fail "could not verify signature; are files signed correctly and ID ${APACHE_ID} correct?"
-fi
-
-cat <<EOF
-
-Subject: [VOTE] Release Apache Brooklyn ${VERSION_NAME} [rc${RC_NUMBER}]
-
-
-This is to call for a vote for the release of Apache Brooklyn ${VERSION_NAME}.
-
-This release comprises of a source code distribution, and a corresponding
-binary distribution, and Maven artifacts.
-
-The source and binary distributions, including signatures, digests, etc. can
-be found at:
-
-  https://dist.apache.org/repos/dist/dev/incubator/brooklyn/${base}
-
-The artifact SHA-256 checksums are as follows:
-
-EOF
-
-cat release/tmp/${base}/*.sha256 | awk '{print "  "$0}'
-
-cat <<EOF
-
-The Nexus staging repository for the Maven artifacts is located at:
-
-    https://repository.apache.org/content/repositories/${staging_repo_id}
-
-All release artifacts are signed with the following key:
-
-    https://people.apache.org/keys/committer/${APACHE_ID}.asc
-
-KEYS file available here:
-
-    https://dist.apache.org/repos/dist/release/incubator/brooklyn/KEYS
-
-
-The artifacts were built from git commit ID $( git rev-parse HEAD ):
-
-    https://git-wip-us.apache.org/repos/asf?p=incubator-brooklyn.git;a=commit;h=$( git rev-parse HEAD )
-
-
-Please vote on releasing this package as Apache Brooklyn ${VERSION_NAME}.
-
-The vote will be open for at least 72 hours.
-[ ] +1 Release this package as Apache Brooklyn ${VERSION_NAME}
-[ ] +0 no opinion
-[ ] -1 Do not release this package because ...
-
-
-Thanks!
-EOF
-
-cat <<EOF
-
-
-
-CHECKLIST for reference
-
-[ ] Download links work.
-[ ] Binaries work.
-[ ] Checksums and PGP signatures are valid.
-[ ] Expanded source archive matches contents of RC tag.
-[ ] Expanded source archive builds and passes tests.
-[ ] LICENSE is present and correct.
-[ ] NOTICE is present and correct, including copyright date.
-[ ] All files have license headers where appropriate.
-[ ] All dependencies have compatible licenses.
-[ ] No compiled archives bundled in source archive.
-[ ] I follow this project’s commits list.
-
-EOF

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/release/pull-request-reports/Gemfile
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/pull-request-reports/Gemfile b/brooklyn-dist/release/pull-request-reports/Gemfile
deleted file mode 100644
index 8ab84b5..0000000
--- a/brooklyn-dist/release/pull-request-reports/Gemfile
+++ /dev/null
@@ -1,5 +0,0 @@
-#ruby=ruby-2.1.2
-#ruby-gemset=brooklyn-release-helpers
-
-source 'https://rubygems.org'
-gem 'github_api'

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/release/pull-request-reports/Gemfile.lock
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/pull-request-reports/Gemfile.lock b/brooklyn-dist/release/pull-request-reports/Gemfile.lock
deleted file mode 100644
index 859202a..0000000
--- a/brooklyn-dist/release/pull-request-reports/Gemfile.lock
+++ /dev/null
@@ -1,38 +0,0 @@
-GEM
-  remote: https://rubygems.org/
-  specs:
-    addressable (2.3.8)
-    descendants_tracker (0.0.4)
-      thread_safe (~> 0.3, >= 0.3.1)
-    faraday (0.9.1)
-      multipart-post (>= 1.2, < 3)
-    github_api (0.12.3)
-      addressable (~> 2.3)
-      descendants_tracker (~> 0.0.4)
-      faraday (~> 0.8, < 0.10)
-      hashie (>= 3.3)
-      multi_json (>= 1.7.5, < 2.0)
-      nokogiri (~> 1.6.3)
-      oauth2
-    hashie (3.4.2)
-    jwt (1.5.1)
-    mini_portile (0.6.2)
-    multi_json (1.11.1)
-    multi_xml (0.5.5)
-    multipart-post (2.0.0)
-    nokogiri (1.6.6.2)
-      mini_portile (~> 0.6.0)
-    oauth2 (1.0.0)
-      faraday (>= 0.8, < 0.10)
-      jwt (~> 1.0)
-      multi_json (~> 1.3)
-      multi_xml (~> 0.5)
-      rack (~> 1.2)
-    rack (1.6.4)
-    thread_safe (0.3.5)
-
-PLATFORMS
-  ruby
-
-DEPENDENCIES
-  github_api

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/release/pull-request-reports/pr_report.rb
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/pull-request-reports/pr_report.rb b/brooklyn-dist/release/pull-request-reports/pr_report.rb
deleted file mode 100644
index 95b6317..0000000
--- a/brooklyn-dist/release/pull-request-reports/pr_report.rb
+++ /dev/null
@@ -1,12 +0,0 @@
-#ruby
-
-require 'CSV'
-require 'github_api'
-
-gh = Github.new
-
-CSV.open("pr_report.tsv", "wb", { :col_sep => "\t" }) do |csv|
-  gh.pull_requests.list('apache', 'incubator-brooklyn').
-      select { |pr| pr.state == "open" }.
-      each { |pr| csv << [ pr.number, pr.title, pr.created_at, pr.user.login ] }
-end

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/release/settings.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/settings.xml b/brooklyn-dist/release/settings.xml
deleted file mode 100644
index 2b03994..0000000
--- a/brooklyn-dist/release/settings.xml
+++ /dev/null
@@ -1,29 +0,0 @@
-<?xml version="1.0"?>
-<settings xsi:schemaLocation="http://maven.apache.org/SETTINGS/1.1.0 http://maven.apache.org/xsd/settings-1.1.0.xsd"
-          xmlns="http://maven.apache.org/SETTINGS/1.1.0"
-          xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
-
-    <servers>
-        <!-- Required for uploads to Apache's Nexus instance. These are LDAP credentials - the same credentials you
-           - would use to log in to Git and Jenkins (but not JIRA) -->
-        <server>
-            <id>apache.snapshots.https</id>
-            <username>xxx</username>
-            <password>xxx</password>
-        </server>
-        <server>
-            <id>apache.releases.https</id>
-            <username>xxx</username>
-            <password>xxx</password>
-        </server>
-
-        <!-- This is used for deployments to the play Artifactory instance that is provisioned by the Vagrant scripts.
-           - It may be safely ignored. -->
-        <server>
-            <id>vagrant-ubuntu-trusty-64</id>
-            <username>admin</username>
-            <password>password</password>
-        </server>
-    </servers>
-
-</settings>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/scripts/buildAndTest
----------------------------------------------------------------------
diff --git a/brooklyn-dist/scripts/buildAndTest b/brooklyn-dist/scripts/buildAndTest
deleted file mode 100755
index 45c1a26..0000000
--- a/brooklyn-dist/scripts/buildAndTest
+++ /dev/null
@@ -1,102 +0,0 @@
-#!/bin/bash
-#
-# 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.
-#
-# Convenience script to clean, build, install and run unit and/or integration tests.
-# Recommend you run this prior to pushing to Github to reduce the chances of breaking
-# the continuous integration (unit tests) or overnight builds (integration tests.)
-#
-# Also very useful when using "git bisect" to find out which commit was responsible
-# for breaking the overnight build - invoke as "git bisect run ./buildAndRun"
-#
-# Run "./buildAndRun --help" to see the usage.
-#
-
-# Has an integration test left a Java process running? See if there is any running
-# Java processes and offer to kill them/
-cleanup(){
-    PROCS=$(ps ax | grep '[j]ava' | grep -v set_tab_title)
-    if [ ! -z "${PROCS}" ]; then
-	echo "These Java processes are running:"
-	echo ${PROCS}
-	echo -n "Kill them? y=yes, n=no, x=abort: "
-	read $RESPONSE
-	[ "${RESPONSE}" = "y" ] && killall java && sleep 1s
-	[ "${RESPONSE}" = "x" ] && exit 50
-    fi
-}
-
-# Check a return value, and bail if its non-zero - invoke as "assert $? 'Unit tests'"
-assert(){
-    [ $1 -eq 0 ] && return
-    echo '*** Command returned '$1' on '$2
-    exit $1
-}
-
-# The defaults
-unit=1
-integration=1
-
-if [ ! -z "$1" ]; then
-    case "$1" in
-	u)
-	    unit=1
-	    integration=0
-	    ;;
-	i)
-	    unit=0
-	    integration=1
-	    ;;
-	ui)
-	    unit=1
-	    integration=1
-	    ;;
-	b)
-	    unit=0
-	    integration=0
-	    ;;
-	*)
-	    echo >&2 Usage: buildAndTest [action]
-	    echo >&2 where action is:
-	    echo >&2 u - build from clean and run unit tests
-	    echo >&2 i - build from clean and run integration tests
-	    echo >&2 ui - build from clean and run unit and integration tests \(default\)
-	    echo >&2 b - build from clean and do not run any tests
-	    exit 1
-	    ;;
-    esac
-fi
-
-echo '*** BUILD'
-mvn clean install -DskipTests -PConsole
-assert $? 'BUILD'
-cleanup
-if [ $unit -eq 1 ]; then
-    echo '*** UNIT TEST'
-    mvn integration-test -PConsole
-    assert $? 'UNIT TEST'
-    cleanup
-fi
-if [ $integration -eq 1 ]; then
-    echo '*** INTEGRATION TEST'
-    mvn integration-test -PConsole,Integration
-    assert $? 'INTEGRATION TEST'
-    cleanup
-fi
-
-exit 0

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/scripts/grep-in-poms.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/scripts/grep-in-poms.sh b/brooklyn-dist/scripts/grep-in-poms.sh
deleted file mode 100755
index aca9258..0000000
--- a/brooklyn-dist/scripts/grep-in-poms.sh
+++ /dev/null
@@ -1,25 +0,0 @@
-#!/usr/bin/env bash
-#
-# 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.
-#
-
-# usage: run in the root dir of a project, it will grep in poms up to 3 levels deep
-# e.g. where are shaded jars defined?
-# brooklyn% grep-in-poms -i slf4j
-
-grep $* {.,*,*/*,*/*/*}/pom.xml

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/scripts/release-branch-from-master
----------------------------------------------------------------------
diff --git a/brooklyn-dist/scripts/release-branch-from-master b/brooklyn-dist/scripts/release-branch-from-master
deleted file mode 100755
index 8d7befa..0000000
--- a/brooklyn-dist/scripts/release-branch-from-master
+++ /dev/null
@@ -1,114 +0,0 @@
-#!/bin/bash -e
-#
-# 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.
-#
-
-usage(){
-	echo >&2 'Usage: release-branch-from-master --release <version> [ --release-suffix <suffix> ]'
-	echo >&2 '                                  --master <version>  [ --master-suffix <suffix> ]'
-	echo >&2 'Creates a release branch, and updates the version number in both the branch and master.'
-	echo >&2 '<version> should be a two-part version number, such as 3.6 or 4.0.'
-	echo >&2 '<suffix> will normally be of the form ".patchlevel", plus "-RC1" or similar if required,'
-	echo >&2 'plus "-SNAPSHOT". Example: ".0.RC1-SNAPSHOT". The defaults for the suffix are normally sensible.'
-	echo >&2 'This command will preview what it is going to do and require confirmation before it makes changes.'
-}
-
-release_ver=
-release_ver_suffix=.0-RC1-SNAPSHOT
-master_ver=
-master_ver_suffix=.0-SNAPSHOT
-
-[ $# -eq 0 ] && echo >&2 "No arguments given, so I'm going to try and figure it out myself. Invoke with the --help option if you want to find how to invoke this script."
-
-while [ $# -gt 0 ]; do
-	case $1 in
-		--release)			shift; release_ver=$1;;
-		--release-suffix)	shift; release_ver_suffix=$1;;
-		--master)			shift; master_ver=$1;;
-		--master-suffix)	shift; master_ver_suffix=$1;;
-		*)					usage; exit 1;;
-	esac
-	shift
-done
-
-# Use xpath to query the current version number in the pom
-xpath='xpath'
-type -P $xpath &>/dev/null && {
-	set +e
-	current_version=$( xpath pom.xml '/project/version/text()' 2>/dev/null )
-	( echo ${current_version} | grep -qE '^([0-9]+).([0-9]+).0-SNAPSHOT$' )
-	current_version_valid=$?
-	set -e 
-} || { 
-	echo "Cannot guess version number as $xpath command not found."
-	current_version_valid=1
-}
-
-if [ "${current_version_valid}" -ne 0 -a -z "${release_ver}" -a -z "${master_ver}" ]; then
-	echo >&2 "Detected current version as '${current_version}', but I can't parse this. Please supply --release and --master parameters."
-	exit 1
-fi
-
-[ -z "${release_ver}" ] && {
-	release_ver=${current_version%-SNAPSHOT}
-	release_ver=${release_ver%.0}
-	[ -z "${release_ver}" ] && { echo >&2 Could not determine the version of the release branch. Please use the --release parameter. ; exit 1 ; }
-}
-
-[ -z "${master_ver}" ] && {
-	master_ver=$( echo ${current_version} | perl -n -e 'if (/^(\d+).(\d+)(.*)$/) { printf "%s.%s\n", $1, $2+1 }' )
-	[ -z "${master_ver}" ] && { echo >&2 Could not determine the version of the master branch. Please use the --master parameter. ; exit 1 ; }
-}
-
-version_on_branch=${release_ver}${release_ver_suffix}
-version_on_master=${master_ver}${master_ver_suffix}
-branch_name=${version_on_branch}
-
-# Show the details and get confirmation
-echo "The current version is:                                  ${current_version}"
-echo "The release branch will be named:                        ${branch_name}"
-echo "The version number on the release branch will be set to: ${version_on_branch}"
-echo "The version number on 'master' will be set to:           ${version_on_master}"
-echo "If you proceed, the new branch and version number changes will be pushed to GitHub."
-echo -n 'Enter "y" if this is correct, anything else to abort: '
-read input
-[ "$input" == "y" ] || { echo >&2 Aborted. ; exit 1 ; }
-
-# Fail if not in a Git repository
-[ -d .git ] || {
-	echo >&2 Error: this directory is not a git repository root. Nothing happened.
-	exit 1
-}
-
-# Warn if the current branch isn't master
-current_branch=$( git name-rev --name-only HEAD )
-[ ${current_branch} == "master" ] || {
-	echo Current branch is ${current_branch}. Usually, release branches are made from master.
-	echo -n 'Enter "y" if this is correct, anything else to abort: '
-	read input
-	[ "$input" == "y" ] || { echo >&2 Aborted. ; exit 1 ; }
-}
-
-# Get Maven to make the branch
-set -x
-mvn release:clean release:branch -P Brooklyn,Console,Example,Launcher,Acceptance,Documentation --batch-mode -DautoVersionSubmodules=true -DbranchName=${branch_name} -DupdateBranchVersions=true -DreleaseVersion=${version_on_branch} -DdevelopmentVersion=${version_on_master}
-set +x
-
-# Done!
-echo Completed. Your repository is still looking at ${current_branch}. To switch to the release branch, enter:
-echo git checkout ${branch_name}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/scripts/release-make
----------------------------------------------------------------------
diff --git a/brooklyn-dist/scripts/release-make b/brooklyn-dist/scripts/release-make
deleted file mode 100755
index df46ea1..0000000
--- a/brooklyn-dist/scripts/release-make
+++ /dev/null
@@ -1,83 +0,0 @@
-#!/bin/bash -e -u
-#
-# 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.
-#
-
-usage(){
-	echo >&2 'Usage: release-make [ --release <version> ] [ --next <version> ]'
-	echo >&2 'Creates and tags a release based on the current branch.'
-	echo >&2 'Arguments are optional - if omitted, the script tries to work out the correct versions.'
-	echo >&2 'release <version> should be a full version number, such as 3.6.0-RC1'
-	echo >&2 'next <version> should be a snapshot version number, such as 3.6.0-RC2-SNAPSHOT'
-	echo >&2 'This command will preview what it is going to do and require confirmation before it makes changes.'
-}
-
-[ $# -eq 0 ] && echo >&2 "No arguments given, so I'm going to try and figure it out myself. Invoke with the --help option if you want to find how to invoke this script."
-
-release_tag_ver=
-release_branch_ver=
-
-while [ $# -gt 0 ]; do
-	case $1 in
-		--release)	shift; release_tag_ver=$1;;
-		--next)		shift; release_branch_ver=$1;;
-		*)					usage; exit 1;;
-	esac
-	shift
-done
-
-# Some magic to derive the anticipated version of the release.
-# Use xpath to query the version number in the pom
-xpath='xpath'
-type -P $xpath &>/dev/null && {
-	set +e
-	current_version=$( xpath pom.xml '/project/version/text()' 2>/dev/null )
-	set -e
-} || {
-        echo "Cannot guess version number as $xpath command not found."
-}
-# If the user didn't supply the release version, strip -SNAPSHOT off the current version and use that
-[ -z "$release_tag_ver" ] && release_tag_ver=${current_version%-SNAPSHOT}
-
-# More magic, this time to guess the next version.
-# If the user didn't supply the next version, modify the digits off the end of the release to increment by one and append -SNAPSHOT
-[ -z "$release_branch_ver" ] && release_branch_ver=$( echo ${release_tag_ver} | perl -n -e 'if (/^(.*)(\d+)$/) { print $1.($2+1)."-SNAPSHOT\n" }' )
-
-current_branch=$( git name-rev --name-only HEAD )
-
-echo "The release is on the branch:                             ${current_branch}"
-echo "The current version (detected) is:                        ${current_version}"
-echo "The release version is:                                   ${release_tag_ver}"
-echo "Development on the release branch continues with version: ${release_branch_ver}"
-echo -n 'Enter "y" if this is correct, anything else to abort: '
-read input
-[ "$input" == "y" ] || { echo >&2 Aborted. ; exit 1 ; }
-
-# Warn if the current branch is master
-[ ${current_branch} == "master" ] && {
-	echo Current branch is ${current_branch}. Usually, releases are made from a release branch.
-	echo -n 'Enter "y" if this is correct, anything else to abort: '
-	read input
-	[ "$input" == "y" ] || { echo >&2 Aborted. ; exit 1 ; }
-}
-
-# Release prepare
-mvn release:clean release:prepare -PExample,Launcher,Four,Three --batch-mode -DautoVersionSubmodules=true -DreleaseVersion=${release_tag_ver} -DdevelopmentVersion=${release_branch_ver}
-
-# Release perform
-mvn release:perform -PExample,Launcher,Four,Three --batch-mode


[41/51] [abbrv] brooklyn-dist git commit: move subdir from incubator up a level as it is promoted to its own repo (first non-incubator commit!)

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/src/main/license/files/NOTICE
----------------------------------------------------------------------
diff --git a/dist/src/main/license/files/NOTICE b/dist/src/main/license/files/NOTICE
new file mode 100644
index 0000000..f790f13
--- /dev/null
+++ b/dist/src/main/license/files/NOTICE
@@ -0,0 +1,5 @@
+Apache Brooklyn
+Copyright 2014-2015 The Apache Software Foundation
+
+This product includes software developed at
+The Apache Software Foundation (http://www.apache.org/).

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/src/test/java/org/apache/brooklyn/cli/BaseCliIntegrationTest.java
----------------------------------------------------------------------
diff --git a/dist/src/test/java/org/apache/brooklyn/cli/BaseCliIntegrationTest.java b/dist/src/test/java/org/apache/brooklyn/cli/BaseCliIntegrationTest.java
new file mode 100644
index 0000000..4cb2d2b
--- /dev/null
+++ b/dist/src/test/java/org/apache/brooklyn/cli/BaseCliIntegrationTest.java
@@ -0,0 +1,189 @@
+/*
+ * 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.brooklyn.cli;
+
+import static org.testng.Assert.assertEquals;
+import static org.testng.Assert.assertFalse;
+import static org.testng.Assert.assertTrue;
+import static org.testng.Assert.fail;
+
+import java.io.InputStream;
+import java.io.OutputStream;
+import java.util.NoSuchElementException;
+import java.util.Scanner;
+import java.util.concurrent.Callable;
+import java.util.concurrent.ExecutionException;
+import java.util.concurrent.ExecutorService;
+import java.util.concurrent.Executors;
+import java.util.concurrent.Future;
+import java.util.concurrent.TimeUnit;
+import java.util.concurrent.TimeoutException;
+
+import org.apache.brooklyn.core.entity.factory.ApplicationBuilder;
+import org.testng.annotations.AfterMethod;
+import org.testng.annotations.BeforeMethod;
+
+import com.google.common.collect.Lists;
+
+/**
+ * Command line interface test support.
+ */
+public class BaseCliIntegrationTest {
+
+    // TODO does this need to be hard-coded?
+    private static final String BROOKLYN_BIN_PATH = "./target/brooklyn-dist/bin/brooklyn";
+    private static final String BROOKLYN_CLASSPATH = "./target/test-classes/:./target/classes/";
+
+    // Times in seconds to allow Brooklyn to run and produce output
+    private static final long DELAY = 10l;
+    private static final long TIMEOUT = DELAY + 30l;
+
+    private ExecutorService executor;
+
+    @BeforeMethod(alwaysRun = true)
+    public void setup() {
+        executor = Executors.newCachedThreadPool();
+    }
+
+    @AfterMethod(alwaysRun = true)
+    public void teardown() {
+        executor.shutdownNow();
+    }
+
+    /** Invoke the brooklyn script with arguments. */
+    public Process startBrooklyn(String...argv) throws Throwable {
+        ProcessBuilder pb = new ProcessBuilder();
+        pb.environment().remove("BROOKLYN_HOME");
+        pb.environment().put("BROOKLYN_CLASSPATH", BROOKLYN_CLASSPATH);
+        pb.command(Lists.asList(BROOKLYN_BIN_PATH, argv));
+        return pb.start();
+    }
+
+    public void testBrooklyn(Process brooklyn, BrooklynCliTest test, int expectedExit) throws Throwable {
+        testBrooklyn(brooklyn, test, expectedExit, false);
+    }
+
+    /** Tests the operation of the Brooklyn CLI. */
+    public void testBrooklyn(Process brooklyn, BrooklynCliTest test, int expectedExit, boolean stop) throws Throwable {
+        try {
+            Future<Integer> future = executor.submit(test);
+
+            // Send CR to stop if required
+            if (stop) {
+                OutputStream out = brooklyn.getOutputStream();
+                out.write('\n');
+                out.flush();
+            }
+
+            int exitStatus = future.get(TIMEOUT, TimeUnit.SECONDS);
+
+            // Check error code from process
+            assertEquals(exitStatus, expectedExit, "Command returned wrong status");
+        } catch (TimeoutException te) {
+            fail("Timed out waiting for process to complete", te);
+        } catch (ExecutionException ee) {
+            if (ee.getCause() instanceof AssertionError) {
+                throw ee.getCause();
+            } else throw ee;
+        } finally {
+            brooklyn.destroy();
+        }
+    }
+
+    /** A {@link Callable} that encapsulates Brooklyn CLI test logic. */
+    public static abstract class BrooklynCliTest implements Callable<Integer> {
+
+        private final Process brooklyn;
+
+        private String consoleOutput;
+        private String consoleError;
+
+        public BrooklynCliTest(Process brooklyn) {
+            this.brooklyn = brooklyn;
+        }
+
+        @Override
+        public Integer call() throws Exception {
+            // Wait for initial output
+            Thread.sleep(TimeUnit.SECONDS.toMillis(DELAY));
+
+            // Get the console output of running that command
+            consoleOutput = convertStreamToString(brooklyn.getInputStream());
+            consoleError = convertStreamToString(brooklyn.getErrorStream());
+
+            // Check if the output looks as expected
+            checkConsole();
+
+            // Return exit status on completion
+            return brooklyn.waitFor();
+        }
+
+        /** Perform test assertions on console output and error streams. */
+        public abstract void checkConsole();
+
+        private String convertStreamToString(InputStream is) {
+            try {
+                return new Scanner(is).useDelimiter("\\A").next();
+            } catch (NoSuchElementException e) {
+                return "";
+            }
+        }
+
+        protected void assertConsoleOutput(String...expected) {
+            for (String e : expected) {
+                assertTrue(consoleOutput.contains(e), "Execution output not logged; output=" + consoleOutput);
+            }
+        }
+
+        protected void assertNoConsoleOutput(String...expected) {
+            for (String e : expected) {
+                assertFalse(consoleOutput.contains(e), "Execution output logged; output=" + consoleOutput);
+            }
+        }
+
+        protected void assertConsoleError(String...expected) {
+            for (String e : expected) {
+                assertTrue(consoleError.contains(e), "Execution error not logged; error=" + consoleError);
+            }
+        }
+
+        protected void assertNoConsoleError(String...expected) {
+            for (String e : expected) {
+                assertFalse(consoleError.contains(e), "Execution error logged; error=" + consoleError);
+            }
+        }
+
+        protected void assertConsoleOutputEmpty() {
+            assertTrue(consoleOutput.isEmpty(), "Output present; output=" + consoleOutput);
+        }
+
+        protected void assertConsoleErrorEmpty() {
+            assertTrue(consoleError.isEmpty(), "Error present; error=" + consoleError);
+        }
+    };
+
+    /** An empty application for testing. */
+    public static class TestApplication extends ApplicationBuilder {
+        @Override
+        protected void doBuild() {
+            // Empty, for testing
+        }
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/src/test/java/org/apache/brooklyn/cli/CliIntegrationTest.java
----------------------------------------------------------------------
diff --git a/dist/src/test/java/org/apache/brooklyn/cli/CliIntegrationTest.java b/dist/src/test/java/org/apache/brooklyn/cli/CliIntegrationTest.java
new file mode 100644
index 0000000..adf9559
--- /dev/null
+++ b/dist/src/test/java/org/apache/brooklyn/cli/CliIntegrationTest.java
@@ -0,0 +1,219 @@
+/*
+ * 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.brooklyn.cli;
+
+import org.testng.annotations.Test;
+
+/**
+ * Test the command line interface operation.
+ */
+public class CliIntegrationTest extends BaseCliIntegrationTest {
+
+    /**
+     * Checks if running {@code brooklyn help} produces the expected output.
+     */
+    @Test(groups = {"Integration","Broken"})
+    public void testLaunchCliHelp() throws Throwable {
+        final Process brooklyn = startBrooklyn("help");
+
+        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
+            @Override
+            public void checkConsole() {
+                assertConsoleOutput("usage: brooklyn"); // Usage info not present
+                assertConsoleOutput("The most commonly used brooklyn commands are:");
+                assertConsoleOutput("help     Display help for available commands",
+                                    "info     Display information about brooklyn",
+                                    "launch   Starts a brooklyn application"); // List of common commands not present
+                assertConsoleOutput("See 'brooklyn help <command>' for more information on a specific command.");
+                assertConsoleErrorEmpty();
+            }
+        };
+
+        testBrooklyn(brooklyn, test, 0);
+    }
+
+    /*
+        Exception java.io.IOException
+        
+        Message: Cannot run program "./target/brooklyn-dist/bin/brooklyn": error=2, No such file or directory
+        Stacktrace:
+        
+        
+        at java.lang.ProcessBuilder.start(ProcessBuilder.java:1047)
+        at org.apache.brooklyn.cli.BaseCliIntegrationTest.startBrooklyn(BaseCliIntegrationTest.java:75)
+        at org.apache.brooklyn.cli.CliIntegrationTest.testLaunchCliApp(CliIntegrationTest.java:56)
+        at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
+        at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:57)
+        at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
+        at java.lang.reflect.Method.invoke(Method.java:606)
+        at org.testng.internal.MethodInvocationHelper.invokeMethod(MethodInvocationHelper.java:84)
+        at org.testng.internal.Invoker.invokeMethod(Invoker.java:714)
+        at org.testng.internal.Invoker.invokeTestMethod(Invoker.java:901)
+        at org.testng.internal.Invoker.invokeTestMethods(Invoker.java:1231)
+        at org.testng.internal.TestMethodWorker.invokeTestMethods(TestMethodWorker.java:127)
+        at org.testng.internal.TestMethodWorker.run(TestMethodWorker.java:111)
+        at org.testng.TestRunner.privateRun(TestRunner.java:767)
+        at org.testng.TestRunner.run(TestRunner.java:617)
+        at org.testng.SuiteRunner.runTest(SuiteRunner.java:348)
+        at org.testng.SuiteRunner.runSequentially(SuiteRunner.java:343)
+        at org.testng.SuiteRunner.privateRun(SuiteRunner.java:305)
+        at org.testng.SuiteRunner.run(SuiteRunner.java:254)
+        at org.testng.SuiteRunnerWorker.runSuite(SuiteRunnerWorker.java:52)
+        at org.testng.SuiteRunnerWorker.run(SuiteRunnerWorker.java:86)
+        at org.testng.TestNG.runSuitesSequentially(TestNG.java:1224)
+        at org.testng.TestNG.runSuitesLocally(TestNG.java:1149)
+        at org.testng.TestNG.run(TestNG.java:1057)
+        at org.apache.maven.surefire.testng.TestNGExecutor.run(TestNGExecutor.java:115)
+        at org.apache.maven.surefire.testng.TestNGDirectoryTestSuite.executeMulti(TestNGDirectoryTestSuite.java:205)
+        at org.apache.maven.surefire.testng.TestNGDirectoryTestSuite.execute(TestNGDirectoryTestSuite.java:108)
+        at org.apache.maven.surefire.testng.TestNGProvider.invoke(TestNGProvider.java:111)
+        at org.apache.maven.surefire.booter.ForkedBooter.invokeProviderInSameClassLoader(ForkedBooter.java:203)
+        at org.apache.maven.surefire.booter.ForkedBooter.runSuitesInProcess(ForkedBooter.java:155)
+        at org.apache.maven.surefire.booter.ForkedBooter.main(ForkedBooter.java:103)
+        Caused by: java.io.IOException: error=2, No such file or directory
+        at java.lang.UNIXProcess.forkAndExec(Native Method)
+        at java.lang.UNIXProcess.<init>(UNIXProcess.java:186)
+        at java.lang.ProcessImpl.start(ProcessImpl.java:130)
+        at java.lang.ProcessBuilder.start(ProcessBuilder.java:1028)
+        ... 30 more
+     */
+    /**
+     * Checks if launching an application using {@code brooklyn launch} produces the expected output.
+     */
+    @Test(groups = {"Integration","Broken"})
+    public void testLaunchCliApp() throws Throwable {
+        final Process brooklyn = startBrooklyn("--verbose", "launch", "--stopOnKeyPress", "--app", "org.apache.brooklyn.cli.BaseCliIntegrationTest$TestApplication", "--location", "localhost", "--noConsole");
+
+        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
+            @Override
+            public void checkConsole() {
+                assertConsoleOutput("Launching brooklyn app:"); // Launch message not output
+                assertNoConsoleOutput("Initiating Jersey application"); // Web console started
+                assertConsoleOutput("Started application BasicApplicationImpl"); // Application not started
+                assertConsoleOutput("Server started. Press return to stop."); // Server started message not output
+                assertConsoleErrorEmpty();
+            }
+        };
+
+        testBrooklyn(brooklyn, test, 0, true);
+    }
+
+    /**
+     * Checks if a correct error and help message is given if using incorrect param.
+     */
+    @Test(groups = {"Integration","Broken"})
+    public void testLaunchCliAppParamError() throws Throwable {
+        final Process brooklyn = startBrooklyn("launch", "nothing", "--app");
+
+        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
+            @Override
+            public void checkConsole() {
+                assertConsoleError("Parse error: Required values for option 'application class or file' not provided");
+                assertConsoleError("NAME", "SYNOPSIS", "OPTIONS", "COMMANDS");
+                assertConsoleOutputEmpty();
+            }
+        };
+
+        testBrooklyn(brooklyn, test, 1);
+    }
+
+    /*
+        Exception java.io.IOException
+        
+        Message: Cannot run program "./target/brooklyn-dist/bin/brooklyn": error=2, No such file or directory
+        Stacktrace:
+        
+        
+        at java.lang.ProcessBuilder.start(ProcessBuilder.java:1047)
+        at org.apache.brooklyn.cli.BaseCliIntegrationTest.startBrooklyn(BaseCliIntegrationTest.java:75)
+        at org.apache.brooklyn.cli.CliIntegrationTest.testLaunchCliAppCommandError(CliIntegrationTest.java:96)
+        at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
+        at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:57)
+        at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
+        at java.lang.reflect.Method.invoke(Method.java:606)
+        at org.testng.internal.MethodInvocationHelper.invokeMethod(MethodInvocationHelper.java:84)
+        at org.testng.internal.Invoker.invokeMethod(Invoker.java:714)
+        at org.testng.internal.Invoker.invokeTestMethod(Invoker.java:901)
+        at org.testng.internal.Invoker.invokeTestMethods(Invoker.java:1231)
+        at org.testng.internal.TestMethodWorker.invokeTestMethods(TestMethodWorker.java:127)
+        at org.testng.internal.TestMethodWorker.run(TestMethodWorker.java:111)
+        at org.testng.TestRunner.privateRun(TestRunner.java:767)
+        at org.testng.TestRunner.run(TestRunner.java:617)
+        at org.testng.SuiteRunner.runTest(SuiteRunner.java:348)
+        at org.testng.SuiteRunner.runSequentially(SuiteRunner.java:343)
+        at org.testng.SuiteRunner.privateRun(SuiteRunner.java:305)
+        at org.testng.SuiteRunner.run(SuiteRunner.java:254)
+        at org.testng.SuiteRunnerWorker.runSuite(SuiteRunnerWorker.java:52)
+        at org.testng.SuiteRunnerWorker.run(SuiteRunnerWorker.java:86)
+        at org.testng.TestNG.runSuitesSequentially(TestNG.java:1224)
+        at org.testng.TestNG.runSuitesLocally(TestNG.java:1149)
+        at org.testng.TestNG.run(TestNG.java:1057)
+        at org.apache.maven.surefire.testng.TestNGExecutor.run(TestNGExecutor.java:115)
+        at org.apache.maven.surefire.testng.TestNGDirectoryTestSuite.executeMulti(TestNGDirectoryTestSuite.java:205)
+        at org.apache.maven.surefire.testng.TestNGDirectoryTestSuite.execute(TestNGDirectoryTestSuite.java:108)
+        at org.apache.maven.surefire.testng.TestNGProvider.invoke(TestNGProvider.java:111)
+        at org.apache.maven.surefire.booter.ForkedBooter.invokeProviderInSameClassLoader(ForkedBooter.java:203)
+        at org.apache.maven.surefire.booter.ForkedBooter.runSuitesInProcess(ForkedBooter.java:155)
+        at org.apache.maven.surefire.booter.ForkedBooter.main(ForkedBooter.java:103)
+        Caused by: java.io.IOException: error=2, No such file or directory
+        at java.lang.UNIXProcess.forkAndExec(Native Method)
+        at java.lang.UNIXProcess.<init>(UNIXProcess.java:186)
+        at java.lang.ProcessImpl.start(ProcessImpl.java:130)
+        at java.lang.ProcessBuilder.start(ProcessBuilder.java:1028)
+        ... 30 more
+     */
+    /**
+     * Checks if a correct error and help message is given if using incorrect command.
+     */
+    @Test(groups = "Integration")
+    public void testLaunchCliAppCommandError() throws Throwable {
+        final Process brooklyn = startBrooklyn("biscuit");
+
+        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
+            @Override
+            public void checkConsole() {
+                assertConsoleError("Parse error: No command specified");
+                assertConsoleError("NAME", "SYNOPSIS", "OPTIONS", "COMMANDS");
+                assertConsoleOutputEmpty();
+            }
+        };
+
+        testBrooklyn(brooklyn, test, 1);
+    }
+
+    /**
+     * Checks if a correct error and help message is given if using incorrect application.
+     */
+    @Test(groups = {"Integration","Broken"})
+    public void testLaunchCliAppLaunchError() throws Throwable {
+        final String app = "org.eample.DoesNotExist";
+        final Process brooklyn = startBrooklyn("launch", "--app", app, "--location", "nowhere");
+
+        BrooklynCliTest test = new BrooklynCliTest(brooklyn) {
+            @Override
+            public void checkConsole() {
+                assertConsoleOutput(app, "not found");
+                assertConsoleError("ERROR", "Fatal", "getting resource", app);
+            }
+        };
+
+        testBrooklyn(brooklyn, test, 2);
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/downstream-parent/pom.xml
----------------------------------------------------------------------
diff --git a/downstream-parent/pom.xml b/downstream-parent/pom.xml
new file mode 100644
index 0000000..f97dba3
--- /dev/null
+++ b/downstream-parent/pom.xml
@@ -0,0 +1,524 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+  <modelVersion>4.0.0</modelVersion>
+
+  <parent>
+    <groupId>org.apache.brooklyn</groupId>
+    <artifactId>brooklyn-server</artifactId>
+    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+    <relativePath>../../brooklyn-server/pom.xml</relativePath>
+    <!-- TODO this uses server root pom as a way to get version info without rat check;
+         it means it inherits apache pom, which might not be desired.
+         probably cleaner NOT to have a downstream-parent, instead for project to redeclare their tasks.
+         (yes it violates DRY, but until Maven 4 supporting Mixins that is probably better than
+         hacks in a parent hierarchy to which people won't have visibility. -->
+  </parent>
+
+  <artifactId>brooklyn-downstream-parent</artifactId>
+  <packaging>pom</packaging>
+  <name>Brooklyn Downstream Project Parent</name>
+  <description>
+      Parent pom that can be used by downstream projects that use Brooklyn,
+      or that contribute additional functionality to Brooklyn.
+  </description>
+
+  <properties>
+    <!-- Compilation -->
+    <java.version>1.7</java.version>
+    <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>
+    <project.reporting.outputEncoding>UTF-8</project.reporting.outputEncoding>
+
+    <!-- Testing -->
+    <testng.version>6.8.8</testng.version>
+    <surefire.version>2.18.1</surefire.version>
+    <includedTestGroups />
+    <excludedTestGroups>Integration,Acceptance,Live,Live-sanity,WIP</excludedTestGroups>
+
+    <!-- Dependencies -->
+    <brooklyn.version>0.9.0-SNAPSHOT</brooklyn.version>  <!-- BROOKLYN_VERSION -->
+    <jclouds.groupId>org.apache.jclouds</jclouds.groupId> <!-- JCLOUDS_GROUPID_VERSION -->
+
+    <!-- versions should match those used by Brooklyn, to avoid conflicts -->
+    <jclouds.version>1.9.2</jclouds.version> <!-- JCLOUDS_VERSION -->
+    <logback.version>1.0.7</logback.version>
+    <slf4j.version>1.6.6</slf4j.version>  <!-- used for java.util.logging jul-to-slf4j interception -->
+    <guava.version>17.0</guava.version>
+    <xstream.version>1.4.7</xstream.version>
+    <jackson.version>1.9.13</jackson.version>  <!-- codehaus jackson, used by brooklyn rest server -->
+    <fasterxml.jackson.version>2.4.5</fasterxml.jackson.version>  <!-- more recent jackson, but not compatible with old annotations! -->
+    <jersey.version>1.19</jersey.version>
+    <httpclient.version>4.4.1</httpclient.version>
+    <commons-lang3.version>3.1</commons-lang3.version>
+    <groovy.version>2.3.7</groovy.version> <!-- Version supported by https://github.com/groovy/groovy-eclipse/wiki/Groovy-Eclipse-2.9.1-Release-Notes -->
+    <jsr305.version>2.0.1</jsr305.version>
+    <snakeyaml.version>1.11</snakeyaml.version>
+  </properties>
+
+  <dependencyManagement>
+    <dependencies>
+      <dependency>
+        <!-- this would pull in all brooklyn entities and clouds;
+             you can cherry pick selected ones instead (for a smaller build) -->
+        <groupId>org.apache.brooklyn</groupId>
+        <artifactId>brooklyn-all</artifactId>
+        <version>${brooklyn.version}</version>
+      </dependency>
+    </dependencies>
+  </dependencyManagement>
+
+  <dependencies>
+    <dependency>
+      <!-- this gives us flexible and easy-to-use logging; just edit logback-custom.xml! -->
+      <groupId>org.apache.brooklyn</groupId>
+      <artifactId>brooklyn-logback-xml</artifactId>
+      <version>${brooklyn.version}</version>
+      <!-- optional so that this project has logging; dependencies may redeclare or supply their own;
+           provided so that it isn't put into the assembly (as it supplies its own explicit logback.xml);
+           see Logging in the Brooklyn website/userguide for more info -->
+      <optional>true</optional>
+      <scope>provided</scope>
+    </dependency>
+    <dependency>
+      <!-- includes testng and useful logging for tests -->
+      <groupId>org.apache.brooklyn</groupId>
+      <artifactId>brooklyn-test-support</artifactId>
+      <version>${brooklyn.version}</version>
+      <scope>test</scope>
+    </dependency>
+    <dependency>
+      <!-- includes org.apache.brooklyn.test.support.LoggingVerboseReporter -->
+      <groupId>org.apache.brooklyn</groupId>
+      <artifactId>brooklyn-utils-test-support</artifactId>
+      <version>${brooklyn.version}</version>
+      <scope>test</scope>
+    </dependency>
+  </dependencies>
+
+  <build>
+    <testSourceDirectory>src/test/java</testSourceDirectory>
+    <testResources>
+      <testResource>
+        <directory>src/test/resources</directory>
+      </testResource>
+    </testResources>
+
+    <pluginManagement>
+      <plugins>
+        <plugin>
+          <artifactId>maven-assembly-plugin</artifactId>
+          <version>2.5.4</version>
+          <configuration>
+            <tarLongFileMode>gnu</tarLongFileMode>
+          </configuration>
+        </plugin>
+        <plugin>
+          <artifactId>maven-clean-plugin</artifactId>
+          <version>2.6.1</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-compiler-plugin</artifactId>
+          <version>3.3</version>
+          <configuration>
+            <source>${java.version}</source>
+            <target>${java.version}</target>
+          </configuration>
+        </plugin>
+        <plugin>
+          <artifactId>maven-deploy-plugin</artifactId>
+          <version>2.8.2</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-eclipse-plugin</artifactId>
+          <version>2.10</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-enforcer-plugin</artifactId>
+          <version>1.4</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-failsafe-plugin</artifactId>
+          <version>2.18.1</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-gpg-plugin</artifactId>
+          <version>1.6</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-jar-plugin</artifactId>
+          <version>2.6</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-javadoc-plugin</artifactId>
+          <version>2.10.3</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-resources-plugin</artifactId>
+          <version>2.7</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-source-plugin</artifactId>
+          <version>2.4</version>
+        </plugin>
+        <plugin>
+          <artifactId>maven-surefire-plugin</artifactId>
+          <version>2.18.1</version>
+        </plugin>
+        <plugin>
+          <groupId>org.apache.felix</groupId>
+          <artifactId>maven-bundle-plugin</artifactId>
+          <version>2.3.4</version>
+        </plugin>
+        <!--This plugin's configuration is used to store Eclipse m2e settings only. It has no influence on the Maven build itself.-->
+        <plugin>
+          <groupId>org.eclipse.m2e</groupId>
+          <artifactId>lifecycle-mapping</artifactId>
+          <version>1.0.0</version>
+          <configuration>
+            <lifecycleMappingMetadata>
+              <pluginExecutions>
+                <pluginExecution>
+                  <pluginExecutionFilter>
+                    <groupId>org.apache.maven.plugins</groupId>
+                    <artifactId>maven-assembly-plugin</artifactId>
+                    <versionRange>[2.4.1,)</versionRange>
+                    <goals>
+                      <goal>single</goal>
+                    </goals>
+                  </pluginExecutionFilter>
+                  <action>
+                    <ignore />
+                  </action>
+                </pluginExecution>
+                <pluginExecution>
+                  <pluginExecutionFilter>
+                    <groupId>org.codehaus.mojo</groupId>
+                    <artifactId>build-helper-maven-plugin</artifactId>
+                    <versionRange>[1.7,)</versionRange>
+                    <goals>
+                      <goal>attach-artifact</goal>
+                    </goals>
+                  </pluginExecutionFilter>
+                  <action>
+                    <ignore />
+                  </action>
+                </pluginExecution>
+                <pluginExecution>
+                  <pluginExecutionFilter>
+                    <groupId>org.apache.maven.plugins</groupId>
+                    <artifactId>maven-enforcer-plugin</artifactId>
+                    <versionRange>[1.3.1,)</versionRange>
+                    <goals>
+                      <goal>enforce</goal>
+                    </goals>
+                  </pluginExecutionFilter>
+                  <action>
+                    <ignore />
+                  </action>
+                </pluginExecution>
+                <pluginExecution>
+                  <pluginExecutionFilter>
+                    <groupId>org.apache.maven.plugins</groupId>
+                    <artifactId>maven-remote-resources-plugin</artifactId>
+                    <versionRange>[1.5,)</versionRange>
+                    <goals>
+                      <goal>process</goal>
+                    </goals>
+                  </pluginExecutionFilter>
+                  <action>
+                    <ignore />
+                  </action>
+                </pluginExecution>
+                <pluginExecution>
+                  <pluginExecutionFilter>
+                    <groupId>org.apache.maven.plugins</groupId>
+                    <artifactId>maven-dependency-plugin</artifactId>
+                    <versionRange>[2.8,)</versionRange>
+                    <goals>
+                      <goal>unpack</goal>
+                      <goal>copy</goal>
+                    </goals>
+                  </pluginExecutionFilter>
+                  <action>
+                    <ignore />
+                  </action>
+                </pluginExecution>
+                <pluginExecution>
+                  <pluginExecutionFilter>
+                    <groupId>com.github.skwakman.nodejs-maven-plugin</groupId>
+                    <artifactId>nodejs-maven-plugin</artifactId>
+                    <versionRange>[1.0.3,)</versionRange>
+                    <goals>
+                      <goal>extract</goal>
+                    </goals>
+                  </pluginExecutionFilter>
+                  <action>
+                    <ignore />
+                  </action>
+                </pluginExecution>
+                <pluginExecution>
+                  <pluginExecutionFilter>
+                    <groupId>org.apache.maven.plugins</groupId>
+                    <artifactId>maven-war-plugin</artifactId>
+                    <versionRange>[2.4,)</versionRange>
+                    <goals>
+                      <goal>exploded</goal>
+                    </goals>
+                  </pluginExecutionFilter>
+                  <action>
+                    <ignore />
+                  </action>
+                </pluginExecution>
+              </pluginExecutions>
+             </lifecycleMappingMetadata>
+           </configuration>
+        </plugin>
+      </plugins>
+    </pluginManagement>
+
+    <plugins>
+      <plugin>
+        <artifactId>maven-clean-plugin</artifactId>
+        <configuration>
+          <filesets>
+            <fileset>
+              <directory>.</directory>
+              <includes>
+                <include>brooklyn*.log</include>
+                <include>brooklyn*.log.*</include>
+                <include>stacktrace.log</include>
+                <include>test-output</include>
+                <include>prodDb.*</include>
+              </includes>
+            </fileset>
+          </filesets>
+        </configuration>
+      </plugin>
+
+      <plugin>
+        <artifactId>maven-resources-plugin</artifactId>
+      </plugin>
+
+      <plugin>
+        <artifactId>maven-eclipse-plugin</artifactId>
+        <configuration>
+          <additionalProjectnatures>
+            <projectnature>org.maven.ide.eclipse.maven2Nature</projectnature>
+          </additionalProjectnatures>
+        </configuration>
+      </plugin>
+
+      <plugin>
+        <artifactId>maven-surefire-plugin</artifactId>
+        <configuration>
+          <argLine>-Xms256m -Xmx512m -XX:MaxPermSize=512m</argLine>
+          <properties>
+            <property>
+              <name>listener</name>
+              <value>org.apache.brooklyn.test.support.LoggingVerboseReporter</value>
+            </property>
+          </properties>
+          <enableAssertions>true</enableAssertions>
+          <groups>${includedTestGroups}</groups>
+          <excludedGroups>${excludedTestGroups}</excludedGroups>
+          <testFailureIgnore>false</testFailureIgnore>
+          <systemPropertyVariables>
+            <verbose>-1</verbose>
+            <net.sourceforge.cobertura.datafile>${project.build.directory}/cobertura/cobertura.ser</net.sourceforge.cobertura.datafile>
+            <cobertura.user.java.nio>false</cobertura.user.java.nio>
+          </systemPropertyVariables>
+          <printSummary>true</printSummary>
+        </configuration>
+      </plugin>
+    </plugins>
+  </build>
+
+  <profiles>
+
+    <profile>
+      <id>Tests</id>
+      <activation>
+        <file> <exists>${basedir}/src/test</exists> </file>
+      </activation>
+      <build>
+        <plugins>
+          <plugin>
+            <artifactId>maven-jar-plugin</artifactId>
+            <inherited>true</inherited>
+            <executions>
+              <execution>
+                <id>test-jar-creation</id>
+                <goals>
+                  <goal>test-jar</goal>
+                </goals>
+                <configuration>
+                  <forceCreation>true</forceCreation>
+                  <archive combine.self="override" />
+                </configuration>
+              </execution>
+            </executions>
+          </plugin>
+        </plugins>
+      </build>
+    </profile>
+
+    <!-- run Integration tests with -PIntegration -->
+    <profile>
+      <id>Integration</id>
+      <properties>
+        <includedTestGroups>Integration</includedTestGroups>
+        <excludedTestGroups>Acceptance,Live,Live-sanity,WIP</excludedTestGroups>
+      </properties>
+    </profile>
+
+    <!-- run Live tests with -PLive -->
+    <profile>
+      <id>Live</id>
+      <properties>
+        <includedTestGroups>Live,Live-sanity</includedTestGroups>
+        <excludedTestGroups>Acceptance,WIP</excludedTestGroups>
+      </properties>
+    </profile>
+
+    <!-- run Live-sanity tests with -PLive-sanity -->
+    <profile>
+      <id>Live-sanity</id>
+      <properties>
+        <includedTestGroups>Live-sanity</includedTestGroups>
+        <excludedTestGroups>Acceptance,WIP</excludedTestGroups>
+      </properties>
+      <build>
+        <plugins>
+          <plugin>
+            <artifactId>maven-jar-plugin</artifactId>
+            <executions>
+              <execution>
+                <id>test-jar-creation</id>
+                <configuration>
+                  <skip>true</skip>
+                </configuration>
+              </execution>
+            </executions>
+          </plugin>
+        </plugins>
+      </build>
+    </profile>
+
+    <profile>
+      <id>Bundle</id>
+      <activation>
+        <file>
+          <!-- NB - this is all the leaf projects, including logback-* (with no src);
+               the archetype project neatly ignores this however -->
+          <exists>${basedir}/src</exists>
+        </file>
+      </activation>
+      <build>
+        <plugins>
+          <plugin>
+            <groupId>org.apache.felix</groupId>
+            <artifactId>maven-bundle-plugin</artifactId>
+            <extensions>true</extensions>
+            <!-- configure plugin to generate MANIFEST.MF
+                 adapted from http://blog.knowhowlab.org/2010/06/osgi-tutorial-from-project-structure-to.html -->
+            <executions>
+              <execution>
+                <id>bundle-manifest</id>
+                <phase>process-classes</phase>
+                <goals>
+                  <goal>manifest</goal>
+                </goals>
+              </execution>
+            </executions>
+            <configuration>
+              <supportedProjectTypes>
+                <supportedProjectType>jar</supportedProjectType>
+              </supportedProjectTypes>
+              <instructions>
+                <!--
+                  Exclude packages used by Brooklyn that are not OSGi bundles. Including any
+                  of the below may cause bundles to fail to load into the catalogue with
+                  messages like "Unable to resolve 150.0: missing requirement [150.0]
+                  osgi.wiring.package; (osgi.wiring.package=com.maxmind.geoip2)".
+                -->
+                <Import-Package>
+                  !com.maxmind.geoip2.*,
+                  !io.airlift.command.*,
+                  !io.cloudsoft.winrm4j.*,
+                  !javax.inject.*,
+                  !org.apache.felix.framework.*,
+                  !org.apache.http.*,
+                  !org.jclouds.googlecomputeengine.*,
+                  !org.osgi.jmx,
+                  !org.python.*,
+                  !org.reflections.*,
+                  !org.w3c.tidy.*,
+                  *
+                </Import-Package>
+                <!--
+                  Brooklyn-Feature prefix triggers inclusion of the project's metadata in the
+                  server's features list.
+                -->
+                <Brooklyn-Feature-Name>${project.name}</Brooklyn-Feature-Name>
+              </instructions>
+            </configuration>
+          </plugin>
+          <plugin>
+            <groupId>org.apache.maven.plugins</groupId>
+            <artifactId>maven-jar-plugin</artifactId>
+            <configuration>
+              <archive>
+                <manifestFile>${project.build.outputDirectory}/META-INF/MANIFEST.MF</manifestFile>
+              </archive>
+            </configuration>
+          </plugin>
+        </plugins>
+      </build>
+    </profile>
+
+    <!-- different properties used to deploy to different locations depending on profiles;
+         default is cloudsoft filesystem repo, but some sources still use cloudsoft artifactory as source
+         and soon we will support artifactory. use this profile for the ASF repositories and
+         sonatype-oss-release profile for the Sonatype OSS repositories.
+    -->
+    <!-- profile>
+      <id>apache-release</id>
+      <activation>
+        <property>
+          <name>brooklyn.deployTo</name>
+          <value>apache</value>
+        </property>
+      </activation>
+      <distributionManagement>
+        <repository>
+          <id>apache.releases.https</id>
+          <name>Apache Release Distribution Repository</name>
+          <url>https://repository.apache.org/service/local/staging/deploy/maven2</url>
+        </repository>
+        <snapshotRepository>
+          <id>apache.snapshots.https</id>
+          <name>Apache Development Snapshot Repository</name>
+          <url>https://repository.apache.org/content/repositories/snapshots</url>
+        </snapshotRepository>
+      </distributionManagement>
+    </profile -->
+  </profiles>
+
+</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
new file mode 100644
index 0000000..12ebdd9
--- /dev/null
+++ b/pom.xml
@@ -0,0 +1,83 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+	xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+
+    <modelVersion>4.0.0</modelVersion>
+    <parent>
+        <groupId>org.apache.brooklyn</groupId>
+        <artifactId>brooklyn-parent</artifactId>
+        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+        <relativePath>../brooklyn-server/parent/pom.xml</relativePath>
+    </parent>
+
+    <groupId>org.apache.brooklyn</groupId>
+    <artifactId>brooklyn-dist-root</artifactId>
+    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+    <packaging>pom</packaging>
+
+    <name>Brooklyn Dist Root</name>
+    <description>
+        Brooklyn Dist project root, serving as the ancestor POM for dist projects --
+        declaring modules to build
+    </description>
+    <url>https://brooklyn.apache.org/</url>
+    <inceptionYear>2012</inceptionYear>
+
+    <developers>
+        <!-- TODO update with PMC members and committers -->
+    </developers>
+
+    <scm>
+        <connection>scm:git:https://git-wip-us.apache.org/repos/asf/incubator-brooklyn.git</connection>
+        <developerConnection>scm:git:https://git-wip-us.apache.org/repos/asf/incubator-brooklyn.git</developerConnection>
+        <url>https://git-wip-us.apache.org/repos/asf?p=incubator-brooklyn.git</url>
+        <tag>HEAD</tag>
+    </scm>
+
+    <issueManagement>
+        <system>JIRA</system>
+        <url>https://issues.apache.org/jira/browse/BROOKLYN</url>
+    </issueManagement>
+    <ciManagement>
+        <system>Jenkins</system>
+        <url>https://builds.apache.org/job/incubator-brooklyn-master-build/</url>
+    </ciManagement>
+    <mailingLists>
+        <mailingList>
+            <name>Brooklyn Developer List</name>
+            <subscribe>dev-subscribe@brooklyn.apache.org</subscribe>
+            <unsubscribe>dev-unsubscribe@brooklyn.apache.org</unsubscribe>
+            <post>dev@brooklyn.apache.org</post>
+            <archive>
+                http://mail-archives.apache.org/mod_mbox/brooklyn-dev/
+            </archive>
+        </mailingList>
+    </mailingLists>
+
+    <modules>
+        <module>downstream-parent</module>
+        <module>all</module>
+        <module>dist</module>
+        <module>vagrant</module>
+        <module>archetypes/quickstart</module>
+    </modules>
+
+</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/release/.gitignore
----------------------------------------------------------------------
diff --git a/release/.gitignore b/release/.gitignore
new file mode 100644
index 0000000..16d63d3
--- /dev/null
+++ b/release/.gitignore
@@ -0,0 +1,2 @@
+.vagrant
+tmp

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/release/README.md
----------------------------------------------------------------------
diff --git a/release/README.md b/release/README.md
new file mode 100644
index 0000000..325b165
--- /dev/null
+++ b/release/README.md
@@ -0,0 +1,50 @@
+Release Scripts and Helpers
+===========================
+
+This folder contains a number of items that will assist in the production of Brooklyn releases.
+
+
+Release scripts - change-version.sh and make-release-artifacts.sh
+-----------------------------------------------------------------
+
+`change-version.sh` will update version numbers across the whole distribution.  It is recommended to use this script
+rather than "rolling your own" or using a manual process, as you risk missing out some version numbers (and
+accidentally changing some that should not be changed).
+
+`make-release-artifacts.sh` will produce the release artifacts with appropriate signatures. It is recommended to use
+this script rather than "rolling your own" or using a manual process, as this script codifies several Apache
+requirements about the release artifacts.
+
+These scripts are fully documented in **Release Process** pages on the website.
+
+
+Vagrant configuration
+---------------------
+
+The `Vagrantfile` and associated files `settings.xml` and `gpg-agent.conf` are for setting up a virtual machine hosting
+a complete and clean development environment. You may benefit from using this environment when making the release, but
+it is not required that you do so.
+
+The environment is a single VM that configured with all the tools needed to make the release. It also configures GnuPG
+by copying your `gpg.conf`, `secring.gpg` and `pubring.gpg` into the VM; also copied is your `.gitconfig`. The
+GnuPG agent is configured to assist with the release signing by caching your passphrase, so you will only need to enter
+it once during the build process. A Maven `settings.xml` is provided to assist with the upload to Apache's Nexus server.
+Finally the canonical Git repository for Apache Brooklyn is cloned into the home directory.
+
+You should edit `settings.xml` before deployment, or `~/.m2/settings.xml` inside the VM after deployment, to include
+your Apache credentials.
+
+Assuming you have VirtualBox and Vagrant already installed, you should simply be able to run `vagrant up` to create the
+VM, and then `vagrant ssh` to get a shell prompt inside the VM. Finally run `vagrant destroy` to clean up afterwards.
+
+This folder is mounted at `/vagrant` inside the VM - this means the release helpers are close to hand, so you can
+run for example `/vagrant/make-release/artifacts.sh`.
+
+
+Pull request reporting
+----------------------
+
+The files in `pull-request-reports`, mainly `pr_report.rb` 
+(and associated files `Gemfile` and `Gemfile.lock`) uses the GitHub API to extract a list of open pull
+requests, and writes a summary into `pr_report.tsv`. This could then be imported into Google Sheets to provide a handy
+way of classifying and managing outstanding PRs ahead of making a release.

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/release/Vagrantfile
----------------------------------------------------------------------
diff --git a/release/Vagrantfile b/release/Vagrantfile
new file mode 100644
index 0000000..016c48f
--- /dev/null
+++ b/release/Vagrantfile
@@ -0,0 +1,66 @@
+# -*- mode: ruby -*-
+# vi: set ft=ruby :
+#
+# 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.
+#
+
+# Vagrantfile that creates a basic workstation for compiling Brooklyn and
+# running tests. Particularly useful for running integration tests, as you
+# can clean up any failed tests simply by destroying and rebuilding the
+# Vagrant instance.
+
+# All Vagrant configuration is done below. The "2" in Vagrant.configure
+# configures the configuration version (we support older styles for
+# backwards compatibility). Please don't change it unless you know what
+# you're doing.
+Vagrant.configure(2) do |config|
+
+  # Base on Ubuntu 14.04 LTS
+  config.vm.box = "ubuntu/trusty64"
+
+  # Provider-specific configuration so you can fine-tune various
+  # backing providers for Vagrant. These expose provider-specific options.
+  config.vm.provider "virtualbox" do |vb|
+    vb.memory = "2048"
+  end
+
+  config.vm.network "forwarded_port", guest: 8008, host: 8008
+
+  config.vm.provision "file", source: "~/.gitconfig", destination: ".gitconfig"
+  config.vm.provision "file", source: "~/.gnupg/gpg.conf", destination: ".gnupg/gpg.conf"
+  config.vm.provision "file", source: "~/.gnupg/pubring.gpg", destination: ".gnupg/pubring.gpg"
+  config.vm.provision "file", source: "~/.gnupg/secring.gpg", destination: ".gnupg/secring.gpg"
+  config.vm.provision "file", source: "gpg-agent.conf", destination: ".gnupg/gpg-agent.conf"
+  config.vm.provision "file", source: "settings.xml", destination: ".m2/settings.xml"
+
+  # Update the VM, install Java and Maven, enable passwordless-ssh-to-localhost,
+  # clone the canonical repository
+  config.vm.provision "shell", inline: <<-SHELL
+    apt-get update
+    apt-get upgrade -y
+    apt-get install -y default-jdk maven git xmlstarlet zip unzip language-pack-en vim-nox gnupg2 gnupg-agent pinentry-curses
+    wget -q -O /tmp/artifactory.zip http://bit.ly/Hqv9aj
+    mkdir -p /opt
+    unzip /tmp/artifactory.zip -d /opt
+    sudo sed -i -e '/Connector port=/ s/=\".*\"/=\"'"8008"'\"/' /opt/artifactory*/tomcat/conf/server.xml
+    /opt/artifactory*/bin/installService.sh
+    service artifactory start
+    chmod -R go= ~vagrant/.gnupg
+    cat /etc/ssh/ssh_host_*_key.pub | awk '{print "localhost,127.0.0.1 "$0}' >> /etc/ssh/ssh_known_hosts
+    su -c 'ssh-keygen -t rsa -b 2048 -N "" -f ~/.ssh/id_rsa; cat ~/.ssh/*.pub >> ~/.ssh/authorized_keys' vagrant
+    su -c 'git clone https://git-wip-us.apache.org/repos/asf/incubator-brooklyn.git apache-brooklyn-git' vagrant
+  SHELL
+end

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/release/change-version.sh
----------------------------------------------------------------------
diff --git a/release/change-version.sh b/release/change-version.sh
new file mode 100755
index 0000000..4b77749
--- /dev/null
+++ b/release/change-version.sh
@@ -0,0 +1,70 @@
+#!/usr/bin/env bash
+#
+# 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.
+#
+
+set -e
+
+# changes the version everywhere
+# usage, e.g.:  change-version.sh 0.3.0-SNAPSHOT 0.3.0-RC1
+#          or:  change-version.sh MARKER 0.3.0-SNAPSHOT 0.3.0-RC1
+
+[ -d .git ] || {
+  echo "Must run in brooklyn project root directory"
+  exit 1
+}
+
+if [ "$#" -eq 2 ]; then
+  VERSION_MARKER=BROOKLYN_VERSION
+elif [ "$#" -eq 3 ]; then
+  VERSION_MARKER=$1_VERSION
+  shift;
+else
+  echo "Usage:  "$0" [VERSION_MARKER] CURRENT_VERSION NEW_VERSION"
+  echo " e.g.:  "$0" BROOKLYN 0.3.0-SNAPSHOT 0.3.0-RC1"
+  exit 1
+fi
+
+# remove binaries and stuff
+if [ -f pom.xml ] && [ -d target ] ; then mvn clean ; fi
+
+VERSION_MARKER_NL=${VERSION_MARKER}_BELOW
+CURRENT_VERSION=$1
+NEW_VERSION=$2
+
+# grep --exclude-dir working only in recent versions, not on all platforms, replace with find;
+# skip folders named "ignored" or .xxx (but not the current folder ".");
+# exclude log, war, etc. files;
+# use null delimiters so files containing spaces are supported;
+# pass /dev/null as the first file to search in, so the command doesn't fail if find doesn't match any files;
+# add || true for the case where grep doesn't have matches, so the script doesn't halt
+# If there's an error "Argument list too long" add -n20 to xargs arguments and loop over $FILE around sed
+FILES=`find . -type d \( -name ignored -or -name .?\* \) -prune \
+       -o -type f -not \( -name \*.log -or -name '*.war' -or -name '*.min.js' -or -name '*.min.css' \) -print0 | \
+       xargs -0 grep -l "${VERSION_MARKER}\|${VERSION_MARKER_NL}" /dev/null || true`
+
+FILES_COUNT=`echo $FILES | wc | awk '{print $2}'`
+
+if [ ${FILES_COUNT} -ne 0 ]; then
+    # search for files containing version markers
+    sed -i.bak -e "/${VERSION_MARKER}/s/${CURRENT_VERSION}/${NEW_VERSION}/g" $FILES
+    sed -i.bak -e "/${VERSION_MARKER_NL}/{n;s/${CURRENT_VERSION}/${NEW_VERSION}/g;}" $FILES
+fi
+
+echo "Changed ${VERSION_MARKER} from ${CURRENT_VERSION} to ${NEW_VERSION} for "${FILES_COUNT}" files"
+echo "(Do a \`find . -name \"*.bak\" -delete\`  to delete the backup files.)"

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/release/gpg-agent.conf
----------------------------------------------------------------------
diff --git a/release/gpg-agent.conf b/release/gpg-agent.conf
new file mode 100644
index 0000000..3cd0291
--- /dev/null
+++ b/release/gpg-agent.conf
@@ -0,0 +1,2 @@
+default-cache-ttl 7200
+max-cache-ttl 86400

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/release/make-release-artifacts.sh
----------------------------------------------------------------------
diff --git a/release/make-release-artifacts.sh b/release/make-release-artifacts.sh
new file mode 100755
index 0000000..90f138e
--- /dev/null
+++ b/release/make-release-artifacts.sh
@@ -0,0 +1,273 @@
+#!/bin/bash
+#
+# 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.
+#
+
+# Creates the following releases with archives (.tar.gz/.zip), signatures and checksums:
+#   binary  (-bin)     - contains the brooklyn dist binary release
+#   source  (-src)     - contains all the source code files that are permitted to be released
+#   vagrant (-vagrant) - contains a Vagrantfile/scripts to start a Brooklyn getting started environment
+
+set -e
+
+###############################################################################
+fail() {
+    echo >&2 "$@"
+    exit 1
+}
+
+###############################################################################
+show_help() {
+    cat >&2 <<END
+Usage: make-release-artifacts.sh [-v version] [-r rc_number]
+Prepares and builds the source and binary distribution artifacts of a Brooklyn
+release.
+
+  -vVERSION                  overrides the name of this version, if detection
+                             from pom.xml is not accurate for any reason.
+  -rRC_NUMBER                specifies the release candidate number. The
+                             produced artifact names include the 'rc' suffix,
+                             but the contents of the archive artifact do *not*
+                             include the suffix. Therefore, turning a release
+                             candidate into a release requires only renaming
+                             the artifacts.
+  -y                         answers "y" to all questions automatically, to
+                             use defaults and make this suitable for batch mode
+
+Specifying the RC number is required. Specifying the version number is
+discouraged; if auto detection is not working, then this script is buggy.
+
+Additionally if APACHE_DIST_SVN_DIR is set, this will transfer artifacts to
+that directory and svn commit them.
+END
+# ruler                      --------------------------------------------------
+}
+
+###############################################################################
+confirm() {
+    # call with a prompt string or use a default
+    if [ "${batch_confirm_y}" == "true" ] ; then
+        true
+    else
+      read -r -p "${1:-Are you sure? [y/N]} " response
+      case $response in
+        [yY][eE][sS]|[yY]) 
+            true
+            ;;
+        *)
+            false
+            ;;
+      esac
+    fi
+}
+
+###############################################################################
+detect_version() {
+    if [ \! -z "${current_version}" ]; then
+        return
+    fi
+
+    set +e
+    current_version=$( xmlstarlet select -t -v '/_:project/_:version/text()' pom.xml 2>/dev/null )
+    success=$?
+    set -e
+    if [ "${success}" -ne 0 -o -z "${current_version}" ]; then
+        fail Could not detect version number
+    fi
+}
+
+###############################################################################
+# Argument parsing
+rc_suffix=
+OPTIND=1
+while getopts "h?v:r:y?" opt; do
+    case "$opt" in
+        h|\?)
+            show_help
+            exit 0
+            ;;
+        v)
+            current_version=$OPTARG
+            ;;
+        r)
+            rc_suffix=$OPTARG
+            ;;
+        y)
+            batch_confirm_y=true
+            ;;
+        *)
+            show_help
+            exit 1
+    esac
+done
+
+shift $((OPTIND-1))
+[ "$1" = "--" ] && shift
+
+###############################################################################
+# Prerequisite checks
+[ -d .git ] || fail Must run in brooklyn project root directory
+
+detect_version
+
+###############################################################################
+# Determine all filenames and paths, and confirm
+
+release_name=apache-brooklyn-${current_version}
+if [ -z "$rc_suffix" ]; then
+    fail Specifying the RC number is required
+else
+    artifact_name=${release_name}-rc${rc_suffix}
+fi
+
+release_script_dir=$( cd $( dirname $0 ) && pwd )
+brooklyn_dir=$( pwd )
+rm -rf ${release_script_dir}/tmp
+staging_dir="${release_script_dir}/tmp/source/"
+src_staging_dir="${release_script_dir}/tmp/source/${release_name}-src"
+bin_staging_dir="${release_script_dir}/tmp/bin/"
+artifact_dir="${release_script_dir}/tmp/${artifact_name}"
+
+echo "The version is ${current_version}"
+echo "The rc suffix is rc${rc_suffix}"
+echo "The release name is ${release_name}"
+echo "The artifact name is ${artifact_name}"
+echo "The artifact directory is ${artifact_dir}"
+if [ ! -z "${APACHE_DIST_SVN_DIR}" ] ; then
+  echo "The artifacts will be copied and uploaded via ${APACHE_DIST_SVN_DIR}"
+else
+  echo "The artifacts will not be copied and uploaded to the svn repo"
+fi
+echo ""
+confirm "Is this information correct? [y/N]" || exit
+echo ""
+echo "WARNING! This script will run 'git clean -dxf' to remove ALL files that are not under Git source control."
+echo "This includes build artifacts and all uncommitted local files and directories."
+echo "If you want to check what will happen, answer no and run 'git clean -dxn' to dry run."
+echo ""
+confirm || exit
+echo ""
+echo "This script will cause uploads to be made to a staging repository on the Apache Nexus server."
+echo ""
+confirm "Shall I continue?  [y/N]" || exit
+
+###############################################################################
+# Clean the workspace
+git clean -dxf
+
+###############################################################################
+# Source release
+echo "Creating source release folder ${release_name}"
+set -x
+mkdir -p ${src_staging_dir}
+mkdir -p ${bin_staging_dir}
+# exclude: 
+# * docs (which isn't part of the release, and adding license headers to js files is cumbersome)
+# * sandbox (which hasn't been vetted so thoroughly)
+# * release (where this is running, and people who *have* the release don't need to make it)
+# * jars and friends (these are sometimes included for tests, but those are marked as skippable,
+#     and apache convention does not allow them in source builds; see PR #365
+rsync -rtp --exclude .git\* --exclude brooklyn-docs/ --exclude brooklyn-library/sandbox/ --exclude brooklyn-dist/release/ --exclude '**/*.[ejw]ar' . ${staging_dir}/${release_name}-src
+
+rm -rf ${artifact_dir}
+mkdir -p ${artifact_dir}
+set +x
+echo "Creating artifact ${artifact_dir}/${artifact_name}-src.tar.gz and .zip"
+set -x
+( cd ${staging_dir} && tar czf ${artifact_dir}/${artifact_name}-src.tar.gz ${release_name}-src )
+( cd ${staging_dir} && zip -qr ${artifact_dir}/${artifact_name}-src.zip ${release_name}-src )
+
+###############################################################################
+# Binary release
+set +x
+echo "Proceeding to build binary release"
+set -x
+
+# Set up GPG agent
+if ps x | grep [g]pg-agent ; then
+  echo "gpg-agent already running; assuming it is set up and exported correctly."
+else
+  eval $(gpg-agent --daemon --no-grab --write-env-file $HOME/.gpg-agent-info)
+  GPG_TTY=$(tty)
+  export GPG_TTY GPG_AGENT_INFO
+fi
+
+# Workaround for bug BROOKLYN-1
+( cd ${src_staging_dir} && mvn clean --projects :brooklyn-archetype-quickstart )
+
+# Perform the build and deploy to Nexus staging repository
+( cd ${src_staging_dir} && mvn deploy -Papache-release )
+## To test the script without a big deploy, use the line below instead of above
+#( cd ${src_staging_dir} && mvn clean install )
+
+# Re-pack the archive with the correct names
+tar xzf ${src_staging_dir}/brooklyn-dist/dist/target/brooklyn-dist-${current_version}-dist.tar.gz -C ${bin_staging_dir}
+mv ${bin_staging_dir}/brooklyn-dist-${current_version} ${bin_staging_dir}/${release_name}-bin
+
+( cd ${bin_staging_dir} && tar czf ${artifact_dir}/${artifact_name}-bin.tar.gz ${release_name}-bin )
+( cd ${bin_staging_dir} && zip -qr ${artifact_dir}/${artifact_name}-bin.zip ${release_name}-bin )
+
+###############################################################################
+# Vagrant release
+set +x
+echo "Proceeding to rename and repackage vagrant environment release"
+set -x
+
+# Re-pack the archive with the correct names
+tar xzf ${src_staging_dir}/brooklyn-dist/vagrant/target/brooklyn-vagrant-${current_version}-dist.tar.gz -C ${bin_staging_dir}
+mv ${bin_staging_dir}/brooklyn-vagrant-${current_version} ${bin_staging_dir}/${release_name}-vagrant
+
+( cd ${bin_staging_dir} && tar czf ${artifact_dir}/${artifact_name}-vagrant.tar.gz ${release_name}-vagrant )
+( cd ${bin_staging_dir} && zip -qr ${artifact_dir}/${artifact_name}-vagrant.zip ${release_name}-vagrant )
+
+###############################################################################
+# Signatures and checksums
+
+# OSX doesn't have sha256sum, even if MacPorts md5sha1sum package is installed.
+# Easy to fake it though.
+which sha256sum >/dev/null || alias sha256sum='shasum -a 256' && shopt -s expand_aliases
+
+( cd ${artifact_dir} &&
+    for a in *.tar.gz *.zip; do
+        md5sum -b ${a} > ${a}.md5
+        sha1sum -b ${a} > ${a}.sha1
+        sha256sum -b ${a} > ${a}.sha256
+        gpg2 --armor --output ${a}.asc --detach-sig ${a}
+    done
+)
+
+###############################################################################
+
+if [ ! -z "${APACHE_DIST_SVN_DIR}" ] ; then
+  pushd ${APACHE_DIST_SVN_DIR}
+  rm -rf ${artifact_name}
+  cp -r ${artifact_dir} ${artifact_name}
+  svn add ${artifact_name}
+  svn commit --message "Add ${artifact_name} artifacts for incubator/brooklyn"
+  artifact_dir=${APACHE_DIST_SVN_DIR}/${artifact_name}
+  popd
+fi
+
+###############################################################################
+# Conclusion
+
+set +x
+echo "The release is done - here is what has been created:"
+ls ${artifact_dir}
+echo "You can find these files in: ${artifact_dir}"
+echo "The git commit ID for the voting emails is: $( git rev-parse HEAD )"

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/release/print-vote-email.sh
----------------------------------------------------------------------
diff --git a/release/print-vote-email.sh b/release/print-vote-email.sh
new file mode 100755
index 0000000..5fd2256
--- /dev/null
+++ b/release/print-vote-email.sh
@@ -0,0 +1,130 @@
+#!/bin/bash
+#
+# 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.
+#
+
+# prints a sample email with all the correct information
+
+set +x
+
+fail() {
+    echo >&2 "$@"
+    exit 1
+}
+
+if [ -z "${VERSION_NAME}" ] ; then fail VERSION_NAME must be set ; fi
+if [ -z "${RC_NUMBER}" ] ; then fail RC_NUMBER must be set ; fi
+
+base=apache-brooklyn-${VERSION_NAME}-rc${RC_NUMBER}
+
+if [ -z "$1" ] ; then fail "A single argument being the staging repo ID must be supplied, e.g. orgapachebrooklyn-1234" ; fi
+
+staging_repo_id=$1
+archetype_check=`curl https://repository.apache.org/content/repositories/${staging_repo_id}/archetype-catalog.xml 2> /dev/null`
+if ! echo $archetype_check | grep brooklyn-archetype-quickstart > /dev/null ; then
+  fail staging repo looks wrong at https://repository.apache.org/content/repositories/${staging_repo_id}
+fi
+if ! echo $archetype_check | grep ${VERSION_NAME} > /dev/null ; then
+  fail wrong version at https://repository.apache.org/content/repositories/${staging_repo_id}
+fi
+
+artifact=release/tmp/${base}/${base}-bin.tar.gz
+if [ ! -f $artifact ] ; then
+  fail could not find artifact $artifact
+fi
+if [ -z "$APACHE_ID" ] ; then
+  APACHE_ID=`gpg2 --verify ${artifact}.asc ${artifact} 2>&1 | egrep -o '[^<]*...@apache.org>' | cut -d @ -f 1`
+fi
+if [ -z "$APACHE_ID" ] ; then
+  fail "could not deduce APACHE_ID (your apache username); are files signed correctly?"
+fi
+if ! ( gpg2 --verify ${artifact}.asc ${artifact} 2>&1 | grep ${APACHE_ID}@apache.org > /dev/null ) ; then
+  fail "could not verify signature; are files signed correctly and ID ${APACHE_ID} correct?"
+fi
+
+cat <<EOF
+
+Subject: [VOTE] Release Apache Brooklyn ${VERSION_NAME} [rc${RC_NUMBER}]
+
+
+This is to call for a vote for the release of Apache Brooklyn ${VERSION_NAME}.
+
+This release comprises of a source code distribution, and a corresponding
+binary distribution, and Maven artifacts.
+
+The source and binary distributions, including signatures, digests, etc. can
+be found at:
+
+  https://dist.apache.org/repos/dist/dev/incubator/brooklyn/${base}
+
+The artifact SHA-256 checksums are as follows:
+
+EOF
+
+cat release/tmp/${base}/*.sha256 | awk '{print "  "$0}'
+
+cat <<EOF
+
+The Nexus staging repository for the Maven artifacts is located at:
+
+    https://repository.apache.org/content/repositories/${staging_repo_id}
+
+All release artifacts are signed with the following key:
+
+    https://people.apache.org/keys/committer/${APACHE_ID}.asc
+
+KEYS file available here:
+
+    https://dist.apache.org/repos/dist/release/incubator/brooklyn/KEYS
+
+
+The artifacts were built from git commit ID $( git rev-parse HEAD ):
+
+    https://git-wip-us.apache.org/repos/asf?p=incubator-brooklyn.git;a=commit;h=$( git rev-parse HEAD )
+
+
+Please vote on releasing this package as Apache Brooklyn ${VERSION_NAME}.
+
+The vote will be open for at least 72 hours.
+[ ] +1 Release this package as Apache Brooklyn ${VERSION_NAME}
+[ ] +0 no opinion
+[ ] -1 Do not release this package because ...
+
+
+Thanks!
+EOF
+
+cat <<EOF
+
+
+
+CHECKLIST for reference
+
+[ ] Download links work.
+[ ] Binaries work.
+[ ] Checksums and PGP signatures are valid.
+[ ] Expanded source archive matches contents of RC tag.
+[ ] Expanded source archive builds and passes tests.
+[ ] LICENSE is present and correct.
+[ ] NOTICE is present and correct, including copyright date.
+[ ] All files have license headers where appropriate.
+[ ] All dependencies have compatible licenses.
+[ ] No compiled archives bundled in source archive.
+[ ] I follow this project’s commits list.
+
+EOF

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/release/pull-request-reports/Gemfile
----------------------------------------------------------------------
diff --git a/release/pull-request-reports/Gemfile b/release/pull-request-reports/Gemfile
new file mode 100644
index 0000000..8ab84b5
--- /dev/null
+++ b/release/pull-request-reports/Gemfile
@@ -0,0 +1,5 @@
+#ruby=ruby-2.1.2
+#ruby-gemset=brooklyn-release-helpers
+
+source 'https://rubygems.org'
+gem 'github_api'

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/release/pull-request-reports/Gemfile.lock
----------------------------------------------------------------------
diff --git a/release/pull-request-reports/Gemfile.lock b/release/pull-request-reports/Gemfile.lock
new file mode 100644
index 0000000..859202a
--- /dev/null
+++ b/release/pull-request-reports/Gemfile.lock
@@ -0,0 +1,38 @@
+GEM
+  remote: https://rubygems.org/
+  specs:
+    addressable (2.3.8)
+    descendants_tracker (0.0.4)
+      thread_safe (~> 0.3, >= 0.3.1)
+    faraday (0.9.1)
+      multipart-post (>= 1.2, < 3)
+    github_api (0.12.3)
+      addressable (~> 2.3)
+      descendants_tracker (~> 0.0.4)
+      faraday (~> 0.8, < 0.10)
+      hashie (>= 3.3)
+      multi_json (>= 1.7.5, < 2.0)
+      nokogiri (~> 1.6.3)
+      oauth2
+    hashie (3.4.2)
+    jwt (1.5.1)
+    mini_portile (0.6.2)
+    multi_json (1.11.1)
+    multi_xml (0.5.5)
+    multipart-post (2.0.0)
+    nokogiri (1.6.6.2)
+      mini_portile (~> 0.6.0)
+    oauth2 (1.0.0)
+      faraday (>= 0.8, < 0.10)
+      jwt (~> 1.0)
+      multi_json (~> 1.3)
+      multi_xml (~> 0.5)
+      rack (~> 1.2)
+    rack (1.6.4)
+    thread_safe (0.3.5)
+
+PLATFORMS
+  ruby
+
+DEPENDENCIES
+  github_api

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/release/pull-request-reports/pr_report.rb
----------------------------------------------------------------------
diff --git a/release/pull-request-reports/pr_report.rb b/release/pull-request-reports/pr_report.rb
new file mode 100644
index 0000000..95b6317
--- /dev/null
+++ b/release/pull-request-reports/pr_report.rb
@@ -0,0 +1,12 @@
+#ruby
+
+require 'CSV'
+require 'github_api'
+
+gh = Github.new
+
+CSV.open("pr_report.tsv", "wb", { :col_sep => "\t" }) do |csv|
+  gh.pull_requests.list('apache', 'incubator-brooklyn').
+      select { |pr| pr.state == "open" }.
+      each { |pr| csv << [ pr.number, pr.title, pr.created_at, pr.user.login ] }
+end

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/release/settings.xml
----------------------------------------------------------------------
diff --git a/release/settings.xml b/release/settings.xml
new file mode 100644
index 0000000..2b03994
--- /dev/null
+++ b/release/settings.xml
@@ -0,0 +1,29 @@
+<?xml version="1.0"?>
+<settings xsi:schemaLocation="http://maven.apache.org/SETTINGS/1.1.0 http://maven.apache.org/xsd/settings-1.1.0.xsd"
+          xmlns="http://maven.apache.org/SETTINGS/1.1.0"
+          xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
+
+    <servers>
+        <!-- Required for uploads to Apache's Nexus instance. These are LDAP credentials - the same credentials you
+           - would use to log in to Git and Jenkins (but not JIRA) -->
+        <server>
+            <id>apache.snapshots.https</id>
+            <username>xxx</username>
+            <password>xxx</password>
+        </server>
+        <server>
+            <id>apache.releases.https</id>
+            <username>xxx</username>
+            <password>xxx</password>
+        </server>
+
+        <!-- This is used for deployments to the play Artifactory instance that is provisioned by the Vagrant scripts.
+           - It may be safely ignored. -->
+        <server>
+            <id>vagrant-ubuntu-trusty-64</id>
+            <username>admin</username>
+            <password>password</password>
+        </server>
+    </servers>
+
+</settings>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/scripts/buildAndTest
----------------------------------------------------------------------
diff --git a/scripts/buildAndTest b/scripts/buildAndTest
new file mode 100755
index 0000000..45c1a26
--- /dev/null
+++ b/scripts/buildAndTest
@@ -0,0 +1,102 @@
+#!/bin/bash
+#
+# 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.
+#
+# Convenience script to clean, build, install and run unit and/or integration tests.
+# Recommend you run this prior to pushing to Github to reduce the chances of breaking
+# the continuous integration (unit tests) or overnight builds (integration tests.)
+#
+# Also very useful when using "git bisect" to find out which commit was responsible
+# for breaking the overnight build - invoke as "git bisect run ./buildAndRun"
+#
+# Run "./buildAndRun --help" to see the usage.
+#
+
+# Has an integration test left a Java process running? See if there is any running
+# Java processes and offer to kill them/
+cleanup(){
+    PROCS=$(ps ax | grep '[j]ava' | grep -v set_tab_title)
+    if [ ! -z "${PROCS}" ]; then
+	echo "These Java processes are running:"
+	echo ${PROCS}
+	echo -n "Kill them? y=yes, n=no, x=abort: "
+	read $RESPONSE
+	[ "${RESPONSE}" = "y" ] && killall java && sleep 1s
+	[ "${RESPONSE}" = "x" ] && exit 50
+    fi
+}
+
+# Check a return value, and bail if its non-zero - invoke as "assert $? 'Unit tests'"
+assert(){
+    [ $1 -eq 0 ] && return
+    echo '*** Command returned '$1' on '$2
+    exit $1
+}
+
+# The defaults
+unit=1
+integration=1
+
+if [ ! -z "$1" ]; then
+    case "$1" in
+	u)
+	    unit=1
+	    integration=0
+	    ;;
+	i)
+	    unit=0
+	    integration=1
+	    ;;
+	ui)
+	    unit=1
+	    integration=1
+	    ;;
+	b)
+	    unit=0
+	    integration=0
+	    ;;
+	*)
+	    echo >&2 Usage: buildAndTest [action]
+	    echo >&2 where action is:
+	    echo >&2 u - build from clean and run unit tests
+	    echo >&2 i - build from clean and run integration tests
+	    echo >&2 ui - build from clean and run unit and integration tests \(default\)
+	    echo >&2 b - build from clean and do not run any tests
+	    exit 1
+	    ;;
+    esac
+fi
+
+echo '*** BUILD'
+mvn clean install -DskipTests -PConsole
+assert $? 'BUILD'
+cleanup
+if [ $unit -eq 1 ]; then
+    echo '*** UNIT TEST'
+    mvn integration-test -PConsole
+    assert $? 'UNIT TEST'
+    cleanup
+fi
+if [ $integration -eq 1 ]; then
+    echo '*** INTEGRATION TEST'
+    mvn integration-test -PConsole,Integration
+    assert $? 'INTEGRATION TEST'
+    cleanup
+fi
+
+exit 0

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/scripts/grep-in-poms.sh
----------------------------------------------------------------------
diff --git a/scripts/grep-in-poms.sh b/scripts/grep-in-poms.sh
new file mode 100755
index 0000000..aca9258
--- /dev/null
+++ b/scripts/grep-in-poms.sh
@@ -0,0 +1,25 @@
+#!/usr/bin/env bash
+#
+# 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.
+#
+
+# usage: run in the root dir of a project, it will grep in poms up to 3 levels deep
+# e.g. where are shaded jars defined?
+# brooklyn% grep-in-poms -i slf4j
+
+grep $* {.,*,*/*,*/*/*}/pom.xml

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/scripts/release-branch-from-master
----------------------------------------------------------------------
diff --git a/scripts/release-branch-from-master b/scripts/release-branch-from-master
new file mode 100755
index 0000000..8d7befa
--- /dev/null
+++ b/scripts/release-branch-from-master
@@ -0,0 +1,114 @@
+#!/bin/bash -e
+#
+# 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.
+#
+
+usage(){
+	echo >&2 'Usage: release-branch-from-master --release <version> [ --release-suffix <suffix> ]'
+	echo >&2 '                                  --master <version>  [ --master-suffix <suffix> ]'
+	echo >&2 'Creates a release branch, and updates the version number in both the branch and master.'
+	echo >&2 '<version> should be a two-part version number, such as 3.6 or 4.0.'
+	echo >&2 '<suffix> will normally be of the form ".patchlevel", plus "-RC1" or similar if required,'
+	echo >&2 'plus "-SNAPSHOT". Example: ".0.RC1-SNAPSHOT". The defaults for the suffix are normally sensible.'
+	echo >&2 'This command will preview what it is going to do and require confirmation before it makes changes.'
+}
+
+release_ver=
+release_ver_suffix=.0-RC1-SNAPSHOT
+master_ver=
+master_ver_suffix=.0-SNAPSHOT
+
+[ $# -eq 0 ] && echo >&2 "No arguments given, so I'm going to try and figure it out myself. Invoke with the --help option if you want to find how to invoke this script."
+
+while [ $# -gt 0 ]; do
+	case $1 in
+		--release)			shift; release_ver=$1;;
+		--release-suffix)	shift; release_ver_suffix=$1;;
+		--master)			shift; master_ver=$1;;
+		--master-suffix)	shift; master_ver_suffix=$1;;
+		*)					usage; exit 1;;
+	esac
+	shift
+done
+
+# Use xpath to query the current version number in the pom
+xpath='xpath'
+type -P $xpath &>/dev/null && {
+	set +e
+	current_version=$( xpath pom.xml '/project/version/text()' 2>/dev/null )
+	( echo ${current_version} | grep -qE '^([0-9]+).([0-9]+).0-SNAPSHOT$' )
+	current_version_valid=$?
+	set -e 
+} || { 
+	echo "Cannot guess version number as $xpath command not found."
+	current_version_valid=1
+}
+
+if [ "${current_version_valid}" -ne 0 -a -z "${release_ver}" -a -z "${master_ver}" ]; then
+	echo >&2 "Detected current version as '${current_version}', but I can't parse this. Please supply --release and --master parameters."
+	exit 1
+fi
+
+[ -z "${release_ver}" ] && {
+	release_ver=${current_version%-SNAPSHOT}
+	release_ver=${release_ver%.0}
+	[ -z "${release_ver}" ] && { echo >&2 Could not determine the version of the release branch. Please use the --release parameter. ; exit 1 ; }
+}
+
+[ -z "${master_ver}" ] && {
+	master_ver=$( echo ${current_version} | perl -n -e 'if (/^(\d+).(\d+)(.*)$/) { printf "%s.%s\n", $1, $2+1 }' )
+	[ -z "${master_ver}" ] && { echo >&2 Could not determine the version of the master branch. Please use the --master parameter. ; exit 1 ; }
+}
+
+version_on_branch=${release_ver}${release_ver_suffix}
+version_on_master=${master_ver}${master_ver_suffix}
+branch_name=${version_on_branch}
+
+# Show the details and get confirmation
+echo "The current version is:                                  ${current_version}"
+echo "The release branch will be named:                        ${branch_name}"
+echo "The version number on the release branch will be set to: ${version_on_branch}"
+echo "The version number on 'master' will be set to:           ${version_on_master}"
+echo "If you proceed, the new branch and version number changes will be pushed to GitHub."
+echo -n 'Enter "y" if this is correct, anything else to abort: '
+read input
+[ "$input" == "y" ] || { echo >&2 Aborted. ; exit 1 ; }
+
+# Fail if not in a Git repository
+[ -d .git ] || {
+	echo >&2 Error: this directory is not a git repository root. Nothing happened.
+	exit 1
+}
+
+# Warn if the current branch isn't master
+current_branch=$( git name-rev --name-only HEAD )
+[ ${current_branch} == "master" ] || {
+	echo Current branch is ${current_branch}. Usually, release branches are made from master.
+	echo -n 'Enter "y" if this is correct, anything else to abort: '
+	read input
+	[ "$input" == "y" ] || { echo >&2 Aborted. ; exit 1 ; }
+}
+
+# Get Maven to make the branch
+set -x
+mvn release:clean release:branch -P Brooklyn,Console,Example,Launcher,Acceptance,Documentation --batch-mode -DautoVersionSubmodules=true -DbranchName=${branch_name} -DupdateBranchVersions=true -DreleaseVersion=${version_on_branch} -DdevelopmentVersion=${version_on_master}
+set +x
+
+# Done!
+echo Completed. Your repository is still looking at ${current_branch}. To switch to the release branch, enter:
+echo git checkout ${branch_name}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/scripts/release-make
----------------------------------------------------------------------
diff --git a/scripts/release-make b/scripts/release-make
new file mode 100755
index 0000000..df46ea1
--- /dev/null
+++ b/scripts/release-make
@@ -0,0 +1,83 @@
+#!/bin/bash -e -u
+#
+# 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.
+#
+
+usage(){
+	echo >&2 'Usage: release-make [ --release <version> ] [ --next <version> ]'
+	echo >&2 'Creates and tags a release based on the current branch.'
+	echo >&2 'Arguments are optional - if omitted, the script tries to work out the correct versions.'
+	echo >&2 'release <version> should be a full version number, such as 3.6.0-RC1'
+	echo >&2 'next <version> should be a snapshot version number, such as 3.6.0-RC2-SNAPSHOT'
+	echo >&2 'This command will preview what it is going to do and require confirmation before it makes changes.'
+}
+
+[ $# -eq 0 ] && echo >&2 "No arguments given, so I'm going to try and figure it out myself. Invoke with the --help option if you want to find how to invoke this script."
+
+release_tag_ver=
+release_branch_ver=
+
+while [ $# -gt 0 ]; do
+	case $1 in
+		--release)	shift; release_tag_ver=$1;;
+		--next)		shift; release_branch_ver=$1;;
+		*)					usage; exit 1;;
+	esac
+	shift
+done
+
+# Some magic to derive the anticipated version of the release.
+# Use xpath to query the version number in the pom
+xpath='xpath'
+type -P $xpath &>/dev/null && {
+	set +e
+	current_version=$( xpath pom.xml '/project/version/text()' 2>/dev/null )
+	set -e
+} || {
+        echo "Cannot guess version number as $xpath command not found."
+}
+# If the user didn't supply the release version, strip -SNAPSHOT off the current version and use that
+[ -z "$release_tag_ver" ] && release_tag_ver=${current_version%-SNAPSHOT}
+
+# More magic, this time to guess the next version.
+# If the user didn't supply the next version, modify the digits off the end of the release to increment by one and append -SNAPSHOT
+[ -z "$release_branch_ver" ] && release_branch_ver=$( echo ${release_tag_ver} | perl -n -e 'if (/^(.*)(\d+)$/) { print $1.($2+1)."-SNAPSHOT\n" }' )
+
+current_branch=$( git name-rev --name-only HEAD )
+
+echo "The release is on the branch:                             ${current_branch}"
+echo "The current version (detected) is:                        ${current_version}"
+echo "The release version is:                                   ${release_tag_ver}"
+echo "Development on the release branch continues with version: ${release_branch_ver}"
+echo -n 'Enter "y" if this is correct, anything else to abort: '
+read input
+[ "$input" == "y" ] || { echo >&2 Aborted. ; exit 1 ; }
+
+# Warn if the current branch is master
+[ ${current_branch} == "master" ] && {
+	echo Current branch is ${current_branch}. Usually, releases are made from a release branch.
+	echo -n 'Enter "y" if this is correct, anything else to abort: '
+	read input
+	[ "$input" == "y" ] || { echo >&2 Aborted. ; exit 1 ; }
+}
+
+# Release prepare
+mvn release:clean release:prepare -PExample,Launcher,Four,Three --batch-mode -DautoVersionSubmodules=true -DreleaseVersion=${release_tag_ver} -DdevelopmentVersion=${release_branch_ver}
+
+# Release perform
+mvn release:perform -PExample,Launcher,Four,Three --batch-mode


[05/51] [abbrv] brooklyn-dist git commit: [SPLITPREP] rearranged to have structure of new repositories

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/release/Vagrantfile
----------------------------------------------------------------------
diff --git a/release/Vagrantfile b/release/Vagrantfile
deleted file mode 100644
index 016c48f..0000000
--- a/release/Vagrantfile
+++ /dev/null
@@ -1,66 +0,0 @@
-# -*- mode: ruby -*-
-# vi: set ft=ruby :
-#
-# 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.
-#
-
-# Vagrantfile that creates a basic workstation for compiling Brooklyn and
-# running tests. Particularly useful for running integration tests, as you
-# can clean up any failed tests simply by destroying and rebuilding the
-# Vagrant instance.
-
-# All Vagrant configuration is done below. The "2" in Vagrant.configure
-# configures the configuration version (we support older styles for
-# backwards compatibility). Please don't change it unless you know what
-# you're doing.
-Vagrant.configure(2) do |config|
-
-  # Base on Ubuntu 14.04 LTS
-  config.vm.box = "ubuntu/trusty64"
-
-  # Provider-specific configuration so you can fine-tune various
-  # backing providers for Vagrant. These expose provider-specific options.
-  config.vm.provider "virtualbox" do |vb|
-    vb.memory = "2048"
-  end
-
-  config.vm.network "forwarded_port", guest: 8008, host: 8008
-
-  config.vm.provision "file", source: "~/.gitconfig", destination: ".gitconfig"
-  config.vm.provision "file", source: "~/.gnupg/gpg.conf", destination: ".gnupg/gpg.conf"
-  config.vm.provision "file", source: "~/.gnupg/pubring.gpg", destination: ".gnupg/pubring.gpg"
-  config.vm.provision "file", source: "~/.gnupg/secring.gpg", destination: ".gnupg/secring.gpg"
-  config.vm.provision "file", source: "gpg-agent.conf", destination: ".gnupg/gpg-agent.conf"
-  config.vm.provision "file", source: "settings.xml", destination: ".m2/settings.xml"
-
-  # Update the VM, install Java and Maven, enable passwordless-ssh-to-localhost,
-  # clone the canonical repository
-  config.vm.provision "shell", inline: <<-SHELL
-    apt-get update
-    apt-get upgrade -y
-    apt-get install -y default-jdk maven git xmlstarlet zip unzip language-pack-en vim-nox gnupg2 gnupg-agent pinentry-curses
-    wget -q -O /tmp/artifactory.zip http://bit.ly/Hqv9aj
-    mkdir -p /opt
-    unzip /tmp/artifactory.zip -d /opt
-    sudo sed -i -e '/Connector port=/ s/=\".*\"/=\"'"8008"'\"/' /opt/artifactory*/tomcat/conf/server.xml
-    /opt/artifactory*/bin/installService.sh
-    service artifactory start
-    chmod -R go= ~vagrant/.gnupg
-    cat /etc/ssh/ssh_host_*_key.pub | awk '{print "localhost,127.0.0.1 "$0}' >> /etc/ssh/ssh_known_hosts
-    su -c 'ssh-keygen -t rsa -b 2048 -N "" -f ~/.ssh/id_rsa; cat ~/.ssh/*.pub >> ~/.ssh/authorized_keys' vagrant
-    su -c 'git clone https://git-wip-us.apache.org/repos/asf/incubator-brooklyn.git apache-brooklyn-git' vagrant
-  SHELL
-end

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/release/change-version.sh
----------------------------------------------------------------------
diff --git a/release/change-version.sh b/release/change-version.sh
deleted file mode 100755
index 280c245..0000000
--- a/release/change-version.sh
+++ /dev/null
@@ -1,70 +0,0 @@
-#!/usr/bin/env bash
-#
-# 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.
-#
-
-set -e
-
-# changes the version everywhere
-# usage, e.g.:  change-version.sh 0.3.0-SNAPSHOT 0.3.0-RC1
-#          or:  change-version.sh MARKER 0.3.0-SNAPSHOT 0.3.0-RC1
-
-[ -d .git ] || {
-  echo "Must run in brooklyn project root directory"
-  exit 1
-}
-
-if [ "$#" -eq 2 ]; then
-  VERSION_MARKER=BROOKLYN_VERSION
-elif [ "$#" -eq 3 ]; then
-  VERSION_MARKER=$1_VERSION
-  shift;
-else
-  echo "Usage:  "$0" [VERSION_MARKER] CURRENT_VERSION NEW_VERSION"
-  echo " e.g.:  "$0" BROOKLYN 0.3.0-SNAPSHOT 0.3.0-RC1"
-  exit 1
-fi
-
-# remove binaries and stuff
-if [ -f pom.xml ] && [ -d target ] ; then mvn clean ; fi
-
-VERSION_MARKER_NL=${VERSION_MARKER}_BELOW
-CURRENT_VERSION=$1
-NEW_VERSION=$2
-
-# grep --exclude-dir working only in recent versions, not on all platforms, replace with find;
-# skip folders named "ignored" or .xxx (but not the current folder ".");
-# exclude log, war, etc. files;
-# use null delimiters so files containing spaces are supported;
-# pass /dev/null as the first file to search in, so the command doesn't fail if find doesn't match any files;
-# add || true for the case where grep doesn't have matches, so the script doesn't halt
-# If there's an error "Argument list too long" add -n20 to xargs arguments and loop over $FILE around sed
-FILES=`find . -type d \( -name ignored -or -name .?\* \) -prune \
-       -o -type f -not \( -name \*.log -or -name '*.war' -or -name '*.min.js' -or -name '*.min.css' \) -print0 | \
-       xargs -0 grep -l "${VERSION_MARKER}\|${VERSION_MARKER_NL}" /dev/null || true`
-
-FILES_COUNT=`echo $FILES | wc | awk '{print $2}'`
-
-if [ ${FILES_COUNT} -ne 0 ]; then
-    # search for files containing version markers
-    sed -i.bak -e "/${VERSION_MARKER}/s/${CURRENT_VERSION}/${NEW_VERSION}/g" $FILES
-    sed -i.bak -e "/${VERSION_MARKER_NL}/{n;s/${CURRENT_VERSION}/${NEW_VERSION}/g;}" $FILES
-fi
-
-echo "Changed ${CURRENT_VERSION} to ${NEW_VERSION} for "${FILES_COUNT}" files"
-echo "(Do a \`find . -name \"*.bak\" -delete\`  to delete the backup files.)"

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/release/gpg-agent.conf
----------------------------------------------------------------------
diff --git a/release/gpg-agent.conf b/release/gpg-agent.conf
deleted file mode 100644
index 3cd0291..0000000
--- a/release/gpg-agent.conf
+++ /dev/null
@@ -1,2 +0,0 @@
-default-cache-ttl 7200
-max-cache-ttl 86400

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/release/make-release-artifacts.sh
----------------------------------------------------------------------
diff --git a/release/make-release-artifacts.sh b/release/make-release-artifacts.sh
deleted file mode 100755
index 476a6e3..0000000
--- a/release/make-release-artifacts.sh
+++ /dev/null
@@ -1,257 +0,0 @@
-#!/bin/bash
-#
-# 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.
-#
-
-# creates a source release - this is a .tar.gz file containing all the source code files that are permitted to be released.
-
-set -e
-
-###############################################################################
-fail() {
-    echo >&2 "$@"
-    exit 1
-}
-
-###############################################################################
-show_help() {
-    cat >&2 <<END
-Usage: make-release-artifacts.sh [-v version] [-r rc_number]
-Prepares and builds the source and binary distribution artifacts of a Brooklyn
-release.
-
-  -vVERSION                  overrides the name of this version, if detection
-                             from pom.xml is not accurate for any reason.
-  -rRC_NUMBER                specifies the release candidate number. The
-                             produced artifact names include the 'rc' suffix,
-                             but the contents of the archive artifact do *not*
-                             include the suffix. Therefore, turning a release
-                             candidate into a release requires only renaming
-                             the artifacts.
-  -y                         answers "y" to all questions automatically, to
-                             use defaults and make this suitable for batch mode
-
-Specifying the RC number is required. Specifying the version number is
-discouraged; if auto detection is not working, then this script is buggy.
-
-Additionally if APACHE_DIST_SVN_DIR is set, this will transfer artifacts to
-that directory and svn commit them.
-END
-# ruler                      --------------------------------------------------
-}
-
-###############################################################################
-confirm() {
-    # call with a prompt string or use a default
-    if [ "${batch_confirm_y}" == "true" ] ; then
-        true
-    else
-      read -r -p "${1:-Are you sure? [y/N]} " response
-      case $response in
-        [yY][eE][sS]|[yY]) 
-            true
-            ;;
-        *)
-            false
-            ;;
-      esac
-    fi
-}
-
-###############################################################################
-detect_version() {
-    if [ \! -z "${current_version}" ]; then
-        return
-    fi
-
-    set +e
-    current_version=$( xmlstarlet select -t -v '/_:project/_:version/text()' pom.xml 2>/dev/null )
-    success=$?
-    set -e
-    if [ "${success}" -ne 0 -o -z "${current_version}" ]; then
-        fail Could not detect version number
-    fi
-}
-
-###############################################################################
-# Argument parsing
-rc_suffix=
-OPTIND=1
-while getopts "h?v:r:y?" opt; do
-    case "$opt" in
-        h|\?)
-            show_help
-            exit 0
-            ;;
-        v)
-            current_version=$OPTARG
-            ;;
-        r)
-            rc_suffix=$OPTARG
-            ;;
-        y)
-            batch_confirm_y=true
-            ;;
-        *)
-            show_help
-            exit 1
-    esac
-done
-
-shift $((OPTIND-1))
-[ "$1" = "--" ] && shift
-
-###############################################################################
-# Prerequisite checks
-[ -d .git ] || fail Must run in brooklyn project root directory
-
-detect_version
-
-###############################################################################
-# Determine all filenames and paths, and confirm
-
-release_name=apache-brooklyn-${current_version}
-if [ -z "$rc_suffix" ]; then
-    fail Specifying the RC number is required
-else
-    artifact_name=${release_name}-rc${rc_suffix}
-fi
-
-release_script_dir=$( cd $( dirname $0 ) && pwd )
-brooklyn_dir=$( pwd )
-rm -rf ${release_script_dir}/tmp
-staging_dir="${release_script_dir}/tmp/source/"
-src_staging_dir="${release_script_dir}/tmp/source/${release_name}-src"
-bin_staging_dir="${release_script_dir}/tmp/bin/"
-artifact_dir="${release_script_dir}/tmp/${artifact_name}"
-
-echo "The version is ${current_version}"
-echo "The rc suffix is rc${rc_suffix}"
-echo "The release name is ${release_name}"
-echo "The artifact name is ${artifact_name}"
-echo "The artifact directory is ${artifact_dir}"
-if [ ! -z "${APACHE_DIST_SVN_DIR}" ] ; then
-  echo "The artifacts will be copied and uploaded via ${APACHE_DIST_SVN_DIR}"
-else
-  echo "The artifacts will not be copied and uploaded to the svn repo"
-fi
-echo ""
-confirm "Is this information correct? [y/N]" || exit
-echo ""
-echo "WARNING! This script will run 'git clean -dxf' to remove ALL files that are not under Git source control."
-echo "This includes build artifacts and all uncommitted local files and directories."
-echo "If you want to check what will happen, answer no and run 'git clean -dxn' to dry run."
-echo ""
-confirm || exit
-echo ""
-echo "This script will cause uploads to be made to a staging repository on the Apache Nexus server."
-echo ""
-confirm "Shall I continue?  [y/N]" || exit
-
-###############################################################################
-# Clean the workspace
-git clean -dxf
-
-###############################################################################
-# Source release
-echo "Creating source release folder ${release_name}"
-set -x
-mkdir -p ${src_staging_dir}
-mkdir -p ${bin_staging_dir}
-# exclude: 
-# * docs (which isn't part of the release, and adding license headers to js files is cumbersome)
-# * sandbox (which hasn't been vetted so thoroughly)
-# * release (where this is running, and people who *have* the release don't need to make it)
-# * jars and friends (these are sometimes included for tests, but those are marked as skippable,
-#     and apache convention does not allow them in source builds; see PR #365
-rsync -rtp --exclude .git\* --exclude docs/ --exclude sandbox/ --exclude release/ --exclude '**/*.[ejw]ar' . ${staging_dir}/${release_name}-src
-
-rm -rf ${artifact_dir}
-mkdir -p ${artifact_dir}
-set +x
-echo "Creating artifact ${artifact_dir}/${artifact_name}-src.tar.gz and .zip"
-set -x
-( cd ${staging_dir} && tar czf ${artifact_dir}/${artifact_name}-src.tar.gz ${release_name}-src )
-( cd ${staging_dir} && zip -qr ${artifact_dir}/${artifact_name}-src.zip ${release_name}-src )
-
-###############################################################################
-# Binary release
-set +x
-echo "Proceeding to build binary release"
-set -x
-
-# Set up GPG agent
-if ps x | grep [g]pg-agent ; then
-  echo "gpg-agent already running; assuming it is set up and exported correctly."
-else
-  eval $(gpg-agent --daemon --no-grab --write-env-file $HOME/.gpg-agent-info)
-  GPG_TTY=$(tty)
-  export GPG_TTY GPG_AGENT_INFO
-fi
-
-# Workaround for bug BROOKLYN-1
-( cd ${src_staging_dir} && mvn clean --projects :brooklyn-archetype-quickstart )
-
-# Perform the build and deploy to Nexus staging repository
-( cd ${src_staging_dir} && mvn deploy -Papache-release )
-## To test the script without a big deploy, use the line below instead of above
-#( cd ${src_staging_dir} && cd usage/dist && mvn clean install )
-
-# Re-pack the archive with the correct names
-tar xzf ${src_staging_dir}/usage/dist/target/brooklyn-dist-${current_version}-dist.tar.gz -C ${bin_staging_dir}
-mv ${bin_staging_dir}/brooklyn-dist-${current_version} ${bin_staging_dir}/${release_name}-bin
-
-( cd ${bin_staging_dir} && tar czf ${artifact_dir}/${artifact_name}-bin.tar.gz ${release_name}-bin )
-( cd ${bin_staging_dir} && zip -qr ${artifact_dir}/${artifact_name}-bin.zip ${release_name}-bin )
-
-###############################################################################
-# Signatures and checksums
-
-# OSX doesn't have sha256sum, even if MacPorts md5sha1sum package is installed.
-# Easy to fake it though.
-which sha256sum >/dev/null || alias sha256sum='shasum -a 256' && shopt -s expand_aliases
-
-( cd ${artifact_dir} &&
-    for a in *.tar.gz *.zip; do
-        md5sum -b ${a} > ${a}.md5
-        sha1sum -b ${a} > ${a}.sha1
-        sha256sum -b ${a} > ${a}.sha256
-        gpg2 --armor --output ${a}.asc --detach-sig ${a}
-    done
-)
-
-###############################################################################
-
-if [ ! -z "${APACHE_DIST_SVN_DIR}" ] ; then
-  pushd ${APACHE_DIST_SVN_DIR}
-  rm -rf ${artifact_name}
-  cp -r ${artifact_dir} ${artifact_name}
-  svn add ${artifact_name}
-  svn commit --message "Add ${artifact_name} artifacts for incubator/brooklyn"
-  artifact_dir=${APACHE_DIST_SVN_DIR}/${artifact_name}
-  popd
-fi
-
-###############################################################################
-# Conclusion
-
-set +x
-echo "The release is done - here is what has been created:"
-ls ${artifact_dir}
-echo "You can find these files in: ${artifact_dir}"
-echo "The git commit ID for the voting emails is: $( git rev-parse HEAD )"

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/release/print-vote-email.sh
----------------------------------------------------------------------
diff --git a/release/print-vote-email.sh b/release/print-vote-email.sh
deleted file mode 100755
index 5fd2256..0000000
--- a/release/print-vote-email.sh
+++ /dev/null
@@ -1,130 +0,0 @@
-#!/bin/bash
-#
-# 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.
-#
-
-# prints a sample email with all the correct information
-
-set +x
-
-fail() {
-    echo >&2 "$@"
-    exit 1
-}
-
-if [ -z "${VERSION_NAME}" ] ; then fail VERSION_NAME must be set ; fi
-if [ -z "${RC_NUMBER}" ] ; then fail RC_NUMBER must be set ; fi
-
-base=apache-brooklyn-${VERSION_NAME}-rc${RC_NUMBER}
-
-if [ -z "$1" ] ; then fail "A single argument being the staging repo ID must be supplied, e.g. orgapachebrooklyn-1234" ; fi
-
-staging_repo_id=$1
-archetype_check=`curl https://repository.apache.org/content/repositories/${staging_repo_id}/archetype-catalog.xml 2> /dev/null`
-if ! echo $archetype_check | grep brooklyn-archetype-quickstart > /dev/null ; then
-  fail staging repo looks wrong at https://repository.apache.org/content/repositories/${staging_repo_id}
-fi
-if ! echo $archetype_check | grep ${VERSION_NAME} > /dev/null ; then
-  fail wrong version at https://repository.apache.org/content/repositories/${staging_repo_id}
-fi
-
-artifact=release/tmp/${base}/${base}-bin.tar.gz
-if [ ! -f $artifact ] ; then
-  fail could not find artifact $artifact
-fi
-if [ -z "$APACHE_ID" ] ; then
-  APACHE_ID=`gpg2 --verify ${artifact}.asc ${artifact} 2>&1 | egrep -o '[^<]*...@apache.org>' | cut -d @ -f 1`
-fi
-if [ -z "$APACHE_ID" ] ; then
-  fail "could not deduce APACHE_ID (your apache username); are files signed correctly?"
-fi
-if ! ( gpg2 --verify ${artifact}.asc ${artifact} 2>&1 | grep ${APACHE_ID}@apache.org > /dev/null ) ; then
-  fail "could not verify signature; are files signed correctly and ID ${APACHE_ID} correct?"
-fi
-
-cat <<EOF
-
-Subject: [VOTE] Release Apache Brooklyn ${VERSION_NAME} [rc${RC_NUMBER}]
-
-
-This is to call for a vote for the release of Apache Brooklyn ${VERSION_NAME}.
-
-This release comprises of a source code distribution, and a corresponding
-binary distribution, and Maven artifacts.
-
-The source and binary distributions, including signatures, digests, etc. can
-be found at:
-
-  https://dist.apache.org/repos/dist/dev/incubator/brooklyn/${base}
-
-The artifact SHA-256 checksums are as follows:
-
-EOF
-
-cat release/tmp/${base}/*.sha256 | awk '{print "  "$0}'
-
-cat <<EOF
-
-The Nexus staging repository for the Maven artifacts is located at:
-
-    https://repository.apache.org/content/repositories/${staging_repo_id}
-
-All release artifacts are signed with the following key:
-
-    https://people.apache.org/keys/committer/${APACHE_ID}.asc
-
-KEYS file available here:
-
-    https://dist.apache.org/repos/dist/release/incubator/brooklyn/KEYS
-
-
-The artifacts were built from git commit ID $( git rev-parse HEAD ):
-
-    https://git-wip-us.apache.org/repos/asf?p=incubator-brooklyn.git;a=commit;h=$( git rev-parse HEAD )
-
-
-Please vote on releasing this package as Apache Brooklyn ${VERSION_NAME}.
-
-The vote will be open for at least 72 hours.
-[ ] +1 Release this package as Apache Brooklyn ${VERSION_NAME}
-[ ] +0 no opinion
-[ ] -1 Do not release this package because ...
-
-
-Thanks!
-EOF
-
-cat <<EOF
-
-
-
-CHECKLIST for reference
-
-[ ] Download links work.
-[ ] Binaries work.
-[ ] Checksums and PGP signatures are valid.
-[ ] Expanded source archive matches contents of RC tag.
-[ ] Expanded source archive builds and passes tests.
-[ ] LICENSE is present and correct.
-[ ] NOTICE is present and correct, including copyright date.
-[ ] All files have license headers where appropriate.
-[ ] All dependencies have compatible licenses.
-[ ] No compiled archives bundled in source archive.
-[ ] I follow this project’s commits list.
-
-EOF

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/release/pull-request-reports/Gemfile
----------------------------------------------------------------------
diff --git a/release/pull-request-reports/Gemfile b/release/pull-request-reports/Gemfile
deleted file mode 100644
index 8ab84b5..0000000
--- a/release/pull-request-reports/Gemfile
+++ /dev/null
@@ -1,5 +0,0 @@
-#ruby=ruby-2.1.2
-#ruby-gemset=brooklyn-release-helpers
-
-source 'https://rubygems.org'
-gem 'github_api'

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/release/pull-request-reports/Gemfile.lock
----------------------------------------------------------------------
diff --git a/release/pull-request-reports/Gemfile.lock b/release/pull-request-reports/Gemfile.lock
deleted file mode 100644
index 859202a..0000000
--- a/release/pull-request-reports/Gemfile.lock
+++ /dev/null
@@ -1,38 +0,0 @@
-GEM
-  remote: https://rubygems.org/
-  specs:
-    addressable (2.3.8)
-    descendants_tracker (0.0.4)
-      thread_safe (~> 0.3, >= 0.3.1)
-    faraday (0.9.1)
-      multipart-post (>= 1.2, < 3)
-    github_api (0.12.3)
-      addressable (~> 2.3)
-      descendants_tracker (~> 0.0.4)
-      faraday (~> 0.8, < 0.10)
-      hashie (>= 3.3)
-      multi_json (>= 1.7.5, < 2.0)
-      nokogiri (~> 1.6.3)
-      oauth2
-    hashie (3.4.2)
-    jwt (1.5.1)
-    mini_portile (0.6.2)
-    multi_json (1.11.1)
-    multi_xml (0.5.5)
-    multipart-post (2.0.0)
-    nokogiri (1.6.6.2)
-      mini_portile (~> 0.6.0)
-    oauth2 (1.0.0)
-      faraday (>= 0.8, < 0.10)
-      jwt (~> 1.0)
-      multi_json (~> 1.3)
-      multi_xml (~> 0.5)
-      rack (~> 1.2)
-    rack (1.6.4)
-    thread_safe (0.3.5)
-
-PLATFORMS
-  ruby
-
-DEPENDENCIES
-  github_api

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/release/pull-request-reports/pr_report.rb
----------------------------------------------------------------------
diff --git a/release/pull-request-reports/pr_report.rb b/release/pull-request-reports/pr_report.rb
deleted file mode 100644
index 95b6317..0000000
--- a/release/pull-request-reports/pr_report.rb
+++ /dev/null
@@ -1,12 +0,0 @@
-#ruby
-
-require 'CSV'
-require 'github_api'
-
-gh = Github.new
-
-CSV.open("pr_report.tsv", "wb", { :col_sep => "\t" }) do |csv|
-  gh.pull_requests.list('apache', 'incubator-brooklyn').
-      select { |pr| pr.state == "open" }.
-      each { |pr| csv << [ pr.number, pr.title, pr.created_at, pr.user.login ] }
-end

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/release/settings.xml
----------------------------------------------------------------------
diff --git a/release/settings.xml b/release/settings.xml
deleted file mode 100644
index 2b03994..0000000
--- a/release/settings.xml
+++ /dev/null
@@ -1,29 +0,0 @@
-<?xml version="1.0"?>
-<settings xsi:schemaLocation="http://maven.apache.org/SETTINGS/1.1.0 http://maven.apache.org/xsd/settings-1.1.0.xsd"
-          xmlns="http://maven.apache.org/SETTINGS/1.1.0"
-          xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
-
-    <servers>
-        <!-- Required for uploads to Apache's Nexus instance. These are LDAP credentials - the same credentials you
-           - would use to log in to Git and Jenkins (but not JIRA) -->
-        <server>
-            <id>apache.snapshots.https</id>
-            <username>xxx</username>
-            <password>xxx</password>
-        </server>
-        <server>
-            <id>apache.releases.https</id>
-            <username>xxx</username>
-            <password>xxx</password>
-        </server>
-
-        <!-- This is used for deployments to the play Artifactory instance that is provisioned by the Vagrant scripts.
-           - It may be safely ignored. -->
-        <server>
-            <id>vagrant-ubuntu-trusty-64</id>
-            <username>admin</username>
-            <password>password</password>
-        </server>
-    </servers>
-
-</settings>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/all/pom.xml
----------------------------------------------------------------------
diff --git a/usage/all/pom.xml b/usage/all/pom.xml
deleted file mode 100644
index 289d4a6..0000000
--- a/usage/all/pom.xml
+++ /dev/null
@@ -1,117 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-    
-     http://www.apache.org/licenses/LICENSE-2.0
-    
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-    <modelVersion>4.0.0</modelVersion>
-    <packaging>jar</packaging>
-
-    <artifactId>brooklyn-all</artifactId>
-
-    <name>Brooklyn All Things</name>
-    <description>
-        A meta-dependency for all the major Brooklyn modules.
-    </description>
-
-    <parent>
-        <groupId>org.apache.brooklyn</groupId>
-        <artifactId>brooklyn-parent</artifactId>
-        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-        <relativePath>../../parent/pom.xml</relativePath>
-    </parent>
-
-    <dependencies>
-        <dependency>
-            <groupId>com.google.guava</groupId>
-            <artifactId>guava</artifactId>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-policy</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-locations-jclouds</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-software-webapp</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-software-messaging</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-software-monitoring</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-software-database</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-software-osgi</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-software-nosql</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-software-network</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-launcher</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-cli</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-test-framework</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-
-        <!-- bring in all jclouds-supported cloud providers -->
-        <dependency>
-            <groupId>${jclouds.groupId}</groupId>
-            <artifactId>jclouds-allcompute</artifactId>
-        </dependency>
-    </dependencies>
-
-</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/NOTES.txt
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/NOTES.txt b/usage/archetypes/quickstart/NOTES.txt
deleted file mode 100644
index 4028bf6..0000000
--- a/usage/archetypes/quickstart/NOTES.txt
+++ /dev/null
@@ -1,76 +0,0 @@
-
-This file contains notes for anyone working on the archetype.
-
-
-Some things to keep in mind:
-
-* The sample project in `src/brooklyn-sample` is what populates the
-  archetype source (in `src/main/resources/archetype-resources`, 
-  copied there by the `pom.xml` in this directory, in `clean` phase).
-  (You can open and edit it in your IDE.)
-  
-* That archetype source then becomes the archetype (in `install` phase)
-  according to the copy and filter rules in `src/main/resources/META-INF/maven/archetype-metadata.xml`
-
-* For any changes to the project:
-
-  * ensure `brooklyn-sample` builds as you would like
-  * ensure the resulting archetype builds as you would like
-    (should be reasonably safe and automated, but check that the 2 sets of 
-    copy/translation rules above do what you intended!)
-  * update the `README.*` files in the root of `brooklyn-sample` and the
-    `src/main/assembly/files` within that
-  * update the docs under `use/guide/defining-applications/archetype.md` and `use/guide/quickstart/index.md`
-
-
-To build:
-
-    mvn clean install
-
-
-To test a build:
-
-    pushd /tmp
-    rm -rf brooklyn-sample
-    export BV=0.9.0-SNAPSHOT    # BROOKLYN_VERSION
-    
-    mvn archetype:generate                                  \
-                                                            \
-      -DarchetypeGroupId=org.apache.brooklyn                \
-      -DarchetypeArtifactId=brooklyn-archetype-quickstart   \
-      -DarchetypeVersion=${BV} \
-      \
-      -DgroupId=com.acme.sample                             \
-      -DartifactId=brooklyn-sample                          \
-      -Dversion=0.1.0-SNAPSHOT                              \
-      -Dpackage=com.acme.sample.brooklyn                    \
-      \
-      --batch-mode
-    
-    cd brooklyn-sample
-    mvn clean assembly:assembly
-    cd target/brooklyn-sample-0.1.0-SNAPSHOT-dist/brooklyn-sample-0.1.0-SNAPSHOT/
-    ./start.sh launch --cluster --location localhost
-
-
-References
-
- * http://stackoverflow.com/questions/4082643/how-can-i-test-a-maven-archetype-that-ive-just-created/18916065#18916065
-
-----
-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.

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/pom.xml
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/pom.xml b/usage/archetypes/quickstart/pom.xml
deleted file mode 100644
index 6caa79e..0000000
--- a/usage/archetypes/quickstart/pom.xml
+++ /dev/null
@@ -1,232 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-    
-     http://www.apache.org/licenses/LICENSE-2.0
-    
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-  <modelVersion>4.0.0</modelVersion>
-  <artifactId>brooklyn-archetype-quickstart</artifactId>
-  <packaging>maven-archetype</packaging>
-  <name>Brooklyn Quick-Start Project Archetype</name>
-  <description>
-    This project defines an archetype for creating new projects which consume brooklyn,
-    including an example application and an example new entity type,
-    able to build an OSGi JAR and a binary assembly, with logging and READMEs.
-  </description>
-
-  <parent>
-    <groupId>org.apache.brooklyn</groupId>
-    <artifactId>brooklyn-parent</artifactId>
-    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-    <relativePath>../../../parent/pom.xml</relativePath>
-  </parent>
-
-  <build>
-    <plugins>
-      <plugin>
-        <artifactId>maven-archetype-plugin</artifactId>
-        <!-- all we want to do is skip _integration tests_ when skipTests is set, not other phases;
-             but for some reason this seems to do it, and it still builds the archetype (!?).
-             whereas setting skip inside the integration-test execution goal does NOT work.
-              
-             TODO promote to root pom.xml when we better understand why
-        -->
-        <configuration>
-          <skip>${skipTests}</skip>
-        </configuration>
-      </plugin>
-      
-      <plugin>
-        <artifactId>maven-clean-plugin</artifactId>
-        <configuration>
-          <filesets>
-            <fileset> 
-                <directory>src/test/resources/projects/integration-test-1/reference</directory> 
-                <includes><include>**/*</include></includes>
-            </fileset>
-            <fileset> 
-                <directory>src/main/resources/archetype-resources/</directory> 
-                <includes><include>**/*</include></includes>
-            </fileset>
-          </filesets>
-        </configuration>
-      </plugin>
-
-      <plugin>
-        <groupId>com.google.code.maven-replacer-plugin</groupId>
-        <artifactId>maven-replacer-plugin</artifactId>
-        <executions>
-          <execution>
-            <id>copy-brooklyn-sample-to-integration-test-reference</id>
-            <phase>clean</phase>
-            <goals> <goal>replace</goal> </goals>
-            <configuration>
-              <basedir>${basedir}/src/brooklyn-sample</basedir> 
-              <outputBasedir>${basedir}</outputBasedir>
-              <outputDir>src/test/resources/projects/integration-test-1/reference</outputDir>
-              <includes> <include>**</include> </includes>
-              <excludes> 
-                <exclude>.*</exclude> 
-                <exclude>.*/**</exclude> 
-                <exclude>target/**</exclude> 
-                <exclude>*.log</exclude> 
-              </excludes>
-              
-              <replacements />
-            </configuration>
-          </execution>
-          <!-- would be nice to reduce the repetion below, but don't see how;
-               have tried with valueTokenMap but it must lie beneath basedir;
-               and tried with {input,output}FilePattern but that doesn't apply to dirs  -->
-          <execution>
-            <!-- copy creating variables and unpackaged, for src/main/java -->
-            <id>copy-brooklyn-sample-to-archetype-src-main-java</id>
-            <phase>clean</phase>
-            <goals> <goal>replace</goal> </goals>
-            <configuration>
-              <basedir>${basedir}/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn</basedir>
-              <outputBasedir>${basedir}</outputBasedir>
-              <outputDir>src/main/resources/archetype-resources/src/main/java</outputDir>
-              <includes> <include>**/*</include> </includes>
-              <replacements>
-                <replacement> <token>brooklyn-sample</token> <value>\$\{artifactId}</value> </replacement>
-                <replacement> <token>com\.acme\.sample\.brooklyn</token> <value>\$\{package}</value> </replacement>
-                <replacement> <token>com/acme/sample/brooklyn</token> <value>\$\{packageInPathFormat}</value> </replacement>
-                <replacement> <token>com\.acme\.sample</token> <value>\$\{groupId}</value> </replacement>
-                <replacement> <token>0.1.0-SNAPSHOT</token> <value>\$\{version}</value> </replacement>
-              </replacements>
-            </configuration>
-          </execution>
-          <execution>
-            <!-- copy creating variables and unpackaged, for src/test/java -->
-            <id>copy-brooklyn-sample-to-archetype-src-test-java</id>
-            <phase>clean</phase>
-            <goals> <goal>replace</goal> </goals>
-            <configuration>
-              <basedir>${basedir}/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn</basedir>
-              <outputBasedir>${basedir}</outputBasedir>
-              <outputDir>src/main/resources/archetype-resources/src/test/java</outputDir>
-              <includes> <include>**/*</include> </includes>
-              <replacements>
-                <replacement> <token>brooklyn-sample</token> <value>\$\{artifactId}</value> </replacement>
-                <replacement> <token>com\.acme\.sample\.brooklyn</token> <value>\$\{package}</value> </replacement>
-                <replacement> <token>com/acme/sample/brooklyn</token> <value>\$\{packageInPathFormat}</value> </replacement>
-                <replacement> <token>com\.acme\.sample</token> <value>\$\{groupId}</value> </replacement>
-                <replacement> <token>0.1.0-SNAPSHOT</token> <value>\$\{version}</value> </replacement>
-              </replacements>
-            </configuration>
-          </execution>
-          <execution>
-            <!-- copy creating variables, for all other places -->
-            <id>copy-brooklyn-sample-to-archetype-resources</id>
-            <phase>clean</phase>
-            <goals> <goal>replace</goal> </goals>
-            <configuration>
-              <basedir>${basedir}/src/brooklyn-sample/</basedir>
-              <outputBasedir>${basedir}</outputBasedir>
-              <outputDir>src/main/resources/archetype-resources/</outputDir>
-              <includes> <include>**/*</include> </includes>
-              <excludes> 
-                <exclude>src/main/java/**</exclude> 
-                <exclude>src/test/java/**</exclude> 
-                <exclude>target/**</exclude> 
-                <exclude>test-output/**</exclude> 
-                <exclude>.*</exclude> 
-                <exclude>**/*.png</exclude> 
-                <exclude>.*/**</exclude> 
-                <exclude>*.log</exclude>
-                <exclude>**/*.sh</exclude>
-              </excludes>
-              <replacements>
-                <!-- special chars in velocity have to be escaped.
-                     fortunately we only use fairly simple examples so we don't need to solve the general case! -->
-                <!-- escaping # is ugly -->
-                <replacement> <token>(#+)</token> <value>#set\(\$H='$1'\)\${H}</value> </replacement>
-                <!-- and escaping $ doesn't even seem to work; perhaps an old version of velocity in use?
-                     (however velocity ignores $ except for variables which are defined, so we're okay)
-                <replacement> <token>\$</token> <value>\\\$</value> </replacement>
-                -->
-                
-                <replacement> <token>brooklyn-sample</token> <value>\$\{artifactId}</value> </replacement>
-                <replacement> <token>com\.acme\.sample\.brooklyn</token> <value>\$\{package}</value> </replacement>
-                <replacement> <token>com/acme/sample/brooklyn</token> <value>\$\{packageInPathFormat}</value> </replacement>
-                <replacement> <token>com\.acme\.sample</token> <value>\$\{groupId}</value> </replacement>
-                <replacement> <token>0.1.0-SNAPSHOT</token> <value>\$\{version}</value> </replacement>
-              </replacements>
-            </configuration>
-          </execution>
-          <execution>
-            <!-- copy creating variables, for all other places -->
-            <id>copy-brooklyn-sample-to-archetype-resources-binary</id>
-            <phase>clean</phase>
-            <goals> <goal>replace</goal> </goals>
-            <configuration>
-              <basedir>${basedir}/src/brooklyn-sample/</basedir>
-              <outputBasedir>${basedir}</outputBasedir>
-              <outputDir>src/main/resources/archetype-resources/</outputDir>
-              <includes>
-                <include>**/*.png</include>
-                <include>**/*.sh</include>
-              </includes>
-              <excludes> 
-                <exclude>target/**</exclude> 
-                <exclude>test-output/**</exclude> 
-                <exclude>.*</exclude> 
-                <exclude>.*/**</exclude> 
-              </excludes>
-              <!-- no replacements for binary (put one just so we can use this plugin for consistency) -->
-              <replacements><replacement> <token>NONCE_123456789XYZ</token> <value>NONCE_123456789XYZ</value> </replacement></replacements>
-            </configuration>
-          </execution>
-          
-        </executions>
-      </plugin>
-
-    </plugins>
-      <pluginManagement>
-        <plugins>
-          <plugin>
-            <groupId>org.apache.rat</groupId>
-            <artifactId>apache-rat-plugin</artifactId>
-            <configuration>
-              <excludes combine.children="append">
-                <!-- 
-                    The maven archetype are files "without any degree of creativity". They are intended
-                    purely as a template to generate a new project for a user, where upon the user can
-                    write their code within this new project.
-                    The exclusions seem to need to include code that is auto-generated during a test run.
-                -->
-                <exclude>**/src/main/resources/archetype-resources/**/*</exclude>
-                <exclude>**/src/test/resources/projects/integration-test-1/goal.txt</exclude>
-                <exclude>**/src/test/resources/projects/integration-test-1/reference/**/*</exclude>
-                <exclude>**/src/main/java/sample/**/*Sample*.java</exclude>
-                <exclude>**/src/main/resources/logback-custom.xml</exclude>
-                <exclude>**/src/brooklyn-sample/README.md</exclude>
-                <exclude>**/src/brooklyn-sample/pom.xml</exclude>
-                <exclude>**/src/brooklyn-sample/src/main/assembly/files/conf/*</exclude>
-                <exclude>**/src/brooklyn-sample/src/main/java/**/*.java</exclude>
-                <exclude>**/src/brooklyn-sample/src/main/resources/logback-custom.xml</exclude>
-                <exclude>**/src/brooklyn-sample/src/test/java/**/*.java</exclude>
-              </excludes>
-            </configuration>
-          </plugin>
-        </plugins>
-      </pluginManagement>
-
-  </build>
-
-</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/brooklyn-sample/README.md
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/brooklyn-sample/README.md b/usage/archetypes/quickstart/src/brooklyn-sample/README.md
deleted file mode 100644
index b40df41..0000000
--- a/usage/archetypes/quickstart/src/brooklyn-sample/README.md
+++ /dev/null
@@ -1,73 +0,0 @@
-brooklyn-sample
-===
-
-This is a Sample Brooklyn project, showing how to define an application
-which Brooklyn will deploy and manage.
-
-This sample project is intended to be customized to suit your purposes: but
-search for all lines containing the word "sample" to make sure all the
-references to this being a sample are removed!   
-
-To build an assembly, simply run:
-
-    mvn clean assembly:assembly
-
-This creates a tarball with a full standalone application which can be installed in any *nix machine at:
-    target/brooklyn-sample-0.1.0-SNAPSHOT-dist.tar.gz
-
-It also installs an unpacked version which you can run locally:
- 
-     cd target/brooklyn-sample-0.1.0-SNAPSHOT-dist/brooklyn-sample-0.1.0-SNAPSHOT
-     ./start.sh server
- 
-For more information see the README (or `./start.sh help`) in that directory.
-On OS X and Linux, this application will deploy to localhost *if* you have key-based 
-password-less (and passphrase-less) ssh enabled.
-
-To configure cloud and fixed-IP locations, see the README file in the built application directly.
-For more information you can run `./start.sh help`) in that directory.
-
-
-### Opening in an IDE
-
-To open this project in an IDE, you will need maven support enabled
-(e.g. with the relevant plugin).  You should then be able to develop
-it and run it as usual.  For more information on IDE support, visit:
-
-    https://brooklyn.incubator.apache.org/v/latest/dev/env/ide/
-
-
-### Customizing the Assembly
-
-The artifacts (directory and tar.gz by default) which get built into
-`target/` can be changed.  Simply edit the relevant files under
-`src/main/assembly`.
-
-You will likely wish to customize the `SampleMain` class as well as
-the `Sample*App` classes provided.  That is the intention!
-You will also likely want to update the `start.sh` script and
-the `README.*` files.
-
-To easily find the bits you should customize, do a:
-
-    grep -ri sample src/ *.*
-
-
-### More About Apache Brooklyn
-
-Apache Brooklyn is a code library and framework for managing applications in a 
-cloud-first dev-ops-y way.  It has been used to create this sample project 
-which shows how to define an application and entities for Brooklyn.
-
-This project can be extended for more complex topologies and more 
-interesting applications, and to develop the policies to scale or tune the 
-deployment depending on what the application needs.
-
-For more information consider:
-
-* Visiting the Apache Brooklyn home page at https://brooklyn.incubator.apache.org
-* Finding us on IRC #brooklyncentral or email (click "Community" at the site above) 
-* Forking the project at  http://github.com/apache/incubator-brooklyn/
-
-A sample Brooklyn project should specify its license.
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/brooklyn-sample/pom.xml
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/brooklyn-sample/pom.xml b/usage/archetypes/quickstart/src/brooklyn-sample/pom.xml
deleted file mode 100644
index 44f5f93..0000000
--- a/usage/archetypes/quickstart/src/brooklyn-sample/pom.xml
+++ /dev/null
@@ -1,102 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-
-  <modelVersion>4.0.0</modelVersion>
-
-  <parent>
-    <groupId>org.apache.brooklyn</groupId>
-    <artifactId>brooklyn-downstream-parent</artifactId>
-    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-  </parent>
-
-  <groupId>com.acme.sample</groupId>
-  <artifactId>brooklyn-sample</artifactId>
-  <version>0.1.0-SNAPSHOT</version>
-  <packaging>jar</packaging>
-
-  <name>Sample Brooklyn Project com.acme.sample:brooklyn-sample v0.1.0-SNAPSHOT</name>
-  <description>
-    Sample optional description goes here.
-  </description>
-
-  <!-- Optional metadata (commented out in this sample) 
-
-  <url>https://github.com/sample/sample</url>
-
-  <licenses>
-    <license>
-      <name>The Apache Software License, Version 2.0</name>
-      <url>http://www.apache.org/licenses/LICENSE-2.0.txt</url>
-      <distribution>repo</distribution>
-    </license>
-  </licenses>
-
-  <developers>
-    <developer>
-      <name>Sample Project Committers</name>
-    </developer>
-  </developers>
-
-  <scm>
-    <connection>scm:git:git://github.com/sample/sample</connection>
-    <developerConnection>scm:git:git@github.com:sample/sample.git</developerConnection>
-    <url>http://github.com/sample/sample</url>
-  </scm>
-
-  -->
-
-  <properties>
-    <project.entry>com.acme.sample.brooklyn.SampleMain</project.entry>
-  </properties>
-
-  <repositories>
-    <repository>
-      <id>apache.snapshots</id>
-      <name>Apache Snapshot Repository</name>
-      <url>http://repository.apache.org/snapshots</url>
-      <releases>
-        <enabled>false</enabled>
-      </releases>
-    </repository>
-  </repositories>
-
-  <dependencies>
-    <dependency>
-      <!-- this pulls in all brooklyn entities and clouds; 
-           you can cherry pick selected ones instead (for a smaller build) -->
-      <groupId>org.apache.brooklyn</groupId>
-      <artifactId>brooklyn-all</artifactId>
-      <version>${brooklyn.version}</version>
-    </dependency>
-
-    <dependency>
-      <!-- includes testng and useful logging for tests -->
-      <groupId>org.apache.brooklyn</groupId>
-      <artifactId>brooklyn-test-support</artifactId>
-      <version>${brooklyn.version}</version>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <!-- this gives us flexible and easy-to-use logging; just edit logback-custom.xml! -->
-      <groupId>org.apache.brooklyn</groupId>
-      <artifactId>brooklyn-logback-xml</artifactId>
-      <version>${brooklyn.version}</version>
-    </dependency>
-  </dependencies>
-
-  <build>
-    <plugins>
-      <plugin>
-        <artifactId>maven-assembly-plugin</artifactId>
-        <configuration>
-          <descriptors>
-            <descriptor>src/main/assembly/assembly.xml</descriptor>
-          </descriptors>
-        </configuration>
-      </plugin>
-    </plugins>
-  </build>
-
-</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/assembly.xml
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/assembly.xml b/usage/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/assembly.xml
deleted file mode 100644
index 2875a8a..0000000
--- a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/assembly.xml
+++ /dev/null
@@ -1,88 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-    
-     http://www.apache.org/licenses/LICENSE-2.0
-    
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-<assembly>
-    <id>dist</id>
-    <!-- Generates an archive and a dir containing the needed files; 
-         can add e.g. zip to the following
-         (but executable bit is not preserved) -->
-    <formats>
-        <format>dir</format>
-        <format>tar.gz</format>
-    </formats>
-
-    <!-- Adds dependencies to zip package under lib directory -->
-    <dependencySets>
-        <dependencySet>
-            <!--
-               Project artifact is not copied under library directory since
-               it is added to the root directory of the zip package.
-           -->
-            <useProjectArtifact>false</useProjectArtifact>
-            <outputDirectory>lib</outputDirectory>
-            <unpack>false</unpack>
-        </dependencySet>
-    </dependencySets>
-
-    <!--
-       Adds startup scripts to the root directory of zip package. The startup
-       scripts are located to src/main/scripts directory as stated by Maven
-       conventions.
-    -->
-    <files>
-        <file>
-            <source>src/main/assembly/scripts/start.sh</source>
-            <outputDirectory></outputDirectory>
-            <fileMode>0755</fileMode>
-            <filtered>true</filtered>
-        </file>
-    </files>
-    <fileSets>
-        <fileSet>
-            <directory>src/main/assembly/scripts</directory>
-            <outputDirectory></outputDirectory>
-            <fileMode>0755</fileMode>
-            <includes>
-                <include>*</include>
-            </includes>
-            <excludes>
-                <exclude>start.sh</exclude>
-            </excludes>
-        </fileSet>
-        <!--  add additional files (but not marked executable) -->
-        <fileSet>
-            <directory>src/main/assembly/files</directory>
-            <outputDirectory></outputDirectory>
-            <includes>
-                <include>**</include>
-            </includes>
-        </fileSet>
-        <!-- adds jar package to the root directory of zip package -->
-        <fileSet>
-            <directory>target</directory>
-            <outputDirectory></outputDirectory>
-            <includes>
-                <include>*.jar</include>
-            </includes>
-            <excludes>
-                <exclude>*-tests.jar</exclude>
-            </excludes>
-        </fileSet>
-    </fileSets>
-</assembly>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/README.txt
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/README.txt b/usage/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/README.txt
deleted file mode 100644
index 8ba14f1..0000000
--- a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/README.txt
+++ /dev/null
@@ -1,96 +0,0 @@
-brooklyn-sample
-===
-
-This is a sample application which is launched and managed by Brooklyn.
-This README file is at the root of the built assembly, which can be uploaded
-and run most anywhere.  This file provides end-user instructions.
-
-To use this, configure any cloud credentials then run  ./start.sh  in this 
-directory. You can then access the management context in your browser, 
-typically on  http://localhost:8081 , and through that console deploy the
-applications contained in this archive.
-
-
-### Cloud Credentials
-
-To run, you'll need to specify credentials for your preferred cloud.  This 
-can be done in `~/.brooklyn/brooklyn.properties`.
-
-A recommended starting point is the file at:
-
-    https://brooklyn.incubator.apache.org/v/latest/use/guide/quickstart/brooklyn.properties
-
-As a quick-start, you can specify:
-
-    brooklyn.location.jclouds.aws-ec2.identity=AKXXXXXXXXXXXXXXXXXX
-    brooklyn.location.jclouds.aws-ec2.credential=secret01xxxxxxxxxxxxxxxxxxxxxxxxxxx
-    
-    brooklyn.location.named.My_Amazon_US_west=jclouds:aws-ec2:us-west-1
-    brooklyn.location.named.My_Amazon_EU=jclouds:aws-ec2:eu-west-1
-
-Alternatively these can be set as shell environment parameters or JVM system properties.
-
-Many other clouds are supported also, as well as pre-existing machines 
-("bring your own nodes"), custom endpoints for private clouds, and specifying 
-custom keys and passphrases. For more information see:
-
-    https://brooklyn.incubator.apache.org/v/latest/use/guide/defining-applications/common-usage#locations
-
-
-### Run
-
-Usage:
-
-    ./start.sh launch [--WHAT] \
-        [--port 8081+] \
-        [--location location] 
-
-The optional port argument specifies the port where the Brooklyn console 
-will be running, such as localhost:8081. (The console is only bound to 
-localhost, unless you set up users and security, as described at
-https://brooklyn.incubator.apache.org/v/latest/use/guide/management/ .)
-
-In the console, you can access the catalog and deploy applications to
-configured locations.
-
-In this sample application, `--cluster` and `--single` are supported in place of `--WHAT`,
-corresponding to sample blueprints in the project. This can be left blank to have nothing 
-launched; note that the blueprints can be launched at runtime via the GUI or API.
-
-Use `./start.sh help` or `./start.sh help launch` for more detailed help.
-
-The location might be `localhost` (the default), `aws-ec2:us-east-1`, 
-`openstack:endpoint`, `softlayer`, or based on names, such as
-`named:My_Amazon_US_west`, so long as it is configured as above. 
-(Localhost does not need any configuration in `~/brooklyn/brooklyn.properties`, 
-provided you have password-less ssh access enabled to localhost, using a 
-private key with no passphrase.) 
-
-
-### More About Brooklyn
-
-Brooklyn is a code library and framework for managing applications in a 
-cloud-first dev-ops-y way.  It has been used to create this sample project 
-which shows how to define an application and entities for Brooklyn.
-
-This project can be extended for more complex topologies and more 
-interesting applications, and to develop the policies to scale or tune the 
-deployment depending on what the application needs.
-
-For more information consider:
-
-* Visiting the open-source Brooklyn home page at  http://brooklyncentral.github.com
-* Forking the Brooklyn project at  http://github.com/brooklyncentral/brooklyn
-* Emailing  brooklyn-users@googlegroups.com 
-
-For commercial enquiries -- including bespoke development and paid support --
-contact Cloudsoft, the supporters of Brooklyn, at:
-
-* www.CloudsoftCorp.com
-* info@cloudsoftcorp.com
-
-Brooklyn is (c) 2014 Cloudsoft Corporation and released as open source under 
-the Apache License v2.0.
-
-A sample Brooklyn project should specify its license here.
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/conf/logback.xml
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/conf/logback.xml b/usage/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/conf/logback.xml
deleted file mode 100644
index 7b7a972..0000000
--- a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/conf/logback.xml
+++ /dev/null
@@ -1,11 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<configuration>
-
-  <!-- logging configuration for this project; edit this file as required, or override the files 
-       this includes as described in the Logging section of the brooklyn users guide.
-       this project already supplies a logback-custom.xml which gets included to log our
-       classes at debug level and write to a log file named after this project -->
-
-  <include resource="logback-main.xml"/>
-  
-</configuration>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/scripts/start.sh
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/scripts/start.sh b/usage/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/scripts/start.sh
deleted file mode 100755
index 2879b6d..0000000
--- a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/scripts/start.sh
+++ /dev/null
@@ -1,40 +0,0 @@
-#!/bin/bash
-#
-# 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.
-#
-
-if [ ! -z "$JAVA_HOME" ] ; then 
-    JAVA=$JAVA_HOME/bin/java
-else
-    JAVA=`which java`
-fi
-
-if [ ! -x "$JAVA" ] ; then
-  echo Cannot find java. Set JAVA_HOME or add java to path.
-  exit 1
-fi
-
-if [[ ! `ls ${project.artifactId}-*.jar 2> /dev/null` ]] ; then
-  echo Command must be run from the directory where the JAR is installed.
-  exit 4
-fi
-
-$JAVA -Xms256m -Xmx1024m -XX:MaxPermSize=1024m \
-    -classpath "conf/:patch/*:*:lib/*" \
-    ${project.entry} \
-    "$@"

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/SampleMain.java
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/SampleMain.java b/usage/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/SampleMain.java
deleted file mode 100644
index 253f657..0000000
--- a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/SampleMain.java
+++ /dev/null
@@ -1,81 +0,0 @@
-package com.acme.sample.brooklyn;
-
-import java.util.Arrays;
-
-import io.airlift.command.Command;
-import io.airlift.command.Option;
-
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-import org.apache.brooklyn.api.catalog.BrooklynCatalog;
-import org.apache.brooklyn.cli.Main;
-
-import com.google.common.base.Objects.ToStringHelper;
-
-import com.acme.sample.brooklyn.sample.app.*;
-
-/**
- * This class provides a static main entry point for launching a custom Brooklyn-based app.
- * <p>
- * It inherits the standard Brooklyn CLI options from {@link Main},
- * plus adds a few more shortcuts for favourite blueprints to the {@link LaunchCommand}.
- */
-public class SampleMain extends Main {
-    
-    private static final Logger log = LoggerFactory.getLogger(SampleMain.class);
-    
-    public static final String DEFAULT_LOCATION = "localhost";
-
-    public static void main(String... args) {
-        log.debug("CLI invoked with args "+Arrays.asList(args));
-        new SampleMain().execCli(args);
-    }
-
-    @Override
-    protected String cliScriptName() {
-        return "start.sh";
-    }
-    
-    @Override
-    protected Class<? extends BrooklynCommand> cliLaunchCommand() {
-        return LaunchCommand.class;
-    }
-
-    @Command(name = "launch", description = "Starts a server, and optionally an application. "
-        + "Use e.g. --single or --cluster to launch one-node and clustered variants of the sample web application.")
-    public static class LaunchCommand extends Main.LaunchCommand {
-
-        // add these options to the LaunchCommand as shortcuts for our favourite applications
-        
-        @Option(name = { "--single" }, description = "Launch a single web-server instance")
-        public boolean single;
-
-        @Option(name = { "--cluster" }, description = "Launch a web-server cluster")
-        public boolean cluster;
-
-        @Override
-        public Void call() throws Exception {
-            // process our CLI arguments
-            if (single) setAppToLaunch( SingleWebServerSample.class.getCanonicalName() );
-            if (cluster) setAppToLaunch( ClusterWebServerDatabaseSample.class.getCanonicalName() );
-            
-            // now process the standard launch arguments
-            return super.call();
-        }
-
-        @Override
-        protected void populateCatalog(BrooklynCatalog catalog) {
-            super.populateCatalog(catalog);
-            catalog.addItem(SingleWebServerSample.class);
-            catalog.addItem(ClusterWebServerDatabaseSample.class);
-        }
-
-        @Override
-        public ToStringHelper string() {
-            return super.string()
-                    .add("single", single)
-                    .add("cluster", cluster);
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/ClusterWebServerDatabaseSample.java
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/ClusterWebServerDatabaseSample.java b/usage/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/ClusterWebServerDatabaseSample.java
deleted file mode 100644
index 11d977f..0000000
--- a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/ClusterWebServerDatabaseSample.java
+++ /dev/null
@@ -1,137 +0,0 @@
-package com.acme.sample.brooklyn.sample.app;
-
-import java.util.concurrent.TimeUnit;
-
-import org.apache.brooklyn.api.catalog.Catalog;
-import org.apache.brooklyn.api.catalog.CatalogConfig;
-import org.apache.brooklyn.api.entity.EntitySpec;
-import org.apache.brooklyn.api.sensor.AttributeSensor;
-import org.apache.brooklyn.config.ConfigKey;
-import org.apache.brooklyn.core.config.ConfigKeys;
-import org.apache.brooklyn.core.entity.AbstractApplication;
-import org.apache.brooklyn.core.entity.Entities;
-import org.apache.brooklyn.core.location.PortRanges;
-import org.apache.brooklyn.core.sensor.Sensors;
-import org.apache.brooklyn.enricher.stock.SensorPropagatingEnricher;
-import org.apache.brooklyn.enricher.stock.SensorTransformingEnricher;
-import org.apache.brooklyn.entity.database.DatastoreMixins.DatastoreCommon;
-import org.apache.brooklyn.entity.database.mysql.MySqlNode;
-import org.apache.brooklyn.entity.group.DynamicCluster;
-import org.apache.brooklyn.entity.java.JavaEntityMethods;
-import org.apache.brooklyn.entity.webapp.ControlledDynamicWebAppCluster;
-import org.apache.brooklyn.entity.webapp.DynamicWebAppCluster;
-import org.apache.brooklyn.entity.webapp.JavaWebAppService;
-import org.apache.brooklyn.entity.webapp.WebAppService;
-import org.apache.brooklyn.entity.webapp.WebAppServiceConstants;
-import org.apache.brooklyn.policy.autoscaling.AutoScalerPolicy;
-import org.apache.brooklyn.policy.enricher.HttpLatencyDetector;
-import org.apache.brooklyn.util.maven.MavenArtifact;
-import org.apache.brooklyn.util.maven.MavenRetriever;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-import com.google.common.base.Functions;
-
-import static org.apache.brooklyn.core.sensor.DependentConfiguration.attributeWhenReady;
-import static org.apache.brooklyn.core.sensor.DependentConfiguration.formatString;
-
-
-/** This sample builds a 3-tier application with an elastic app-server cluster,
- *  and it sets it up for use in the Brooklyn catalog. 
- *  <p>
- *  Note that root access (and xcode etc) may be required to install nginx.
- **/
-@Catalog(name="Elastic Java Web + DB",
-    description="Deploys a WAR to a load-balanced elastic Java AppServer cluster, " +
-        "with an auto-scaling policy, " +
-        "wired to a database initialized with the provided SQL; " +
-        "defaults to a 'Hello World' chatroom app.",
-    iconUrl="classpath://sample-icon.png")
-public class ClusterWebServerDatabaseSample extends AbstractApplication {
-
-    public static final Logger LOG = LoggerFactory.getLogger(ClusterWebServerDatabaseSample.class);
-
-    // ---------- WAR configuration ---------------
-    
-    public static final String DEFAULT_WAR_URL =
-            // can supply any URL -- this loads a stock example from maven central / sonatype
-            MavenRetriever.localUrl(MavenArtifact.fromCoordinate("io.brooklyn.example:brooklyn-example-hello-world-sql-webapp:war:0.5.0"));
-
-    @CatalogConfig(label="WAR (URL)", priority=2)
-    public static final ConfigKey<String> WAR_URL = ConfigKeys.newConfigKey(
-        "app.war", "URL to the application archive which should be deployed", DEFAULT_WAR_URL);    
-
-    
-    // ---------- DB configuration ----------------
-    
-    // this is included in src/main/resources. if in an IDE, ensure your build path is set appropriately.
-    public static final String DEFAULT_DB_SETUP_SQL_URL = "classpath://visitors-creation-script.sql";
-    
-    @CatalogConfig(label="DB Setup SQL (URL)", priority=1)
-    public static final ConfigKey<String> DB_SETUP_SQL_URL = ConfigKeys.newConfigKey(
-        "app.db_sql", "URL to the SQL script to set up the database", 
-        DEFAULT_DB_SETUP_SQL_URL);
-    
-    public static final String DB_TABLE = "visitors";
-    public static final String DB_USERNAME = "brooklyn";
-    public static final String DB_PASSWORD = "br00k11n";
-    
-
-    // --------- Custom Sensor --------------------
-    
-    AttributeSensor<Integer> APPSERVERS_COUNT = Sensors.newIntegerSensor( 
-            "appservers.count", "Number of app servers deployed");
-
-    
-    // --------- Initialization -------------------
-    
-    /** Initialize our application. In this case it consists of 
-     *  a single DB, with a load-balanced cluster (nginx + multiple JBosses, by default),
-     *  with some sensors and a policy. */
-    @Override
-    public void init() {
-        DatastoreCommon db = addChild(
-                EntitySpec.create(MySqlNode.class)
-                        .configure(MySqlNode.CREATION_SCRIPT_URL, Entities.getRequiredUrlConfig(this, DB_SETUP_SQL_URL)));
-
-        ControlledDynamicWebAppCluster web = addChild(
-                EntitySpec.create(ControlledDynamicWebAppCluster.class)
-                        // set WAR to use, and port to use
-                        .configure(JavaWebAppService.ROOT_WAR, getConfig(WAR_URL))
-                        .configure(WebAppService.HTTP_PORT, PortRanges.fromString("8080+"))
-                        
-//                        // optionally - use Tomcat instead of JBoss (default:
-//                        .configure(ControlledDynamicWebAppCluster.MEMBER_SPEC, EntitySpec.create(TomcatServer.class))
-                        
-                        // inject a JVM system property to point to the DB
-                        .configure(JavaEntityMethods.javaSysProp("brooklyn.example.db.url"), 
-                                formatString("jdbc:%s%s?user=%s\\&password=%s", 
-                                        attributeWhenReady(db, DatastoreCommon.DATASTORE_URL), DB_TABLE, DB_USERNAME, DB_PASSWORD))
-                    
-                        // start with 2 appserver nodes, initially
-                        .configure(DynamicCluster.INITIAL_SIZE, 2) 
-                    );
-
-        // add an enricher which measures latency
-        web.addEnricher(HttpLatencyDetector.builder().
-                url(WebAppServiceConstants.ROOT_URL).
-                rollup(10, TimeUnit.SECONDS).
-                build());
-
-        // add a policy which scales out based on Reqs/Sec
-        web.getCluster().addPolicy(AutoScalerPolicy.builder().
-                metric(DynamicWebAppCluster.REQUESTS_PER_SECOND_IN_WINDOW_PER_NODE).
-                metricRange(10, 100).
-                sizeRange(2, 5).
-                build());
-
-        // add a few more sensors at the top-level (KPI's at the root of the application)
-        addEnricher(SensorPropagatingEnricher.newInstanceListeningTo(web,  
-                WebAppServiceConstants.ROOT_URL,
-                DynamicWebAppCluster.REQUESTS_PER_SECOND_IN_WINDOW,
-                HttpLatencyDetector.REQUEST_LATENCY_IN_SECONDS_IN_WINDOW));
-        addEnricher(SensorTransformingEnricher.newInstanceTransforming(web, 
-                DynamicWebAppCluster.GROUP_SIZE, Functions.<Integer>identity(), APPSERVERS_COUNT));
-    }
-    
-}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/SingleWebServerSample.java
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/SingleWebServerSample.java b/usage/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/SingleWebServerSample.java
deleted file mode 100644
index 3cc9426..0000000
--- a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/SingleWebServerSample.java
+++ /dev/null
@@ -1,32 +0,0 @@
-package com.acme.sample.brooklyn.sample.app;
-
-import org.apache.brooklyn.api.entity.EntitySpec;
-import org.apache.brooklyn.core.entity.AbstractApplication;
-import org.apache.brooklyn.core.entity.Attributes;
-import org.apache.brooklyn.core.location.PortRanges;
-import org.apache.brooklyn.entity.webapp.JavaWebAppService;
-import org.apache.brooklyn.entity.webapp.jboss.JBoss7Server;
-import org.apache.brooklyn.util.maven.MavenArtifact;
-import org.apache.brooklyn.util.maven.MavenRetriever;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/** This example starts one web app on 8080. */
-public class SingleWebServerSample extends AbstractApplication {
-
-    public static final Logger LOG = LoggerFactory.getLogger(SingleWebServerSample.class);
-
-    public static final String DEFAULT_WAR_URL =
-            // can supply any URL -- this loads a stock example from maven central / sonatype
-            MavenRetriever.localUrl(MavenArtifact.fromCoordinate("io.brooklyn.example:brooklyn-example-hello-world-sql-webapp:war:0.5.0"));
-
-    /** Initialize our application. In this case it consists of 
-     *  a single JBoss entity, configured to run the WAR above. */
-    @Override
-    public void init() {
-        addChild(EntitySpec.create(JBoss7Server.class)
-                .configure(JavaWebAppService.ROOT_WAR, DEFAULT_WAR_URL)
-                .configure(Attributes.HTTP_PORT, PortRanges.fromString("8080+")));
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/brooklyn-sample/src/main/resources/logback-custom.xml
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/resources/logback-custom.xml b/usage/archetypes/quickstart/src/brooklyn-sample/src/main/resources/logback-custom.xml
deleted file mode 100644
index 5a1ec98..0000000
--- a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/resources/logback-custom.xml
+++ /dev/null
@@ -1,10 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<included>
-
-    <!-- include everything in this project at debug level -->
-    <logger name="com.acme.sample.brooklyn" level="DEBUG"/>    
-    
-    <!-- logfile named after this project -->
-    <property name="logging.basename" scope="context" value="brooklyn-sample" />
-
-</included>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/brooklyn-sample/src/main/resources/sample-icon.png
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/resources/sample-icon.png b/usage/archetypes/quickstart/src/brooklyn-sample/src/main/resources/sample-icon.png
deleted file mode 100644
index 542a1de..0000000
Binary files a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/resources/sample-icon.png and /dev/null differ

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/brooklyn-sample/src/main/resources/visitors-creation-script.sql
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/resources/visitors-creation-script.sql b/usage/archetypes/quickstart/src/brooklyn-sample/src/main/resources/visitors-creation-script.sql
deleted file mode 100644
index 0a805c4..0000000
--- a/usage/archetypes/quickstart/src/brooklyn-sample/src/main/resources/visitors-creation-script.sql
+++ /dev/null
@@ -1,35 +0,0 @@
---
--- Licensed to the Apache Software Foundation (ASF) under one
--- or more contributor license agreements.  See the NOTICE file
--- distributed with this work for additional information
--- regarding copyright ownership.  The ASF licenses this file
--- to you under the Apache License, Version 2.0 (the
--- "License"); you may not use this file except in compliance
--- with the License.  You may obtain a copy of the License at
---
---  http://www.apache.org/licenses/LICENSE-2.0
---
--- Unless required by applicable law or agreed to in writing,
--- software distributed under the License is distributed on an
--- "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
--- KIND, either express or implied.  See the License for the
--- specific language governing permissions and limitations
--- under the License.
---
-create database visitors;
-use visitors;
-create user 'brooklyn' identified by 'br00k11n';
-grant usage on *.* to 'brooklyn'@'%' identified by 'br00k11n';
-# ''@localhost is sometimes set up, overriding brooklyn@'%', so do a second explicit grant
-grant usage on *.* to 'brooklyn'@'localhost' identified by 'br00k11n';
-grant all privileges on visitors.* to 'brooklyn'@'%';
-flush privileges;
-
-CREATE TABLE MESSAGES (
-        id INT NOT NULL AUTO_INCREMENT,
-        NAME VARCHAR(30) NOT NULL,
-        MESSAGE VARCHAR(400) NOT NULL,
-        PRIMARY KEY (ID)
-    );
-
-INSERT INTO MESSAGES values (default, 'Isaac Asimov', 'I grew up in Brooklyn' );

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleLocalhostIntegrationTest.java
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleLocalhostIntegrationTest.java b/usage/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleLocalhostIntegrationTest.java
deleted file mode 100644
index f640f6a..0000000
--- a/usage/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleLocalhostIntegrationTest.java
+++ /dev/null
@@ -1,81 +0,0 @@
-package com.acme.sample.brooklyn.sample.app;
-
-import java.util.Arrays;
-import java.util.Iterator;
-
-import org.apache.brooklyn.api.entity.Entity;
-import org.apache.brooklyn.api.entity.EntitySpec;
-import org.apache.brooklyn.api.mgmt.ManagementContext;
-import org.apache.brooklyn.core.mgmt.internal.LocalManagementContext;
-import org.apache.brooklyn.core.entity.Entities;
-import org.apache.brooklyn.core.entity.StartableApplication;
-import org.apache.brooklyn.entity.webapp.JavaWebAppService;
-import org.apache.brooklyn.util.core.ResourceUtils;
-import org.apache.brooklyn.util.text.Strings;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-import org.testng.Assert;
-import org.testng.annotations.AfterMethod;
-import org.testng.annotations.BeforeMethod;
-import org.testng.annotations.Test;
-
-/**
- * Sample integration tests which show how to launch the sample applications on localhost,
- * make some assertions about them, and then destroy them.
- */
-@Test(groups="Integration")
-public class SampleLocalhostIntegrationTest {
-
-    private static final Logger log = LoggerFactory.getLogger(SampleLocalhostIntegrationTest.class);
-    
-    private ManagementContext mgmt;
-
-    @BeforeMethod(alwaysRun=true)
-    public void setup() {
-        mgmt = new LocalManagementContext();
-    }
-
-    @AfterMethod(alwaysRun=true)
-    public void shutdown() {
-        if (mgmt != null) Entities.destroyAll(mgmt);
-    }
-
-
-    public void testSingle() {
-        StartableApplication app = mgmt.getEntityManager().createEntity(
-                EntitySpec.create(StartableApplication.class, SingleWebServerSample.class));
-        Entities.startManagement(app, mgmt);
-        Entities.start(app, Arrays.asList(mgmt.getLocationRegistry().resolve("localhost")));
-        
-        Iterator<Entity> children = app.getChildren().iterator();
-        if (!children.hasNext()) Assert.fail("Should have had a single JBoss child; had none");
-        
-        Entity web = children.next();
-        
-        if (children.hasNext()) Assert.fail("Should have had a single JBoss child; had too many: "+app.getChildren());
-        
-        String url = web.getAttribute(JavaWebAppService.ROOT_URL);
-        Assert.assertNotNull(url);
-        
-        String page = new ResourceUtils(this).getResourceAsString(url);
-        log.info("Read web page for "+app+" from "+url+":\n"+page);
-        Assert.assertTrue(!Strings.isBlank(page));
-    }
-
-    public void testCluster() {
-        StartableApplication app = mgmt.getEntityManager().createEntity(
-                EntitySpec.create(StartableApplication.class, ClusterWebServerDatabaseSample.class));
-        Entities.startManagement(app, mgmt);
-        Entities.start(app, Arrays.asList(mgmt.getLocationRegistry().resolve("localhost")));
-        
-        log.debug("APP is started");
-        
-        String url = app.getAttribute(JavaWebAppService.ROOT_URL);
-        Assert.assertNotNull(url);
-
-        String page = new ResourceUtils(this).getResourceAsString(url);
-        log.info("Read web page for "+app+" from "+url+":\n"+page);
-        Assert.assertTrue(!Strings.isBlank(page));
-    }
-    
-}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleUnitTest.java
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleUnitTest.java b/usage/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleUnitTest.java
deleted file mode 100644
index 6a34301..0000000
--- a/usage/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleUnitTest.java
+++ /dev/null
@@ -1,69 +0,0 @@
-package com.acme.sample.brooklyn.sample.app;
-
-import org.apache.brooklyn.api.entity.Entity;
-import org.apache.brooklyn.api.entity.EntitySpec;
-import org.apache.brooklyn.api.mgmt.ManagementContext;
-import org.apache.brooklyn.core.mgmt.internal.LocalManagementContext;
-import org.apache.brooklyn.core.entity.Entities;
-import org.apache.brooklyn.core.entity.StartableApplication;
-import org.apache.brooklyn.entity.database.DatastoreMixins.DatastoreCommon;
-import org.apache.brooklyn.entity.database.mysql.MySqlNode;
-import org.apache.brooklyn.entity.webapp.JavaWebAppService;
-import org.apache.brooklyn.entity.webapp.WebAppService;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-import org.testng.Assert;
-import org.testng.annotations.AfterMethod;
-import org.testng.annotations.BeforeMethod;
-import org.testng.annotations.Test;
-
-import com.google.common.base.Predicates;
-import com.google.common.collect.Iterables;
-
-/** 
- * Unit tests for the sample applications defined in this project.
- * Shows how to examine the spec and make assertions about configuration.
- */
-@Test
-public class SampleUnitTest {
-
-    private static final Logger log = LoggerFactory.getLogger(SampleUnitTest.class);
-
-    
-    private ManagementContext mgmt;
-
-    @BeforeMethod(alwaysRun=true)
-    public void setup() {
-        mgmt = new LocalManagementContext();
-    }
-
-    @AfterMethod(alwaysRun=true)
-    public void shutdown() {
-        if (mgmt != null) Entities.destroyAll(mgmt);
-    }
-
-    
-    public void testSampleSingleStructure() {
-        StartableApplication app = mgmt.getEntityManager().createEntity(
-                EntitySpec.create(StartableApplication.class, SingleWebServerSample.class));
-        log.info("app from spec is: "+app);
-        
-        Assert.assertEquals(app.getChildren().size(), 1);
-        Assert.assertNotNull( app.getChildren().iterator().next().getConfig(JavaWebAppService.ROOT_WAR) );
-    }
-    
-    public void testSampleClusterStructure() {
-        StartableApplication app = mgmt.getEntityManager().createEntity(
-                EntitySpec.create(StartableApplication.class, ClusterWebServerDatabaseSample.class));
-        log.info("app from spec is: "+app);
-        
-        Assert.assertEquals(app.getChildren().size(), 2);
-        
-        Entity webappCluster = Iterables.find(app.getChildren(), Predicates.instanceOf(WebAppService.class));
-        Entity database = Iterables.find(app.getChildren(), Predicates.instanceOf(DatastoreCommon.class));
-        
-        Assert.assertNotNull( webappCluster.getConfig(JavaWebAppService.ROOT_WAR) );
-        Assert.assertNotNull( database.getConfig(MySqlNode.CREATION_SCRIPT_URL) );
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/archetypes/quickstart/src/main/resources/.gitignore
----------------------------------------------------------------------
diff --git a/usage/archetypes/quickstart/src/main/resources/.gitignore b/usage/archetypes/quickstart/src/main/resources/.gitignore
deleted file mode 100644
index 6d7b6a3..0000000
--- a/usage/archetypes/quickstart/src/main/resources/.gitignore
+++ /dev/null
@@ -1 +0,0 @@
-archetype-resources


[39/51] [abbrv] brooklyn-dist git commit: update LICENSE files throughout

Posted by he...@apache.org.
update LICENSE files throughout


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

Branch: refs/heads/master
Commit: e8c23d3370e6e96541694527c09feb71e6830b81
Parents: 92947c9
Author: Alex Heneveld <al...@cloudsoftcorp.com>
Authored: Sat Jan 30 03:33:08 2016 +0000
Committer: Alex Heneveld <al...@cloudsoftcorp.com>
Committed: Sat Jan 30 03:33:08 2016 +0000

----------------------------------------------------------------------
 LICENSE                                         | 18 ++++--------
 brooklyn-dist/LICENSE                           | 20 ++++++-------
 .../dist/src/main/license/files/LICENSE         | 30 +++++++++-----------
 3 files changed, 29 insertions(+), 39 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/e8c23d33/LICENSE
----------------------------------------------------------------------
diff --git a/LICENSE b/LICENSE
index 6d18497..3d8f4e7 100644
--- a/LICENSE
+++ b/LICENSE
@@ -250,13 +250,6 @@ This project includes the software: DataTables Table plug-in for jQuery
   Used under the following license: The BSD 3-Clause (New BSD) License (http://opensource.org/licenses/BSD-3-Clause)
   Copyright (c) Allan Jardine (2008-2012)
 
-This project includes the software: glossarizer
-  Available at: https://github.com/PebbleRoad/glossarizer
-  Developed by: Vinay M, PebbleRoad Pte Ltd (http://www.pebbleroad.com)
-  Version used: 1.5
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Vinay M, PebbleRoad Pte Ltd (2004-2016)
-
 This project includes the software: jQuery Form Plugin
   Available at: https://github.com/malsup/form
   Developed by: Mike Alsup (http://malsup.com/)
@@ -337,11 +330,12 @@ This project includes the software: RequireJS (r.js maven plugin)
       Arpad Borsos (2012)
     Used under the BSD 2-Clause license.
 
-This project includes the software: swagger
-  Used under the following license: <no license info>
-
-This project includes the software: swagger-ui
-  Used under the following license: <no license info>
+This project includes the software: Swagger UI
+  Available at: https://github.com/swagger-api/swagger-ui
+  Inclusive of: swagger*.{js,css,html}
+  Version used: 2.1.4
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+  Copyright (c) SmartBear Software (2011-2015)
 
 This project includes the software: typeahead.js
   Available at: https://github.com/twitter/typeahead.js

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/e8c23d33/brooklyn-dist/LICENSE
----------------------------------------------------------------------
diff --git a/brooklyn-dist/LICENSE b/brooklyn-dist/LICENSE
index ca60394..3d8f4e7 100644
--- a/brooklyn-dist/LICENSE
+++ b/brooklyn-dist/LICENSE
@@ -282,6 +282,13 @@ This project includes the software: js-yaml.js
   Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
   Copyright (c) Vitaly Puzrin (2011-2015)
 
+This project includes the software: marked.js
+  Available at: https://github.com/chjj/marked
+  Developed by: Christopher Jeffrey (https://github.com/chjj)
+  Version used: 0.3.1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Christopher Jeffrey (2011-2014)
+
 This project includes the software: moment.js
   Available at: http://momentjs.com
   Developed by: Tim Wood (http://momentjs.com)
@@ -323,17 +330,10 @@ This project includes the software: RequireJS (r.js maven plugin)
       Arpad Borsos (2012)
     Used under the BSD 2-Clause license.
 
-This project includes the software: Swagger JS
-  Available at: https://github.com/wordnik/swagger-js
-  Inclusive of: swagger.js
-  Version used: 1.0.1
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-  Copyright (c) SmartBear Software (2011-2015)
-
 This project includes the software: Swagger UI
-  Available at: https://github.com/wordnik/swagger-ui
-  Inclusive of: swagger-ui.js
-  Version used: 1.0.1
+  Available at: https://github.com/swagger-api/swagger-ui
+  Inclusive of: swagger*.{js,css,html}
+  Version used: 2.1.4
   Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
   Copyright (c) SmartBear Software (2011-2015)
 

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/e8c23d33/brooklyn-dist/dist/src/main/license/files/LICENSE
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/license/files/LICENSE b/brooklyn-dist/dist/src/main/license/files/LICENSE
index 39db9db..dd42819 100644
--- a/brooklyn-dist/dist/src/main/license/files/LICENSE
+++ b/brooklyn-dist/dist/src/main/license/files/LICENSE
@@ -413,7 +413,7 @@ This project includes the software: io.airlift
 
 This project includes the software: io.cloudsoft.windows
   Available at: http://github.com/cloudsoft/winrm4j
-  Version used: 0.1.0
+  Version used: 0.2.0
   Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
 
 This project includes the software: io.swagger
@@ -576,37 +576,37 @@ This project includes the software: org.apache.httpcomponents
 This project includes the software: org.apache.jclouds
   Available at: http://jclouds.apache.org/
   Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.1
+  Version used: 1.9.2
   Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
 
 This project includes the software: org.apache.jclouds.api
   Available at: http://jclouds.apache.org/
   Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.1
+  Version used: 1.9.2
   Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
 
 This project includes the software: org.apache.jclouds.common
   Available at: http://jclouds.apache.org/
   Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.1
+  Version used: 1.9.2
   Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
 
 This project includes the software: org.apache.jclouds.driver
   Available at: http://jclouds.apache.org/
   Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.1
+  Version used: 1.9.2
   Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
 
 This project includes the software: org.apache.jclouds.labs
   Available at: http://jclouds.apache.org/
   Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.1
+  Version used: 1.9.2
   Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
 
 This project includes the software: org.apache.jclouds.provider
   Available at: http://jclouds.apache.org/
   Developed by: The Apache Software Foundation (http://www.apache.org/)
-  Version used: 1.9.1
+  Version used: 1.9.2
   Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
 
 This project includes the software: org.bouncycastle
@@ -678,11 +678,6 @@ This project includes the software: org.mongodb
   Version used: 3.0.3
   Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
 
-This project includes the software: org.python
-  Available at: http://www.jython.org/
-  Version used: 2.7-b3
-  Used under the following license: Jython Software License (http://www.jython.org/license.html)
-
 This project includes the software: org.reflections
   Available at: http://code.google.com/p/reflections/
   Version used: 0.9.9-RC1
@@ -738,11 +733,12 @@ This project includes the software: RequireJS (r.js maven plugin)
       Arpad Borsos (2012)
     Used under the BSD 2-Clause license.
 
-This project includes the software: swagger
-  Used under the following license: <no license info>
-
-This project includes the software: swagger-ui
-  Used under the following license: <no license info>
+This project includes the software: Swagger UI
+  Available at: https://github.com/swagger-api/swagger-ui
+  Inclusive of: swagger*.{js,css,html}
+  Version used: 2.1.4
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+  Copyright (c) SmartBear Software (2011-2015)
 
 This project includes the software: typeahead.js
   Available at: https://github.com/twitter/typeahead.js


[50/51] [abbrv] brooklyn-dist git commit: move subdir from incubator up a level as it is promoted to its own repo (first non-incubator commit!)

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/LICENSE
----------------------------------------------------------------------
diff --git a/brooklyn-dist/LICENSE b/brooklyn-dist/LICENSE
deleted file mode 100644
index 3d8f4e7..0000000
--- a/brooklyn-dist/LICENSE
+++ /dev/null
@@ -1,455 +0,0 @@
-
-This software is distributed under the Apache License, version 2.0. See (1) below.
-This software is copyright (c) The Apache Software Foundation and contributors.
-
-Contents:
-
-  (1) This software license: Apache License, version 2.0
-  (2) Notices for bundled software
-  (3) Licenses for bundled software
-
-
----------------------------------------------------
-
-(1) This software license: Apache License, version 2.0
-
-
-                                 Apache License
-                           Version 2.0, January 2004
-                        http://www.apache.org/licenses/
-
-   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
-
-   1. Definitions.
-
-      "License" shall mean the terms and conditions for use, reproduction,
-      and distribution as defined by Sections 1 through 9 of this document.
-
-      "Licensor" shall mean the copyright owner or entity authorized by
-      the copyright owner that is granting the License.
-
-      "Legal Entity" shall mean the union of the acting entity and all
-      other entities that control, are controlled by, or are under common
-      control with that entity. For the purposes of this definition,
-      "control" means (i) the power, direct or indirect, to cause the
-      direction or management of such entity, whether by contract or
-      otherwise, or (ii) ownership of fifty percent (50%) or more of the
-      outstanding shares, or (iii) beneficial ownership of such entity.
-
-      "You" (or "Your") shall mean an individual or Legal Entity
-      exercising permissions granted by this License.
-
-      "Source" form shall mean the preferred form for making modifications,
-      including but not limited to software source code, documentation
-      source, and configuration files.
-
-      "Object" form shall mean any form resulting from mechanical
-      transformation or translation of a Source form, including but
-      not limited to compiled object code, generated documentation,
-      and conversions to other media types.
-
-      "Work" shall mean the work of authorship, whether in Source or
-      Object form, made available under the License, as indicated by a
-      copyright notice that is included in or attached to the work
-      (an example is provided in the Appendix below).
-
-      "Derivative Works" shall mean any work, whether in Source or Object
-      form, that is based on (or derived from) the Work and for which the
-      editorial revisions, annotations, elaborations, or other modifications
-      represent, as a whole, an original work of authorship. For the purposes
-      of this License, Derivative Works shall not include works that remain
-      separable from, or merely link (or bind by name) to the interfaces of,
-      the Work and Derivative Works thereof.
-
-      "Contribution" shall mean any work of authorship, including
-      the original version of the Work and any modifications or additions
-      to that Work or Derivative Works thereof, that is intentionally
-      submitted to Licensor for inclusion in the Work by the copyright owner
-      or by an individual or Legal Entity authorized to submit on behalf of
-      the copyright owner. For the purposes of this definition, "submitted"
-      means any form of electronic, verbal, or written communication sent
-      to the Licensor or its representatives, including but not limited to
-      communication on electronic mailing lists, source code control systems,
-      and issue tracking systems that are managed by, or on behalf of, the
-      Licensor for the purpose of discussing and improving the Work, but
-      excluding communication that is conspicuously marked or otherwise
-      designated in writing by the copyright owner as "Not a Contribution."
-
-      "Contributor" shall mean Licensor and any individual or Legal Entity
-      on behalf of whom a Contribution has been received by Licensor and
-      subsequently incorporated within the Work.
-
-   2. Grant of Copyright License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      copyright license to reproduce, prepare Derivative Works of,
-      publicly display, publicly perform, sublicense, and distribute the
-      Work and such Derivative Works in Source or Object form.
-
-   3. Grant of Patent License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      (except as stated in this section) patent license to make, have made,
-      use, offer to sell, sell, import, and otherwise transfer the Work,
-      where such license applies only to those patent claims licensable
-      by such Contributor that are necessarily infringed by their
-      Contribution(s) alone or by combination of their Contribution(s)
-      with the Work to which such Contribution(s) was submitted. If You
-      institute patent litigation against any entity (including a
-      cross-claim or counterclaim in a lawsuit) alleging that the Work
-      or a Contribution incorporated within the Work constitutes direct
-      or contributory patent infringement, then any patent licenses
-      granted to You under this License for that Work shall terminate
-      as of the date such litigation is filed.
-
-   4. Redistribution. You may reproduce and distribute copies of the
-      Work or Derivative Works thereof in any medium, with or without
-      modifications, and in Source or Object form, provided that You
-      meet the following conditions:
-
-      (a) You must give any other recipients of the Work or
-          Derivative Works a copy of this License; and
-
-      (b) You must cause any modified files to carry prominent notices
-          stating that You changed the files; and
-
-      (c) You must retain, in the Source form of any Derivative Works
-          that You distribute, all copyright, patent, trademark, and
-          attribution notices from the Source form of the Work,
-          excluding those notices that do not pertain to any part of
-          the Derivative Works; and
-
-      (d) If the Work includes a "NOTICE" text file as part of its
-          distribution, then any Derivative Works that You distribute must
-          include a readable copy of the attribution notices contained
-          within such NOTICE file, excluding those notices that do not
-          pertain to any part of the Derivative Works, in at least one
-          of the following places: within a NOTICE text file distributed
-          as part of the Derivative Works; within the Source form or
-          documentation, if provided along with the Derivative Works; or,
-          within a display generated by the Derivative Works, if and
-          wherever such third-party notices normally appear. The contents
-          of the NOTICE file are for informational purposes only and
-          do not modify the License. You may add Your own attribution
-          notices within Derivative Works that You distribute, alongside
-          or as an addendum to the NOTICE text from the Work, provided
-          that such additional attribution notices cannot be construed
-          as modifying the License.
-
-      You may add Your own copyright statement to Your modifications and
-      may provide additional or different license terms and conditions
-      for use, reproduction, or distribution of Your modifications, or
-      for any such Derivative Works as a whole, provided Your use,
-      reproduction, and distribution of the Work otherwise complies with
-      the conditions stated in this License.
-
-   5. Submission of Contributions. Unless You explicitly state otherwise,
-      any Contribution intentionally submitted for inclusion in the Work
-      by You to the Licensor shall be under the terms and conditions of
-      this License, without any additional terms or conditions.
-      Notwithstanding the above, nothing herein shall supersede or modify
-      the terms of any separate license agreement you may have executed
-      with Licensor regarding such Contributions.
-
-   6. Trademarks. This License does not grant permission to use the trade
-      names, trademarks, service marks, or product names of the Licensor,
-      except as required for reasonable and customary use in describing the
-      origin of the Work and reproducing the content of the NOTICE file.
-
-   7. Disclaimer of Warranty. Unless required by applicable law or
-      agreed to in writing, Licensor provides the Work (and each
-      Contributor provides its Contributions) on an "AS IS" BASIS,
-      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-      implied, including, without limitation, any warranties or conditions
-      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-      PARTICULAR PURPOSE. You are solely responsible for determining the
-      appropriateness of using or redistributing the Work and assume any
-      risks associated with Your exercise of permissions under this License.
-
-   8. Limitation of Liability. In no event and under no legal theory,
-      whether in tort (including negligence), contract, or otherwise,
-      unless required by applicable law (such as deliberate and grossly
-      negligent acts) or agreed to in writing, shall any Contributor be
-      liable to You for damages, including any direct, indirect, special,
-      incidental, or consequential damages of any character arising as a
-      result of this License or out of the use or inability to use the
-      Work (including but not limited to damages for loss of goodwill,
-      work stoppage, computer failure or malfunction, or any and all
-      other commercial damages or losses), even if such Contributor
-      has been advised of the possibility of such damages.
-
-   9. Accepting Warranty or Additional Liability. While redistributing
-      the Work or Derivative Works thereof, You may choose to offer,
-      and charge a fee for, acceptance of support, warranty, indemnity,
-      or other liability obligations and/or rights consistent with this
-      License. However, in accepting such obligations, You may act only
-      on Your own behalf and on Your sole responsibility, not on behalf
-      of any other Contributor, and only if You agree to indemnify,
-      defend, and hold each Contributor harmless for any liability
-      incurred by, or claims asserted against, such Contributor by reason
-      of your accepting any such warranty or additional liability.
-
-
----------------------------------------------------
-
-(2) Notices for bundled software
-
-This project includes the software: async.js
-  Available at: https://github.com/p15martin/google-maps-hello-world/blob/master/js/libs/async.js
-  Developed by: Miller Medeiros (https://github.com/millermedeiros/)
-  Version used: 0.1.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Miller Medeiros (2011)
-
-This project includes the software: backbone.js
-  Available at: http://backbonejs.org
-  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
-  Version used: 1.0.0
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2010-2013)
-
-This project includes the software: bootstrap.js
-  Available at: http://twitter.github.com/bootstrap/javascript.html#transitions
-  Version used: 2.0.4
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-  Copyright (c) Twitter, Inc. (2012)
-
-This project includes the software: handlebars.js
-  Available at: https://github.com/wycats/handlebars.js
-  Developed by: Yehuda Katz (https://github.com/wycats/)
-  Inclusive of: handlebars*.js
-  Version used: 1.0-rc1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Yehuda Katz (2012)
-
-This project includes the software: jQuery JavaScript Library
-  Available at: http://jquery.com/
-  Developed by: The jQuery Foundation (http://jquery.org/)
-  Inclusive of: jquery.js
-  Version used: 1.7.2
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) John Resig (2005-2011)
-  Includes code fragments from sizzle.js:
-    Copyright (c) The Dojo Foundation
-    Available at http://sizzlejs.com
-    Used under the MIT license
-
-This project includes the software: jQuery BBQ: Back Button & Query Library
-  Available at: http://benalman.com/projects/jquery-bbq-plugin/
-  Developed by: "Cowboy" Ben Alman (http://benalman.com/)
-  Inclusive of: jquery.ba-bbq*.js
-  Version used: 1.2.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) "Cowboy" Ben Alman (2010)"
-
-This project includes the software: DataTables Table plug-in for jQuery
-  Available at: http://www.datatables.net/
-  Developed by: SpryMedia Ltd (http://sprymedia.co.uk/)
-  Inclusive of: jquery.dataTables.{js,css}
-  Version used: 1.9.4
-  Used under the following license: The BSD 3-Clause (New BSD) License (http://opensource.org/licenses/BSD-3-Clause)
-  Copyright (c) Allan Jardine (2008-2012)
-
-This project includes the software: jQuery Form Plugin
-  Available at: https://github.com/malsup/form
-  Developed by: Mike Alsup (http://malsup.com/)
-  Inclusive of: jquery.form.js
-  Version used: 3.09
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) M. Alsup (2006-2013)
-
-This project includes the software: jQuery Wiggle
-  Available at: https://github.com/jordanthomas/jquery-wiggle
-  Inclusive of: jquery.wiggle.min.js
-  Version used: swagger-ui:1.0.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) WonderGroup and Jordan Thomas (2010)
-  Previously online at http://labs.wondergroup.com/demos/mini-ui/index.html.
-  The version included here is from the Swagger UI distribution.
-
-This project includes the software: js-uri
-  Available at: http://code.google.com/p/js-uri/
-  Developed by: js-uri contributors (https://code.google.com/js-uri)
-  Inclusive of: URI.js
-  Version used: 0.1
-  Used under the following license: The BSD 3-Clause (New BSD) License (http://opensource.org/licenses/BSD-3-Clause)
-  Copyright (c) js-uri contributors (2013)
-
-This project includes the software: js-yaml.js
-  Available at: https://github.com/nodeca/
-  Developed by: Vitaly Puzrin (https://github.com/nodeca/)
-  Version used: 3.2.7
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Vitaly Puzrin (2011-2015)
-
-This project includes the software: marked.js
-  Available at: https://github.com/chjj/marked
-  Developed by: Christopher Jeffrey (https://github.com/chjj)
-  Version used: 0.3.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Christopher Jeffrey (2011-2014)
-
-This project includes the software: moment.js
-  Available at: http://momentjs.com
-  Developed by: Tim Wood (http://momentjs.com)
-  Version used: 2.1.0
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Tim Wood, Iskren Chernev, Moment.js contributors (2011-2014)
-
-This project includes the software: RequireJS
-  Available at: http://requirejs.org/
-  Developed by: The Dojo Foundation (http://dojofoundation.org/)
-  Inclusive of: require.js, text.js
-  Version used: 2.0.6
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) The Dojo Foundation (2010-2012)
-
-This project includes the software: RequireJS (r.js maven plugin)
-  Available at: http://github.com/jrburke/requirejs
-  Developed by: The Dojo Foundation (http://dojofoundation.org/)
-  Inclusive of: r.js
-  Version used: 2.1.6
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) The Dojo Foundation (2009-2013)
-  Includes code fragments for source-map and other functionality:
-    Copyright (c) The Mozilla Foundation and contributors (2011)
-    Used under the BSD 2-Clause license.
-  Includes code fragments for parse-js and other functionality:
-    Copyright (c) Mihai Bazon (2010, 2012)
-    Used under the BSD 2-Clause license.
-  Includes code fragments for uglifyjs/consolidator:
-    Copyright (c) Robert Gust-Bardon (2012)
-    Used under the BSD 2-Clause license.
-  Includes code fragments for the esprima parser:
-    Copyright (c):
-      Ariya Hidayat (2011, 2012)
-      Mathias Bynens (2012)
-      Joost-Wim Boekesteijn (2012)
-      Kris Kowal (2012)
-      Yusuke Suzuki (2012)
-      Arpad Borsos (2012)
-    Used under the BSD 2-Clause license.
-
-This project includes the software: Swagger UI
-  Available at: https://github.com/swagger-api/swagger-ui
-  Inclusive of: swagger*.{js,css,html}
-  Version used: 2.1.4
-  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
-  Copyright (c) SmartBear Software (2011-2015)
-
-This project includes the software: typeahead.js
-  Available at: https://github.com/twitter/typeahead.js
-  Developed by: Twitter, Inc (http://twitter.com)
-  Version used: 0.10.5
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Twitter, Inc. and other contributors (2013-2014)
-
-This project includes the software: underscore.js
-  Available at: http://underscorejs.org
-  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
-  Inclusive of: underscore*.{js,map}
-  Version used: 1.4.4
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2009-2013)
-
-This project includes the software: underscore.js:1.7.0
-  Available at: http://underscorejs.org
-  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
-  Inclusive of: underscore*.{js,map}
-  Version used: 1.7.0
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Jeremy Ashkenas, DocumentCloud and Investigative Reporters & Editors (2009-2014)
-
-This project includes the software: ZeroClipboard
-  Available at: http://zeroclipboard.org/
-  Developed by: ZeroClipboard contributors (https://github.com/zeroclipboard)
-  Inclusive of: ZeroClipboard.*
-  Version used: 1.3.1
-  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
-  Copyright (c) Jon Rohan, James M. Greene (2014)
-
-
----------------------------------------------------
-
-(3) Licenses for bundled software
-
-Contents:
-
-  The BSD 2-Clause License
-  The BSD 3-Clause License ("New BSD")
-  The MIT License ("MIT")
-
-
-The BSD 2-Clause License
-
-  Redistribution and use in source and binary forms, with or without
-  modification, are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, this
-  list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice,
-  this list of conditions and the following disclaimer in the documentation
-  and/or other materials provided with the distribution.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
-  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
-  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
-  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
-  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
-  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
-  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
-  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
-  
-
-The BSD 3-Clause License ("New BSD")
-
-  Redistribution and use in source and binary forms, with or without modification,
-  are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, 
-  this list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice, 
-  this list of conditions and the following disclaimer in the documentation 
-  and/or other materials provided with the distribution.
-  
-  3. Neither the name of the copyright holder nor the names of its contributors 
-  may be used to endorse or promote products derived from this software without 
-  specific prior written permission.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
-  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
-  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
-  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
-  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
-  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
-  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
-  POSSIBILITY OF SUCH DAMAGE.
-  
-
-The MIT License ("MIT")
-
-  Permission is hereby granted, free of charge, to any person obtaining a copy
-  of this software and associated documentation files (the "Software"), to deal
-  in the Software without restriction, including without limitation the rights
-  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
-  copies of the Software, and to permit persons to whom the Software is
-  furnished to do so, subject to the following conditions:
-  
-  The above copyright notice and this permission notice shall be included in
-  all copies or substantial portions of the Software.
-  
-  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
-  THE SOFTWARE.
-  
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/NOTICE
----------------------------------------------------------------------
diff --git a/brooklyn-dist/NOTICE b/brooklyn-dist/NOTICE
deleted file mode 100644
index f790f13..0000000
--- a/brooklyn-dist/NOTICE
+++ /dev/null
@@ -1,5 +0,0 @@
-Apache Brooklyn
-Copyright 2014-2015 The Apache Software Foundation
-
-This product includes software developed at
-The Apache Software Foundation (http://www.apache.org/).

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/README.md
----------------------------------------------------------------------
diff --git a/brooklyn-dist/README.md b/brooklyn-dist/README.md
deleted file mode 100644
index 0b34dc4..0000000
--- a/brooklyn-dist/README.md
+++ /dev/null
@@ -1,8 +0,0 @@
-
-# [![**Brooklyn**](https://brooklyn.apache.org/style/img/apache-brooklyn-logo-244px-wide.png)](http://brooklyn.apache.org/)
-
-### Distribution Sub-Project for Apache Brooklyn
-
-This repo contains modules for creating the distributable binary
-combining the `server`, the `ui`, and other elements in other Brooklyn repos.
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/all/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/all/pom.xml b/brooklyn-dist/all/pom.xml
deleted file mode 100644
index bcaa758..0000000
--- a/brooklyn-dist/all/pom.xml
+++ /dev/null
@@ -1,117 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-    
-     http://www.apache.org/licenses/LICENSE-2.0
-    
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-    <modelVersion>4.0.0</modelVersion>
-    <packaging>jar</packaging>
-
-    <artifactId>brooklyn-all</artifactId>
-
-    <name>Brooklyn All Things</name>
-    <description>
-        A meta-dependency for all the major Brooklyn modules.
-    </description>
-
-    <parent>
-        <groupId>org.apache.brooklyn</groupId>
-        <artifactId>brooklyn-dist-root</artifactId>
-        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-        <relativePath>../pom.xml</relativePath>
-    </parent>
-
-    <dependencies>
-        <dependency>
-            <groupId>com.google.guava</groupId>
-            <artifactId>guava</artifactId>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-policy</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-locations-jclouds</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-software-webapp</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-software-messaging</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-software-monitoring</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-software-database</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-software-osgi</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-software-nosql</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-software-network</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-launcher</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-cli</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-test-framework</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-
-        <!-- bring in all jclouds-supported cloud providers -->
-        <dependency>
-            <groupId>${jclouds.groupId}</groupId>
-            <artifactId>jclouds-allcompute</artifactId>
-        </dependency>
-    </dependencies>
-
-</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/NOTES.txt
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/NOTES.txt b/brooklyn-dist/archetypes/quickstart/NOTES.txt
deleted file mode 100644
index 4028bf6..0000000
--- a/brooklyn-dist/archetypes/quickstart/NOTES.txt
+++ /dev/null
@@ -1,76 +0,0 @@
-
-This file contains notes for anyone working on the archetype.
-
-
-Some things to keep in mind:
-
-* The sample project in `src/brooklyn-sample` is what populates the
-  archetype source (in `src/main/resources/archetype-resources`, 
-  copied there by the `pom.xml` in this directory, in `clean` phase).
-  (You can open and edit it in your IDE.)
-  
-* That archetype source then becomes the archetype (in `install` phase)
-  according to the copy and filter rules in `src/main/resources/META-INF/maven/archetype-metadata.xml`
-
-* For any changes to the project:
-
-  * ensure `brooklyn-sample` builds as you would like
-  * ensure the resulting archetype builds as you would like
-    (should be reasonably safe and automated, but check that the 2 sets of 
-    copy/translation rules above do what you intended!)
-  * update the `README.*` files in the root of `brooklyn-sample` and the
-    `src/main/assembly/files` within that
-  * update the docs under `use/guide/defining-applications/archetype.md` and `use/guide/quickstart/index.md`
-
-
-To build:
-
-    mvn clean install
-
-
-To test a build:
-
-    pushd /tmp
-    rm -rf brooklyn-sample
-    export BV=0.9.0-SNAPSHOT    # BROOKLYN_VERSION
-    
-    mvn archetype:generate                                  \
-                                                            \
-      -DarchetypeGroupId=org.apache.brooklyn                \
-      -DarchetypeArtifactId=brooklyn-archetype-quickstart   \
-      -DarchetypeVersion=${BV} \
-      \
-      -DgroupId=com.acme.sample                             \
-      -DartifactId=brooklyn-sample                          \
-      -Dversion=0.1.0-SNAPSHOT                              \
-      -Dpackage=com.acme.sample.brooklyn                    \
-      \
-      --batch-mode
-    
-    cd brooklyn-sample
-    mvn clean assembly:assembly
-    cd target/brooklyn-sample-0.1.0-SNAPSHOT-dist/brooklyn-sample-0.1.0-SNAPSHOT/
-    ./start.sh launch --cluster --location localhost
-
-
-References
-
- * http://stackoverflow.com/questions/4082643/how-can-i-test-a-maven-archetype-that-ive-just-created/18916065#18916065
-
-----
-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.

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/pom.xml b/brooklyn-dist/archetypes/quickstart/pom.xml
deleted file mode 100644
index f47c395..0000000
--- a/brooklyn-dist/archetypes/quickstart/pom.xml
+++ /dev/null
@@ -1,232 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-    
-     http://www.apache.org/licenses/LICENSE-2.0
-    
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-  <modelVersion>4.0.0</modelVersion>
-  <artifactId>brooklyn-archetype-quickstart</artifactId>
-  <packaging>maven-archetype</packaging>
-  <name>Brooklyn Quick-Start Project Archetype</name>
-  <description>
-    This project defines an archetype for creating new projects which consume brooklyn,
-    including an example application and an example new entity type,
-    able to build an OSGi JAR and a binary assembly, with logging and READMEs.
-  </description>
-
-  <parent>
-    <groupId>org.apache.brooklyn</groupId>
-    <artifactId>brooklyn-parent</artifactId>
-    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-    <relativePath>../../../brooklyn-server/parent/pom.xml</relativePath>
-  </parent>
-
-  <build>
-    <plugins>
-      <plugin>
-        <artifactId>maven-archetype-plugin</artifactId>
-        <!-- all we want to do is skip _integration tests_ when skipTests is set, not other phases;
-             but for some reason this seems to do it, and it still builds the archetype (!?).
-             whereas setting skip inside the integration-test execution goal does NOT work.
-              
-             TODO promote to root pom.xml when we better understand why
-        -->
-        <configuration>
-          <skip>${skipTests}</skip>
-        </configuration>
-      </plugin>
-      
-      <plugin>
-        <artifactId>maven-clean-plugin</artifactId>
-        <configuration>
-          <filesets>
-            <fileset> 
-                <directory>src/test/resources/projects/integration-test-1/reference</directory> 
-                <includes><include>**/*</include></includes>
-            </fileset>
-            <fileset> 
-                <directory>src/main/resources/archetype-resources/</directory> 
-                <includes><include>**/*</include></includes>
-            </fileset>
-          </filesets>
-        </configuration>
-      </plugin>
-
-      <plugin>
-        <groupId>com.google.code.maven-replacer-plugin</groupId>
-        <artifactId>maven-replacer-plugin</artifactId>
-        <executions>
-          <execution>
-            <id>copy-brooklyn-sample-to-integration-test-reference</id>
-            <phase>clean</phase>
-            <goals> <goal>replace</goal> </goals>
-            <configuration>
-              <basedir>${basedir}/src/brooklyn-sample</basedir> 
-              <outputBasedir>${basedir}</outputBasedir>
-              <outputDir>src/test/resources/projects/integration-test-1/reference</outputDir>
-              <includes> <include>**</include> </includes>
-              <excludes> 
-                <exclude>.*</exclude> 
-                <exclude>.*/**</exclude> 
-                <exclude>target/**</exclude> 
-                <exclude>*.log</exclude> 
-              </excludes>
-              
-              <replacements />
-            </configuration>
-          </execution>
-          <!-- would be nice to reduce the repetion below, but don't see how;
-               have tried with valueTokenMap but it must lie beneath basedir;
-               and tried with {input,output}FilePattern but that doesn't apply to dirs  -->
-          <execution>
-            <!-- copy creating variables and unpackaged, for src/main/java -->
-            <id>copy-brooklyn-sample-to-archetype-src-main-java</id>
-            <phase>clean</phase>
-            <goals> <goal>replace</goal> </goals>
-            <configuration>
-              <basedir>${basedir}/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn</basedir>
-              <outputBasedir>${basedir}</outputBasedir>
-              <outputDir>src/main/resources/archetype-resources/src/main/java</outputDir>
-              <includes> <include>**/*</include> </includes>
-              <replacements>
-                <replacement> <token>brooklyn-sample</token> <value>\$\{artifactId}</value> </replacement>
-                <replacement> <token>com\.acme\.sample\.brooklyn</token> <value>\$\{package}</value> </replacement>
-                <replacement> <token>com/acme/sample/brooklyn</token> <value>\$\{packageInPathFormat}</value> </replacement>
-                <replacement> <token>com\.acme\.sample</token> <value>\$\{groupId}</value> </replacement>
-                <replacement> <token>0.1.0-SNAPSHOT</token> <value>\$\{version}</value> </replacement>
-              </replacements>
-            </configuration>
-          </execution>
-          <execution>
-            <!-- copy creating variables and unpackaged, for src/test/java -->
-            <id>copy-brooklyn-sample-to-archetype-src-test-java</id>
-            <phase>clean</phase>
-            <goals> <goal>replace</goal> </goals>
-            <configuration>
-              <basedir>${basedir}/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn</basedir>
-              <outputBasedir>${basedir}</outputBasedir>
-              <outputDir>src/main/resources/archetype-resources/src/test/java</outputDir>
-              <includes> <include>**/*</include> </includes>
-              <replacements>
-                <replacement> <token>brooklyn-sample</token> <value>\$\{artifactId}</value> </replacement>
-                <replacement> <token>com\.acme\.sample\.brooklyn</token> <value>\$\{package}</value> </replacement>
-                <replacement> <token>com/acme/sample/brooklyn</token> <value>\$\{packageInPathFormat}</value> </replacement>
-                <replacement> <token>com\.acme\.sample</token> <value>\$\{groupId}</value> </replacement>
-                <replacement> <token>0.1.0-SNAPSHOT</token> <value>\$\{version}</value> </replacement>
-              </replacements>
-            </configuration>
-          </execution>
-          <execution>
-            <!-- copy creating variables, for all other places -->
-            <id>copy-brooklyn-sample-to-archetype-resources</id>
-            <phase>clean</phase>
-            <goals> <goal>replace</goal> </goals>
-            <configuration>
-              <basedir>${basedir}/src/brooklyn-sample/</basedir>
-              <outputBasedir>${basedir}</outputBasedir>
-              <outputDir>src/main/resources/archetype-resources/</outputDir>
-              <includes> <include>**/*</include> </includes>
-              <excludes> 
-                <exclude>src/main/java/**</exclude> 
-                <exclude>src/test/java/**</exclude> 
-                <exclude>target/**</exclude> 
-                <exclude>test-output/**</exclude> 
-                <exclude>.*</exclude> 
-                <exclude>**/*.png</exclude> 
-                <exclude>.*/**</exclude> 
-                <exclude>*.log</exclude>
-                <exclude>**/*.sh</exclude>
-              </excludes>
-              <replacements>
-                <!-- special chars in velocity have to be escaped.
-                     fortunately we only use fairly simple examples so we don't need to solve the general case! -->
-                <!-- escaping # is ugly -->
-                <replacement> <token>(#+)</token> <value>#set\(\$H='$1'\)\${H}</value> </replacement>
-                <!-- and escaping $ doesn't even seem to work; perhaps an old version of velocity in use?
-                     (however velocity ignores $ except for variables which are defined, so we're okay)
-                <replacement> <token>\$</token> <value>\\\$</value> </replacement>
-                -->
-                
-                <replacement> <token>brooklyn-sample</token> <value>\$\{artifactId}</value> </replacement>
-                <replacement> <token>com\.acme\.sample\.brooklyn</token> <value>\$\{package}</value> </replacement>
-                <replacement> <token>com/acme/sample/brooklyn</token> <value>\$\{packageInPathFormat}</value> </replacement>
-                <replacement> <token>com\.acme\.sample</token> <value>\$\{groupId}</value> </replacement>
-                <replacement> <token>0.1.0-SNAPSHOT</token> <value>\$\{version}</value> </replacement>
-              </replacements>
-            </configuration>
-          </execution>
-          <execution>
-            <!-- copy creating variables, for all other places -->
-            <id>copy-brooklyn-sample-to-archetype-resources-binary</id>
-            <phase>clean</phase>
-            <goals> <goal>replace</goal> </goals>
-            <configuration>
-              <basedir>${basedir}/src/brooklyn-sample/</basedir>
-              <outputBasedir>${basedir}</outputBasedir>
-              <outputDir>src/main/resources/archetype-resources/</outputDir>
-              <includes>
-                <include>**/*.png</include>
-                <include>**/*.sh</include>
-              </includes>
-              <excludes> 
-                <exclude>target/**</exclude> 
-                <exclude>test-output/**</exclude> 
-                <exclude>.*</exclude> 
-                <exclude>.*/**</exclude> 
-              </excludes>
-              <!-- no replacements for binary (put one just so we can use this plugin for consistency) -->
-              <replacements><replacement> <token>NONCE_123456789XYZ</token> <value>NONCE_123456789XYZ</value> </replacement></replacements>
-            </configuration>
-          </execution>
-          
-        </executions>
-      </plugin>
-
-    </plugins>
-      <pluginManagement>
-        <plugins>
-          <plugin>
-            <groupId>org.apache.rat</groupId>
-            <artifactId>apache-rat-plugin</artifactId>
-            <configuration>
-              <excludes combine.children="append">
-                <!-- 
-                    The maven archetype are files "without any degree of creativity". They are intended
-                    purely as a template to generate a new project for a user, where upon the user can
-                    write their code within this new project.
-                    The exclusions seem to need to include code that is auto-generated during a test run.
-                -->
-                <exclude>**/src/main/resources/archetype-resources/**/*</exclude>
-                <exclude>**/src/test/resources/projects/integration-test-1/goal.txt</exclude>
-                <exclude>**/src/test/resources/projects/integration-test-1/reference/**/*</exclude>
-                <exclude>**/src/main/java/sample/**/*Sample*.java</exclude>
-                <exclude>**/src/main/resources/logback-custom.xml</exclude>
-                <exclude>**/src/brooklyn-sample/README.md</exclude>
-                <exclude>**/src/brooklyn-sample/pom.xml</exclude>
-                <exclude>**/src/brooklyn-sample/src/main/assembly/files/conf/*</exclude>
-                <exclude>**/src/brooklyn-sample/src/main/java/**/*.java</exclude>
-                <exclude>**/src/brooklyn-sample/src/main/resources/logback-custom.xml</exclude>
-                <exclude>**/src/brooklyn-sample/src/test/java/**/*.java</exclude>
-              </excludes>
-            </configuration>
-          </plugin>
-        </plugins>
-      </pluginManagement>
-
-  </build>
-
-</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/README.md
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/README.md b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/README.md
deleted file mode 100644
index b40df41..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/README.md
+++ /dev/null
@@ -1,73 +0,0 @@
-brooklyn-sample
-===
-
-This is a Sample Brooklyn project, showing how to define an application
-which Brooklyn will deploy and manage.
-
-This sample project is intended to be customized to suit your purposes: but
-search for all lines containing the word "sample" to make sure all the
-references to this being a sample are removed!   
-
-To build an assembly, simply run:
-
-    mvn clean assembly:assembly
-
-This creates a tarball with a full standalone application which can be installed in any *nix machine at:
-    target/brooklyn-sample-0.1.0-SNAPSHOT-dist.tar.gz
-
-It also installs an unpacked version which you can run locally:
- 
-     cd target/brooklyn-sample-0.1.0-SNAPSHOT-dist/brooklyn-sample-0.1.0-SNAPSHOT
-     ./start.sh server
- 
-For more information see the README (or `./start.sh help`) in that directory.
-On OS X and Linux, this application will deploy to localhost *if* you have key-based 
-password-less (and passphrase-less) ssh enabled.
-
-To configure cloud and fixed-IP locations, see the README file in the built application directly.
-For more information you can run `./start.sh help`) in that directory.
-
-
-### Opening in an IDE
-
-To open this project in an IDE, you will need maven support enabled
-(e.g. with the relevant plugin).  You should then be able to develop
-it and run it as usual.  For more information on IDE support, visit:
-
-    https://brooklyn.incubator.apache.org/v/latest/dev/env/ide/
-
-
-### Customizing the Assembly
-
-The artifacts (directory and tar.gz by default) which get built into
-`target/` can be changed.  Simply edit the relevant files under
-`src/main/assembly`.
-
-You will likely wish to customize the `SampleMain` class as well as
-the `Sample*App` classes provided.  That is the intention!
-You will also likely want to update the `start.sh` script and
-the `README.*` files.
-
-To easily find the bits you should customize, do a:
-
-    grep -ri sample src/ *.*
-
-
-### More About Apache Brooklyn
-
-Apache Brooklyn is a code library and framework for managing applications in a 
-cloud-first dev-ops-y way.  It has been used to create this sample project 
-which shows how to define an application and entities for Brooklyn.
-
-This project can be extended for more complex topologies and more 
-interesting applications, and to develop the policies to scale or tune the 
-deployment depending on what the application needs.
-
-For more information consider:
-
-* Visiting the Apache Brooklyn home page at https://brooklyn.incubator.apache.org
-* Finding us on IRC #brooklyncentral or email (click "Community" at the site above) 
-* Forking the project at  http://github.com/apache/incubator-brooklyn/
-
-A sample Brooklyn project should specify its license.
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
deleted file mode 100644
index 44f5f93..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/pom.xml
+++ /dev/null
@@ -1,102 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-
-  <modelVersion>4.0.0</modelVersion>
-
-  <parent>
-    <groupId>org.apache.brooklyn</groupId>
-    <artifactId>brooklyn-downstream-parent</artifactId>
-    <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-  </parent>
-
-  <groupId>com.acme.sample</groupId>
-  <artifactId>brooklyn-sample</artifactId>
-  <version>0.1.0-SNAPSHOT</version>
-  <packaging>jar</packaging>
-
-  <name>Sample Brooklyn Project com.acme.sample:brooklyn-sample v0.1.0-SNAPSHOT</name>
-  <description>
-    Sample optional description goes here.
-  </description>
-
-  <!-- Optional metadata (commented out in this sample) 
-
-  <url>https://github.com/sample/sample</url>
-
-  <licenses>
-    <license>
-      <name>The Apache Software License, Version 2.0</name>
-      <url>http://www.apache.org/licenses/LICENSE-2.0.txt</url>
-      <distribution>repo</distribution>
-    </license>
-  </licenses>
-
-  <developers>
-    <developer>
-      <name>Sample Project Committers</name>
-    </developer>
-  </developers>
-
-  <scm>
-    <connection>scm:git:git://github.com/sample/sample</connection>
-    <developerConnection>scm:git:git@github.com:sample/sample.git</developerConnection>
-    <url>http://github.com/sample/sample</url>
-  </scm>
-
-  -->
-
-  <properties>
-    <project.entry>com.acme.sample.brooklyn.SampleMain</project.entry>
-  </properties>
-
-  <repositories>
-    <repository>
-      <id>apache.snapshots</id>
-      <name>Apache Snapshot Repository</name>
-      <url>http://repository.apache.org/snapshots</url>
-      <releases>
-        <enabled>false</enabled>
-      </releases>
-    </repository>
-  </repositories>
-
-  <dependencies>
-    <dependency>
-      <!-- this pulls in all brooklyn entities and clouds; 
-           you can cherry pick selected ones instead (for a smaller build) -->
-      <groupId>org.apache.brooklyn</groupId>
-      <artifactId>brooklyn-all</artifactId>
-      <version>${brooklyn.version}</version>
-    </dependency>
-
-    <dependency>
-      <!-- includes testng and useful logging for tests -->
-      <groupId>org.apache.brooklyn</groupId>
-      <artifactId>brooklyn-test-support</artifactId>
-      <version>${brooklyn.version}</version>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <!-- this gives us flexible and easy-to-use logging; just edit logback-custom.xml! -->
-      <groupId>org.apache.brooklyn</groupId>
-      <artifactId>brooklyn-logback-xml</artifactId>
-      <version>${brooklyn.version}</version>
-    </dependency>
-  </dependencies>
-
-  <build>
-    <plugins>
-      <plugin>
-        <artifactId>maven-assembly-plugin</artifactId>
-        <configuration>
-          <descriptors>
-            <descriptor>src/main/assembly/assembly.xml</descriptor>
-          </descriptors>
-        </configuration>
-      </plugin>
-    </plugins>
-  </build>
-
-</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/assembly.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/assembly.xml b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/assembly.xml
deleted file mode 100644
index 2875a8a..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/assembly.xml
+++ /dev/null
@@ -1,88 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-    
-     http://www.apache.org/licenses/LICENSE-2.0
-    
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-<assembly>
-    <id>dist</id>
-    <!-- Generates an archive and a dir containing the needed files; 
-         can add e.g. zip to the following
-         (but executable bit is not preserved) -->
-    <formats>
-        <format>dir</format>
-        <format>tar.gz</format>
-    </formats>
-
-    <!-- Adds dependencies to zip package under lib directory -->
-    <dependencySets>
-        <dependencySet>
-            <!--
-               Project artifact is not copied under library directory since
-               it is added to the root directory of the zip package.
-           -->
-            <useProjectArtifact>false</useProjectArtifact>
-            <outputDirectory>lib</outputDirectory>
-            <unpack>false</unpack>
-        </dependencySet>
-    </dependencySets>
-
-    <!--
-       Adds startup scripts to the root directory of zip package. The startup
-       scripts are located to src/main/scripts directory as stated by Maven
-       conventions.
-    -->
-    <files>
-        <file>
-            <source>src/main/assembly/scripts/start.sh</source>
-            <outputDirectory></outputDirectory>
-            <fileMode>0755</fileMode>
-            <filtered>true</filtered>
-        </file>
-    </files>
-    <fileSets>
-        <fileSet>
-            <directory>src/main/assembly/scripts</directory>
-            <outputDirectory></outputDirectory>
-            <fileMode>0755</fileMode>
-            <includes>
-                <include>*</include>
-            </includes>
-            <excludes>
-                <exclude>start.sh</exclude>
-            </excludes>
-        </fileSet>
-        <!--  add additional files (but not marked executable) -->
-        <fileSet>
-            <directory>src/main/assembly/files</directory>
-            <outputDirectory></outputDirectory>
-            <includes>
-                <include>**</include>
-            </includes>
-        </fileSet>
-        <!-- adds jar package to the root directory of zip package -->
-        <fileSet>
-            <directory>target</directory>
-            <outputDirectory></outputDirectory>
-            <includes>
-                <include>*.jar</include>
-            </includes>
-            <excludes>
-                <exclude>*-tests.jar</exclude>
-            </excludes>
-        </fileSet>
-    </fileSets>
-</assembly>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/README.txt
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/README.txt b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/README.txt
deleted file mode 100644
index 8ba14f1..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/README.txt
+++ /dev/null
@@ -1,96 +0,0 @@
-brooklyn-sample
-===
-
-This is a sample application which is launched and managed by Brooklyn.
-This README file is at the root of the built assembly, which can be uploaded
-and run most anywhere.  This file provides end-user instructions.
-
-To use this, configure any cloud credentials then run  ./start.sh  in this 
-directory. You can then access the management context in your browser, 
-typically on  http://localhost:8081 , and through that console deploy the
-applications contained in this archive.
-
-
-### Cloud Credentials
-
-To run, you'll need to specify credentials for your preferred cloud.  This 
-can be done in `~/.brooklyn/brooklyn.properties`.
-
-A recommended starting point is the file at:
-
-    https://brooklyn.incubator.apache.org/v/latest/use/guide/quickstart/brooklyn.properties
-
-As a quick-start, you can specify:
-
-    brooklyn.location.jclouds.aws-ec2.identity=AKXXXXXXXXXXXXXXXXXX
-    brooklyn.location.jclouds.aws-ec2.credential=secret01xxxxxxxxxxxxxxxxxxxxxxxxxxx
-    
-    brooklyn.location.named.My_Amazon_US_west=jclouds:aws-ec2:us-west-1
-    brooklyn.location.named.My_Amazon_EU=jclouds:aws-ec2:eu-west-1
-
-Alternatively these can be set as shell environment parameters or JVM system properties.
-
-Many other clouds are supported also, as well as pre-existing machines 
-("bring your own nodes"), custom endpoints for private clouds, and specifying 
-custom keys and passphrases. For more information see:
-
-    https://brooklyn.incubator.apache.org/v/latest/use/guide/defining-applications/common-usage#locations
-
-
-### Run
-
-Usage:
-
-    ./start.sh launch [--WHAT] \
-        [--port 8081+] \
-        [--location location] 
-
-The optional port argument specifies the port where the Brooklyn console 
-will be running, such as localhost:8081. (The console is only bound to 
-localhost, unless you set up users and security, as described at
-https://brooklyn.incubator.apache.org/v/latest/use/guide/management/ .)
-
-In the console, you can access the catalog and deploy applications to
-configured locations.
-
-In this sample application, `--cluster` and `--single` are supported in place of `--WHAT`,
-corresponding to sample blueprints in the project. This can be left blank to have nothing 
-launched; note that the blueprints can be launched at runtime via the GUI or API.
-
-Use `./start.sh help` or `./start.sh help launch` for more detailed help.
-
-The location might be `localhost` (the default), `aws-ec2:us-east-1`, 
-`openstack:endpoint`, `softlayer`, or based on names, such as
-`named:My_Amazon_US_west`, so long as it is configured as above. 
-(Localhost does not need any configuration in `~/brooklyn/brooklyn.properties`, 
-provided you have password-less ssh access enabled to localhost, using a 
-private key with no passphrase.) 
-
-
-### More About Brooklyn
-
-Brooklyn is a code library and framework for managing applications in a 
-cloud-first dev-ops-y way.  It has been used to create this sample project 
-which shows how to define an application and entities for Brooklyn.
-
-This project can be extended for more complex topologies and more 
-interesting applications, and to develop the policies to scale or tune the 
-deployment depending on what the application needs.
-
-For more information consider:
-
-* Visiting the open-source Brooklyn home page at  http://brooklyncentral.github.com
-* Forking the Brooklyn project at  http://github.com/brooklyncentral/brooklyn
-* Emailing  brooklyn-users@googlegroups.com 
-
-For commercial enquiries -- including bespoke development and paid support --
-contact Cloudsoft, the supporters of Brooklyn, at:
-
-* www.CloudsoftCorp.com
-* info@cloudsoftcorp.com
-
-Brooklyn is (c) 2014 Cloudsoft Corporation and released as open source under 
-the Apache License v2.0.
-
-A sample Brooklyn project should specify its license here.
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/conf/logback.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/conf/logback.xml b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/conf/logback.xml
deleted file mode 100644
index 7b7a972..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/files/conf/logback.xml
+++ /dev/null
@@ -1,11 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<configuration>
-
-  <!-- logging configuration for this project; edit this file as required, or override the files 
-       this includes as described in the Logging section of the brooklyn users guide.
-       this project already supplies a logback-custom.xml which gets included to log our
-       classes at debug level and write to a log file named after this project -->
-
-  <include resource="logback-main.xml"/>
-  
-</configuration>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/scripts/start.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/scripts/start.sh b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/scripts/start.sh
deleted file mode 100755
index 2879b6d..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/assembly/scripts/start.sh
+++ /dev/null
@@ -1,40 +0,0 @@
-#!/bin/bash
-#
-# 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.
-#
-
-if [ ! -z "$JAVA_HOME" ] ; then 
-    JAVA=$JAVA_HOME/bin/java
-else
-    JAVA=`which java`
-fi
-
-if [ ! -x "$JAVA" ] ; then
-  echo Cannot find java. Set JAVA_HOME or add java to path.
-  exit 1
-fi
-
-if [[ ! `ls ${project.artifactId}-*.jar 2> /dev/null` ]] ; then
-  echo Command must be run from the directory where the JAR is installed.
-  exit 4
-fi
-
-$JAVA -Xms256m -Xmx1024m -XX:MaxPermSize=1024m \
-    -classpath "conf/:patch/*:*:lib/*" \
-    ${project.entry} \
-    "$@"

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/SampleMain.java
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/SampleMain.java b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/SampleMain.java
deleted file mode 100644
index 253f657..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/SampleMain.java
+++ /dev/null
@@ -1,81 +0,0 @@
-package com.acme.sample.brooklyn;
-
-import java.util.Arrays;
-
-import io.airlift.command.Command;
-import io.airlift.command.Option;
-
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-import org.apache.brooklyn.api.catalog.BrooklynCatalog;
-import org.apache.brooklyn.cli.Main;
-
-import com.google.common.base.Objects.ToStringHelper;
-
-import com.acme.sample.brooklyn.sample.app.*;
-
-/**
- * This class provides a static main entry point for launching a custom Brooklyn-based app.
- * <p>
- * It inherits the standard Brooklyn CLI options from {@link Main},
- * plus adds a few more shortcuts for favourite blueprints to the {@link LaunchCommand}.
- */
-public class SampleMain extends Main {
-    
-    private static final Logger log = LoggerFactory.getLogger(SampleMain.class);
-    
-    public static final String DEFAULT_LOCATION = "localhost";
-
-    public static void main(String... args) {
-        log.debug("CLI invoked with args "+Arrays.asList(args));
-        new SampleMain().execCli(args);
-    }
-
-    @Override
-    protected String cliScriptName() {
-        return "start.sh";
-    }
-    
-    @Override
-    protected Class<? extends BrooklynCommand> cliLaunchCommand() {
-        return LaunchCommand.class;
-    }
-
-    @Command(name = "launch", description = "Starts a server, and optionally an application. "
-        + "Use e.g. --single or --cluster to launch one-node and clustered variants of the sample web application.")
-    public static class LaunchCommand extends Main.LaunchCommand {
-
-        // add these options to the LaunchCommand as shortcuts for our favourite applications
-        
-        @Option(name = { "--single" }, description = "Launch a single web-server instance")
-        public boolean single;
-
-        @Option(name = { "--cluster" }, description = "Launch a web-server cluster")
-        public boolean cluster;
-
-        @Override
-        public Void call() throws Exception {
-            // process our CLI arguments
-            if (single) setAppToLaunch( SingleWebServerSample.class.getCanonicalName() );
-            if (cluster) setAppToLaunch( ClusterWebServerDatabaseSample.class.getCanonicalName() );
-            
-            // now process the standard launch arguments
-            return super.call();
-        }
-
-        @Override
-        protected void populateCatalog(BrooklynCatalog catalog) {
-            super.populateCatalog(catalog);
-            catalog.addItem(SingleWebServerSample.class);
-            catalog.addItem(ClusterWebServerDatabaseSample.class);
-        }
-
-        @Override
-        public ToStringHelper string() {
-            return super.string()
-                    .add("single", single)
-                    .add("cluster", cluster);
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/ClusterWebServerDatabaseSample.java
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/ClusterWebServerDatabaseSample.java b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/ClusterWebServerDatabaseSample.java
deleted file mode 100644
index 11d977f..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/ClusterWebServerDatabaseSample.java
+++ /dev/null
@@ -1,137 +0,0 @@
-package com.acme.sample.brooklyn.sample.app;
-
-import java.util.concurrent.TimeUnit;
-
-import org.apache.brooklyn.api.catalog.Catalog;
-import org.apache.brooklyn.api.catalog.CatalogConfig;
-import org.apache.brooklyn.api.entity.EntitySpec;
-import org.apache.brooklyn.api.sensor.AttributeSensor;
-import org.apache.brooklyn.config.ConfigKey;
-import org.apache.brooklyn.core.config.ConfigKeys;
-import org.apache.brooklyn.core.entity.AbstractApplication;
-import org.apache.brooklyn.core.entity.Entities;
-import org.apache.brooklyn.core.location.PortRanges;
-import org.apache.brooklyn.core.sensor.Sensors;
-import org.apache.brooklyn.enricher.stock.SensorPropagatingEnricher;
-import org.apache.brooklyn.enricher.stock.SensorTransformingEnricher;
-import org.apache.brooklyn.entity.database.DatastoreMixins.DatastoreCommon;
-import org.apache.brooklyn.entity.database.mysql.MySqlNode;
-import org.apache.brooklyn.entity.group.DynamicCluster;
-import org.apache.brooklyn.entity.java.JavaEntityMethods;
-import org.apache.brooklyn.entity.webapp.ControlledDynamicWebAppCluster;
-import org.apache.brooklyn.entity.webapp.DynamicWebAppCluster;
-import org.apache.brooklyn.entity.webapp.JavaWebAppService;
-import org.apache.brooklyn.entity.webapp.WebAppService;
-import org.apache.brooklyn.entity.webapp.WebAppServiceConstants;
-import org.apache.brooklyn.policy.autoscaling.AutoScalerPolicy;
-import org.apache.brooklyn.policy.enricher.HttpLatencyDetector;
-import org.apache.brooklyn.util.maven.MavenArtifact;
-import org.apache.brooklyn.util.maven.MavenRetriever;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-import com.google.common.base.Functions;
-
-import static org.apache.brooklyn.core.sensor.DependentConfiguration.attributeWhenReady;
-import static org.apache.brooklyn.core.sensor.DependentConfiguration.formatString;
-
-
-/** This sample builds a 3-tier application with an elastic app-server cluster,
- *  and it sets it up for use in the Brooklyn catalog. 
- *  <p>
- *  Note that root access (and xcode etc) may be required to install nginx.
- **/
-@Catalog(name="Elastic Java Web + DB",
-    description="Deploys a WAR to a load-balanced elastic Java AppServer cluster, " +
-        "with an auto-scaling policy, " +
-        "wired to a database initialized with the provided SQL; " +
-        "defaults to a 'Hello World' chatroom app.",
-    iconUrl="classpath://sample-icon.png")
-public class ClusterWebServerDatabaseSample extends AbstractApplication {
-
-    public static final Logger LOG = LoggerFactory.getLogger(ClusterWebServerDatabaseSample.class);
-
-    // ---------- WAR configuration ---------------
-    
-    public static final String DEFAULT_WAR_URL =
-            // can supply any URL -- this loads a stock example from maven central / sonatype
-            MavenRetriever.localUrl(MavenArtifact.fromCoordinate("io.brooklyn.example:brooklyn-example-hello-world-sql-webapp:war:0.5.0"));
-
-    @CatalogConfig(label="WAR (URL)", priority=2)
-    public static final ConfigKey<String> WAR_URL = ConfigKeys.newConfigKey(
-        "app.war", "URL to the application archive which should be deployed", DEFAULT_WAR_URL);    
-
-    
-    // ---------- DB configuration ----------------
-    
-    // this is included in src/main/resources. if in an IDE, ensure your build path is set appropriately.
-    public static final String DEFAULT_DB_SETUP_SQL_URL = "classpath://visitors-creation-script.sql";
-    
-    @CatalogConfig(label="DB Setup SQL (URL)", priority=1)
-    public static final ConfigKey<String> DB_SETUP_SQL_URL = ConfigKeys.newConfigKey(
-        "app.db_sql", "URL to the SQL script to set up the database", 
-        DEFAULT_DB_SETUP_SQL_URL);
-    
-    public static final String DB_TABLE = "visitors";
-    public static final String DB_USERNAME = "brooklyn";
-    public static final String DB_PASSWORD = "br00k11n";
-    
-
-    // --------- Custom Sensor --------------------
-    
-    AttributeSensor<Integer> APPSERVERS_COUNT = Sensors.newIntegerSensor( 
-            "appservers.count", "Number of app servers deployed");
-
-    
-    // --------- Initialization -------------------
-    
-    /** Initialize our application. In this case it consists of 
-     *  a single DB, with a load-balanced cluster (nginx + multiple JBosses, by default),
-     *  with some sensors and a policy. */
-    @Override
-    public void init() {
-        DatastoreCommon db = addChild(
-                EntitySpec.create(MySqlNode.class)
-                        .configure(MySqlNode.CREATION_SCRIPT_URL, Entities.getRequiredUrlConfig(this, DB_SETUP_SQL_URL)));
-
-        ControlledDynamicWebAppCluster web = addChild(
-                EntitySpec.create(ControlledDynamicWebAppCluster.class)
-                        // set WAR to use, and port to use
-                        .configure(JavaWebAppService.ROOT_WAR, getConfig(WAR_URL))
-                        .configure(WebAppService.HTTP_PORT, PortRanges.fromString("8080+"))
-                        
-//                        // optionally - use Tomcat instead of JBoss (default:
-//                        .configure(ControlledDynamicWebAppCluster.MEMBER_SPEC, EntitySpec.create(TomcatServer.class))
-                        
-                        // inject a JVM system property to point to the DB
-                        .configure(JavaEntityMethods.javaSysProp("brooklyn.example.db.url"), 
-                                formatString("jdbc:%s%s?user=%s\\&password=%s", 
-                                        attributeWhenReady(db, DatastoreCommon.DATASTORE_URL), DB_TABLE, DB_USERNAME, DB_PASSWORD))
-                    
-                        // start with 2 appserver nodes, initially
-                        .configure(DynamicCluster.INITIAL_SIZE, 2) 
-                    );
-
-        // add an enricher which measures latency
-        web.addEnricher(HttpLatencyDetector.builder().
-                url(WebAppServiceConstants.ROOT_URL).
-                rollup(10, TimeUnit.SECONDS).
-                build());
-
-        // add a policy which scales out based on Reqs/Sec
-        web.getCluster().addPolicy(AutoScalerPolicy.builder().
-                metric(DynamicWebAppCluster.REQUESTS_PER_SECOND_IN_WINDOW_PER_NODE).
-                metricRange(10, 100).
-                sizeRange(2, 5).
-                build());
-
-        // add a few more sensors at the top-level (KPI's at the root of the application)
-        addEnricher(SensorPropagatingEnricher.newInstanceListeningTo(web,  
-                WebAppServiceConstants.ROOT_URL,
-                DynamicWebAppCluster.REQUESTS_PER_SECOND_IN_WINDOW,
-                HttpLatencyDetector.REQUEST_LATENCY_IN_SECONDS_IN_WINDOW));
-        addEnricher(SensorTransformingEnricher.newInstanceTransforming(web, 
-                DynamicWebAppCluster.GROUP_SIZE, Functions.<Integer>identity(), APPSERVERS_COUNT));
-    }
-    
-}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/SingleWebServerSample.java
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/SingleWebServerSample.java b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/SingleWebServerSample.java
deleted file mode 100644
index 3cc9426..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/java/com/acme/sample/brooklyn/sample/app/SingleWebServerSample.java
+++ /dev/null
@@ -1,32 +0,0 @@
-package com.acme.sample.brooklyn.sample.app;
-
-import org.apache.brooklyn.api.entity.EntitySpec;
-import org.apache.brooklyn.core.entity.AbstractApplication;
-import org.apache.brooklyn.core.entity.Attributes;
-import org.apache.brooklyn.core.location.PortRanges;
-import org.apache.brooklyn.entity.webapp.JavaWebAppService;
-import org.apache.brooklyn.entity.webapp.jboss.JBoss7Server;
-import org.apache.brooklyn.util.maven.MavenArtifact;
-import org.apache.brooklyn.util.maven.MavenRetriever;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/** This example starts one web app on 8080. */
-public class SingleWebServerSample extends AbstractApplication {
-
-    public static final Logger LOG = LoggerFactory.getLogger(SingleWebServerSample.class);
-
-    public static final String DEFAULT_WAR_URL =
-            // can supply any URL -- this loads a stock example from maven central / sonatype
-            MavenRetriever.localUrl(MavenArtifact.fromCoordinate("io.brooklyn.example:brooklyn-example-hello-world-sql-webapp:war:0.5.0"));
-
-    /** Initialize our application. In this case it consists of 
-     *  a single JBoss entity, configured to run the WAR above. */
-    @Override
-    public void init() {
-        addChild(EntitySpec.create(JBoss7Server.class)
-                .configure(JavaWebAppService.ROOT_WAR, DEFAULT_WAR_URL)
-                .configure(Attributes.HTTP_PORT, PortRanges.fromString("8080+")));
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/logback-custom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/logback-custom.xml b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/logback-custom.xml
deleted file mode 100644
index 5a1ec98..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/logback-custom.xml
+++ /dev/null
@@ -1,10 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<included>
-
-    <!-- include everything in this project at debug level -->
-    <logger name="com.acme.sample.brooklyn" level="DEBUG"/>    
-    
-    <!-- logfile named after this project -->
-    <property name="logging.basename" scope="context" value="brooklyn-sample" />
-
-</included>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/sample-icon.png
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/sample-icon.png b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/sample-icon.png
deleted file mode 100644
index 542a1de..0000000
Binary files a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/sample-icon.png and /dev/null differ

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/visitors-creation-script.sql
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/visitors-creation-script.sql b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/visitors-creation-script.sql
deleted file mode 100644
index 0a805c4..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/main/resources/visitors-creation-script.sql
+++ /dev/null
@@ -1,35 +0,0 @@
---
--- Licensed to the Apache Software Foundation (ASF) under one
--- or more contributor license agreements.  See the NOTICE file
--- distributed with this work for additional information
--- regarding copyright ownership.  The ASF licenses this file
--- to you under the Apache License, Version 2.0 (the
--- "License"); you may not use this file except in compliance
--- with the License.  You may obtain a copy of the License at
---
---  http://www.apache.org/licenses/LICENSE-2.0
---
--- Unless required by applicable law or agreed to in writing,
--- software distributed under the License is distributed on an
--- "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
--- KIND, either express or implied.  See the License for the
--- specific language governing permissions and limitations
--- under the License.
---
-create database visitors;
-use visitors;
-create user 'brooklyn' identified by 'br00k11n';
-grant usage on *.* to 'brooklyn'@'%' identified by 'br00k11n';
-# ''@localhost is sometimes set up, overriding brooklyn@'%', so do a second explicit grant
-grant usage on *.* to 'brooklyn'@'localhost' identified by 'br00k11n';
-grant all privileges on visitors.* to 'brooklyn'@'%';
-flush privileges;
-
-CREATE TABLE MESSAGES (
-        id INT NOT NULL AUTO_INCREMENT,
-        NAME VARCHAR(30) NOT NULL,
-        MESSAGE VARCHAR(400) NOT NULL,
-        PRIMARY KEY (ID)
-    );
-
-INSERT INTO MESSAGES values (default, 'Isaac Asimov', 'I grew up in Brooklyn' );

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleLocalhostIntegrationTest.java
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleLocalhostIntegrationTest.java b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleLocalhostIntegrationTest.java
deleted file mode 100644
index f640f6a..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleLocalhostIntegrationTest.java
+++ /dev/null
@@ -1,81 +0,0 @@
-package com.acme.sample.brooklyn.sample.app;
-
-import java.util.Arrays;
-import java.util.Iterator;
-
-import org.apache.brooklyn.api.entity.Entity;
-import org.apache.brooklyn.api.entity.EntitySpec;
-import org.apache.brooklyn.api.mgmt.ManagementContext;
-import org.apache.brooklyn.core.mgmt.internal.LocalManagementContext;
-import org.apache.brooklyn.core.entity.Entities;
-import org.apache.brooklyn.core.entity.StartableApplication;
-import org.apache.brooklyn.entity.webapp.JavaWebAppService;
-import org.apache.brooklyn.util.core.ResourceUtils;
-import org.apache.brooklyn.util.text.Strings;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-import org.testng.Assert;
-import org.testng.annotations.AfterMethod;
-import org.testng.annotations.BeforeMethod;
-import org.testng.annotations.Test;
-
-/**
- * Sample integration tests which show how to launch the sample applications on localhost,
- * make some assertions about them, and then destroy them.
- */
-@Test(groups="Integration")
-public class SampleLocalhostIntegrationTest {
-
-    private static final Logger log = LoggerFactory.getLogger(SampleLocalhostIntegrationTest.class);
-    
-    private ManagementContext mgmt;
-
-    @BeforeMethod(alwaysRun=true)
-    public void setup() {
-        mgmt = new LocalManagementContext();
-    }
-
-    @AfterMethod(alwaysRun=true)
-    public void shutdown() {
-        if (mgmt != null) Entities.destroyAll(mgmt);
-    }
-
-
-    public void testSingle() {
-        StartableApplication app = mgmt.getEntityManager().createEntity(
-                EntitySpec.create(StartableApplication.class, SingleWebServerSample.class));
-        Entities.startManagement(app, mgmt);
-        Entities.start(app, Arrays.asList(mgmt.getLocationRegistry().resolve("localhost")));
-        
-        Iterator<Entity> children = app.getChildren().iterator();
-        if (!children.hasNext()) Assert.fail("Should have had a single JBoss child; had none");
-        
-        Entity web = children.next();
-        
-        if (children.hasNext()) Assert.fail("Should have had a single JBoss child; had too many: "+app.getChildren());
-        
-        String url = web.getAttribute(JavaWebAppService.ROOT_URL);
-        Assert.assertNotNull(url);
-        
-        String page = new ResourceUtils(this).getResourceAsString(url);
-        log.info("Read web page for "+app+" from "+url+":\n"+page);
-        Assert.assertTrue(!Strings.isBlank(page));
-    }
-
-    public void testCluster() {
-        StartableApplication app = mgmt.getEntityManager().createEntity(
-                EntitySpec.create(StartableApplication.class, ClusterWebServerDatabaseSample.class));
-        Entities.startManagement(app, mgmt);
-        Entities.start(app, Arrays.asList(mgmt.getLocationRegistry().resolve("localhost")));
-        
-        log.debug("APP is started");
-        
-        String url = app.getAttribute(JavaWebAppService.ROOT_URL);
-        Assert.assertNotNull(url);
-
-        String page = new ResourceUtils(this).getResourceAsString(url);
-        log.info("Read web page for "+app+" from "+url+":\n"+page);
-        Assert.assertTrue(!Strings.isBlank(page));
-    }
-    
-}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleUnitTest.java
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleUnitTest.java b/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleUnitTest.java
deleted file mode 100644
index 6a34301..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/brooklyn-sample/src/test/java/com/acme/sample/brooklyn/sample/app/SampleUnitTest.java
+++ /dev/null
@@ -1,69 +0,0 @@
-package com.acme.sample.brooklyn.sample.app;
-
-import org.apache.brooklyn.api.entity.Entity;
-import org.apache.brooklyn.api.entity.EntitySpec;
-import org.apache.brooklyn.api.mgmt.ManagementContext;
-import org.apache.brooklyn.core.mgmt.internal.LocalManagementContext;
-import org.apache.brooklyn.core.entity.Entities;
-import org.apache.brooklyn.core.entity.StartableApplication;
-import org.apache.brooklyn.entity.database.DatastoreMixins.DatastoreCommon;
-import org.apache.brooklyn.entity.database.mysql.MySqlNode;
-import org.apache.brooklyn.entity.webapp.JavaWebAppService;
-import org.apache.brooklyn.entity.webapp.WebAppService;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-import org.testng.Assert;
-import org.testng.annotations.AfterMethod;
-import org.testng.annotations.BeforeMethod;
-import org.testng.annotations.Test;
-
-import com.google.common.base.Predicates;
-import com.google.common.collect.Iterables;
-
-/** 
- * Unit tests for the sample applications defined in this project.
- * Shows how to examine the spec and make assertions about configuration.
- */
-@Test
-public class SampleUnitTest {
-
-    private static final Logger log = LoggerFactory.getLogger(SampleUnitTest.class);
-
-    
-    private ManagementContext mgmt;
-
-    @BeforeMethod(alwaysRun=true)
-    public void setup() {
-        mgmt = new LocalManagementContext();
-    }
-
-    @AfterMethod(alwaysRun=true)
-    public void shutdown() {
-        if (mgmt != null) Entities.destroyAll(mgmt);
-    }
-
-    
-    public void testSampleSingleStructure() {
-        StartableApplication app = mgmt.getEntityManager().createEntity(
-                EntitySpec.create(StartableApplication.class, SingleWebServerSample.class));
-        log.info("app from spec is: "+app);
-        
-        Assert.assertEquals(app.getChildren().size(), 1);
-        Assert.assertNotNull( app.getChildren().iterator().next().getConfig(JavaWebAppService.ROOT_WAR) );
-    }
-    
-    public void testSampleClusterStructure() {
-        StartableApplication app = mgmt.getEntityManager().createEntity(
-                EntitySpec.create(StartableApplication.class, ClusterWebServerDatabaseSample.class));
-        log.info("app from spec is: "+app);
-        
-        Assert.assertEquals(app.getChildren().size(), 2);
-        
-        Entity webappCluster = Iterables.find(app.getChildren(), Predicates.instanceOf(WebAppService.class));
-        Entity database = Iterables.find(app.getChildren(), Predicates.instanceOf(DatastoreCommon.class));
-        
-        Assert.assertNotNull( webappCluster.getConfig(JavaWebAppService.ROOT_WAR) );
-        Assert.assertNotNull( database.getConfig(MySqlNode.CREATION_SCRIPT_URL) );
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/archetypes/quickstart/src/main/resources/.gitignore
----------------------------------------------------------------------
diff --git a/brooklyn-dist/archetypes/quickstart/src/main/resources/.gitignore b/brooklyn-dist/archetypes/quickstart/src/main/resources/.gitignore
deleted file mode 100644
index 6d7b6a3..0000000
--- a/brooklyn-dist/archetypes/quickstart/src/main/resources/.gitignore
+++ /dev/null
@@ -1 +0,0 @@
-archetype-resources


[16/51] [abbrv] brooklyn-dist git commit: [ALL] update README file in each repo to be appropriate to that repo, with building instructions

Posted by he...@apache.org.
[ALL]  update README file in each repo to be appropriate to that repo, with building instructions


Project: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/repo
Commit: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/commit/445c9c15
Tree: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/tree/445c9c15
Diff: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/diff/445c9c15

Branch: refs/heads/master
Commit: 445c9c159f10111bbafbdd6e4a5d8e1c5987ed37
Parents: d0a6e70
Author: Alex Heneveld <al...@cloudsoftcorp.com>
Authored: Fri Dec 18 22:57:12 2015 +0000
Committer: Alex Heneveld <al...@cloudsoftcorp.com>
Committed: Mon Dec 21 16:43:37 2015 +0000

----------------------------------------------------------------------
 brooklyn-dist/README.md | 19 +++----------------
 1 file changed, 3 insertions(+), 16 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/445c9c15/brooklyn-dist/README.md
----------------------------------------------------------------------
diff --git a/brooklyn-dist/README.md b/brooklyn-dist/README.md
index 6b66cf2..0b34dc4 100644
--- a/brooklyn-dist/README.md
+++ b/brooklyn-dist/README.md
@@ -1,21 +1,8 @@
 
 # [![**Brooklyn**](https://brooklyn.apache.org/style/img/apache-brooklyn-logo-244px-wide.png)](http://brooklyn.apache.org/)
 
-### Apache Brooklyn helps to model, deploy, and manage systems.
+### Distribution Sub-Project for Apache Brooklyn
 
-It supports blueprints in YAML or Java, and deploys them to many clouds and other target environments.
-It monitors those deployments, maintains a live model, and runs autonomic policies to maintain their health.
+This repo contains modules for creating the distributable binary
+combining the `server`, the `ui`, and other elements in other Brooklyn repos.
 
-For more information see **[brooklyn.apache.org](https://brooklyn.apache.org/)**.
-
-
-### To Build
-
-The code can be built with a:
-
-    mvn clean install
-
-This creates a build in `usage/dist/target/brooklyn-dist`.  Run with `bin/brooklyn launch`.
-
-The **[developer guide](https://brooklyn.apache.org/v/latest/dev/)**
-has more information about the source code.


[31/51] [abbrv] brooklyn-dist git commit: add -SNAPSHOT handling - aborts starting brooklyn VM with a warning and pointer to README - README describes how to update the Vagrantfile to point at the desired -SNAPSHOT source

Posted by he...@apache.org.
add -SNAPSHOT handling
- aborts starting brooklyn VM with a warning and pointer to README
- README describes how to update the Vagrantfile to point at the desired -SNAPSHOT source


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

Branch: refs/heads/master
Commit: dcb2e2581a8fa46993bc658ceb49d00657ba350a
Parents: b1f392c
Author: John McCabe <jo...@johnmccabe.net>
Authored: Sun Jan 24 23:41:26 2016 +0000
Committer: John McCabe <jo...@johnmccabe.net>
Committed: Sun Jan 24 23:41:26 2016 +0000

----------------------------------------------------------------------
 .../vagrant/src/main/vagrant/README.md          | 63 ++++++++++++++++++++
 .../vagrant/src/main/vagrant/Vagrantfile        |  5 ++
 2 files changed, 68 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/dcb2e258/brooklyn-dist/vagrant/src/main/vagrant/README.md
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/README.md b/brooklyn-dist/vagrant/src/main/vagrant/README.md
new file mode 100644
index 0000000..b446ab8
--- /dev/null
+++ b/brooklyn-dist/vagrant/src/main/vagrant/README.md
@@ -0,0 +1,63 @@
+
+# [![**Brooklyn**](https://brooklyn.apache.org/style/img/apache-brooklyn-logo-244px-wide.png)](http://brooklyn.apache.org/)
+
+### Using Vagrant with Brooklyn -SNAPSHOT releases
+Due to the absence of a single source for snapshots (i.e. locally built vs. [periodically published archives](https://brooklyn.apache.org/v/0.9.0-SNAPSHOT/misc/download.html)), we require that you override the supplied `servers.yaml` to explicitly point at your desired `-SNAPSHOT` release.
+
+Full releases use the `BROOKLYN_VERSION` environment variable to download the associated `-bin` artifact from the closest Apache mirror, if this environment variable is set to a `-SNAPSHOT` we abort creating the Brooklyn Vagrant VM.
+
+##### Installing from local file
+For example to install from a locally built `-dist` archive:
+
+1. Copy the SNAPSHOT `-dist` archive to the same directory as the `Vagrantfile`
+
+   ```
+   cp  ~/Workspaces/incubator-brooklyn/brooklyn-dist/dist/target/brooklyn-dist-0.9.0-SNAPSHOT-dist.tar.gz .
+   ```
+
+2. Delete the `BROOKLYN_VERSION:` environment variable from `servers.yaml`. For example:
+
+   ```
+   env:
+     BROOKLYN_VERSION: 0.9.0-SNAPSHOT
+   ```
+
+3. Update `servers.yaml` to install from the `-dist` archive. For example, replace:
+   ```
+   - curl -s -S -J -O -L "https://www.apache.org/dyn/closer.cgi?action=download&filename=brooklyn/apache-brooklyn-${BROOKLYN_VERSION}/apache-brooklyn-${BROOKLYN_VERSION}-bin.tar.gz"
+   - tar zxf apache-brooklyn-${BROOKLYN_VERSION}-bin.tar.gz
+   - ln -s apache-brooklyn-${BROOKLYN_VERSION}-bin apache-brooklyn
+   ```
+   with:
+   ```
+   - cp /vagrant/brooklyn-dist-0.9.0-SNAPSHOT-dist.tar.gz .
+   - tar zxf brooklyn-dist-0.9.0-SNAPSHOT-dist.tar.gz
+   - ln -s brooklyn-dist-0.9.0-SNAPSHOT apache-brooklyn
+   ```
+
+4. You may proceed to use the `Vagrantfile` as normal; `vagrant up`, `vagrant destroy` etc.
+
+##### Installing from URL
+For example to install from a published `-SHAPSHOT` archive:
+
+1. Delete the `BROOKLYN_VERSION:` environment variable from `servers.yaml`. For example:
+
+   ```
+   env:
+     BROOKLYN_VERSION: 0.9.0-SNAPSHOT
+   ```
+
+2. Update `servers.yaml` to install from URL. For example, replace:
+   ```
+   - curl -s -S -J -O -L "https://www.apache.org/dyn/closer.cgi?action=download&filename=brooklyn/apache-brooklyn-${BROOKLYN_VERSION}/apache-brooklyn-${BROOKLYN_VERSION}-bin.tar.gz"
+   - tar zxf apache-brooklyn-${BROOKLYN_VERSION}-bin.tar.gz
+   - ln -s apache-brooklyn-${BROOKLYN_VERSION}-bin apache-brooklyn
+   ```
+   with:
+   ```
+   - curl -s -S -J -O -L "https://repository.apache.org/service/local/artifact/maven/redirect?r=snapshots&g=org.apache.brooklyn&a=brooklyn-dist&v=0.9.0-SNAPSHOT&c=dist&e=tar.gz"
+   - tar zxf brooklyn-dist-0.9.0-SNAPSHOT-dist.tar.gz
+   - ln -s brooklyn-dist-0.9.0-SNAPSHOT apache-brooklyn
+   ```
+
+3. You may proceed to use the `Vagrantfile` as normal; `vagrant up`, `vagrant destroy` etc.
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/dcb2e258/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile b/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
index 395e8bc..7f5dbb0 100644
--- a/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
+++ b/brooklyn-dist/vagrant/src/main/vagrant/Vagrantfile
@@ -38,6 +38,11 @@ Vagrant.configure(VAGRANTFILE_API_VERSION) do |config|
   # Iterate through server entries in YAML file
   yaml_cfg["servers"].each do |server|
     config.vm.define server["name"] do |server_config|
+
+      if server["shell"] && server["shell"]["env"]["BROOKLYN_VERSION"] =~ /SNAPSHOT/i
+        raise Vagrant::Errors::VagrantError.new, "Deploying Brooklyn SNAPSHOTS is not supported without a manual update to servers.yaml. See README for instructions."
+      end
+
       server_config.vm.box = server["box"]
 
       server_config.vm.box_check_update = yaml_cfg["default_config"]["check_newer_vagrant_box"]


[43/51] [abbrv] brooklyn-dist git commit: move subdir from incubator up a level as it is promoted to its own repo (first non-incubator commit!)

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/src/main/config/build-distribution.xml
----------------------------------------------------------------------
diff --git a/dist/src/main/config/build-distribution.xml b/dist/src/main/config/build-distribution.xml
new file mode 100644
index 0000000..f543292
--- /dev/null
+++ b/dist/src/main/config/build-distribution.xml
@@ -0,0 +1,95 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+    
+     http://www.apache.org/licenses/LICENSE-2.0
+    
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<assembly xmlns="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2 http://maven.apache.org/xsd/assembly-1.1.2.xsd">
+    <id>dist</id>
+    <formats><!-- empty, intended for caller to specify --></formats>
+    <fileSets>
+        <fileSet>
+            <directory>${project.basedir}/../..</directory>
+            <outputDirectory></outputDirectory>
+            <fileMode>0644</fileMode>
+            <directoryMode>0755</directoryMode>
+            <includes>
+                <include>DISCLAIMER*</include>
+            </includes>
+        </fileSet>
+        <fileSet>
+            <directory>${project.basedir}/src/main/license/files</directory>
+            <outputDirectory></outputDirectory>
+            <fileMode>0644</fileMode>
+            <directoryMode>0755</directoryMode>
+        </fileSet>
+        <fileSet>
+            <directory>${project.basedir}/src/main/dist/bin</directory>
+            <outputDirectory>bin</outputDirectory>
+            <fileMode>0755</fileMode>
+            <directoryMode>0755</directoryMode>
+        </fileSet>
+        <fileSet>
+            <!-- Add an empty dropins folder (so need to reference an existing dir, and exclude everything) -->
+            <directory>${project.basedir}/src/main/dist</directory>
+            <outputDirectory>lib/dropins</outputDirectory>
+            <directoryMode>0755</directoryMode>
+            <excludes>
+                <exclude>**/*</exclude>
+            </excludes>
+        </fileSet>
+        <fileSet>
+            <directory>${project.basedir}/target</directory>
+            <outputDirectory>conf/brooklyn</outputDirectory>
+            <fileMode>0644</fileMode>
+            <directoryMode>0755</directoryMode>
+            <includes>
+                <include>default.catalog.bom</include>
+            </includes>
+        </fileSet>
+        <fileSet>
+            <!-- Add an empty patch folder (so need to reference an existing dir, and exclude everything) -->
+            <directory>${project.basedir}/src/main/dist</directory>
+            <outputDirectory>lib/patch</outputDirectory>
+            <directoryMode>0755</directoryMode>
+            <excludes>
+                <exclude>**/*</exclude>
+            </excludes>
+        </fileSet>
+        <fileSet>
+            <directory>${project.basedir}/src/main/dist</directory>
+            <outputDirectory></outputDirectory>
+            <fileMode>0644</fileMode>
+            <directoryMode>0755</directoryMode>
+            <excludes>
+                <exclude>bin/*</exclude>
+            </excludes>
+        </fileSet>
+    </fileSets>
+    <!-- TODO include documentation -->
+    <!-- TODO include examples -->
+    <dependencySets>
+        <dependencySet>
+            <useProjectArtifact>false</useProjectArtifact>
+            <outputDirectory>lib/brooklyn</outputDirectory>
+            <fileMode>0644</fileMode>
+            <directoryMode>0755</directoryMode>
+            <outputFileNameMapping>${artifact.groupId}-${artifact.artifactId}-${artifact.version}${dashClassifier?}.${artifact.extension}</outputFileNameMapping>
+        </dependencySet>
+    </dependencySets>
+</assembly>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/src/main/dist/README.md
----------------------------------------------------------------------
diff --git a/dist/src/main/dist/README.md b/dist/src/main/dist/README.md
new file mode 100644
index 0000000..406bccd
--- /dev/null
+++ b/dist/src/main/dist/README.md
@@ -0,0 +1,17 @@
+
+# [![**Brooklyn**](https://brooklyn.apache.org/style/img/apache-brooklyn-logo-244px-wide.png)](http://brooklyn.apache.org/)
+
+### Apache Brooklyn
+
+This is the distribution of Apache Brooklyn.
+
+As a quick start, run:
+
+    ./bin/brooklyn launch
+
+For server CLI info, use:
+
+    ./bin/brooklyn help
+
+And to learn more, including the full user's guide, visit [brooklyn.apache.org](http://brooklyn.apache.org/).
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/src/main/dist/bin/.gitattributes
----------------------------------------------------------------------
diff --git a/dist/src/main/dist/bin/.gitattributes b/dist/src/main/dist/bin/.gitattributes
new file mode 100644
index 0000000..4e2b719
--- /dev/null
+++ b/dist/src/main/dist/bin/.gitattributes
@@ -0,0 +1,3 @@
+#Don't auto-convert line endings for shell scripts on Windows (breaks the scripts)
+brooklyn text eol=lf
+cloud-explorer text eol=lf

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/src/main/dist/bin/brooklyn
----------------------------------------------------------------------
diff --git a/dist/src/main/dist/bin/brooklyn b/dist/src/main/dist/bin/brooklyn
new file mode 100755
index 0000000..370bc93
--- /dev/null
+++ b/dist/src/main/dist/bin/brooklyn
@@ -0,0 +1,51 @@
+#!/usr/bin/env bash
+#
+# 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.
+#
+# Brooklyn
+#
+
+#set -x # debug
+
+# discover BROOKLYN_HOME if not set, by attempting to resolve absolute path of this command
+ROOT=$(cd "$(dirname "$0")/.." && pwd -P)
+if [ -z "$BROOKLYN_HOME" ] ; then
+    BROOKLYN_HOME=$(cd "$(dirname "$(readlink -f "$0" 2> /dev/null || readlink "$0" 2> /dev/null || echo "$0")")/.." && pwd)
+fi
+export ROOT BROOKLYN_HOME
+
+# use default memory settings, if not specified
+if [ -z "${JAVA_OPTS}" ] ; then
+    JAVA_OPTS="-Xms256m -Xmx1g -XX:MaxPermSize=256m"
+fi
+
+# set up the classpath
+INITIAL_CLASSPATH=${BROOKLYN_HOME}/conf:${BROOKLYN_HOME}/lib/patch/*:${BROOKLYN_HOME}/lib/brooklyn/*:${BROOKLYN_HOME}/lib/dropins/*
+# specify additional CP args in BROOKLYN_CLASSPATH
+if [ ! -z "${BROOKLYN_CLASSPATH}" ]; then
+    INITIAL_CLASSPATH=${BROOKLYN_CLASSPATH}:${INITIAL_CLASSPATH}
+fi
+export INITIAL_CLASSPATH
+
+# force resolution of localhost to be loopback, otherwise we hit problems
+# TODO should be changed in code
+JAVA_OPTS="-Dbrooklyn.location.localhost.address=127.0.0.1 ${JAVA_OPTS}"
+
+# start Brooklyn
+echo $$ > "$ROOT/pid_java"
+exec java ${JAVA_OPTS} -cp "${INITIAL_CLASSPATH}" org.apache.brooklyn.cli.Main "$@"

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/src/main/dist/bin/brooklyn.bat
----------------------------------------------------------------------
diff --git a/dist/src/main/dist/bin/brooklyn.bat b/dist/src/main/dist/bin/brooklyn.bat
new file mode 100644
index 0000000..90e300e
--- /dev/null
+++ b/dist/src/main/dist/bin/brooklyn.bat
@@ -0,0 +1,111 @@
+@echo off
+REM Licensed to the Apache Software Foundation (ASF) under one
+REM or more contributor license agreements.  See the NOTICE file
+REM distributed with this work for additional information
+REM regarding copyright ownership.  The ASF licenses this file
+REM to you under the Apache License, Version 2.0 (the
+REM "License"); you may not use this file except in compliance
+REM with the License.  You may obtain a copy of the License at
+REM 
+REM   http://www.apache.org/licenses/LICENSE-2.0
+REM 
+REM Unless required by applicable law or agreed to in writing,
+REM software distributed under the License is distributed on an
+REM "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+REM KIND, either express or implied.  See the License for the
+REM specific language governing permissions and limitations
+REM under the License.
+
+SETLOCAL EnableDelayedExpansion
+
+REM discover BROOKLYN_HOME if not set, by attempting to resolve absolute path of this command (brooklyn.bat)
+IF NOT DEFINED BROOKLYN_HOME (
+    SET "WORKING_FOLDER=%~dp0"
+    
+    REM stript trailing slash
+    SET "WORKING_FOLDER=!WORKING_FOLDER:~0,-1!"
+    
+    REM get parent folder (~dp works only for batch file params and loop indexes)
+    FOR %%i in ("!WORKING_FOLDER!") DO SET "BROOKLYN_HOME=%%~dpi"
+)
+
+REM Discover the location of Java.
+REM Use JAVA_HOME environment variable, if available;
+REM else, check the path;
+REM else, search registry for Java installations;
+REM else fail.
+
+IF DEFINED JAVA_HOME (
+    CALL :joinpath "%JAVA_HOME%" bin\java.exe JAVA_BIN
+)
+
+IF NOT DEFINED JAVA_BIN (
+    IF NOT DEFINED JAVA_HOME CALL :registry_home "HKLM\SOFTWARE\JavaSoft\Java Runtime Environment"
+    IF NOT DEFINED JAVA_HOME CALL :registry_home "HKLM\SOFTWARE\Wow6432Node\JavaSoft\Java Runtime Environment"
+    IF NOT DEFINED JAVA_HOME CALL :registry_home "HKLM\SOFTWARE\JavaSoft\Java Development Kit"
+    IF NOT DEFINED JAVA_HOME CALL :registry_home "HKLM\SOFTWARE\Wow6432Node\JavaSoft\Java Development Kit"
+    CALL :joinpath "!JAVA_HOME!" bin\java.exe JAVA_BIN
+)
+
+IF NOT DEFINED JAVA_BIN (
+    java.exe -version > NUL 2> NUL
+    echo !ERRORLEVEL!
+    IF NOT !ERRORLEVEL!==9009 SET JAVA_BIN=java.exe
+)
+
+IF NOT DEFINED JAVA_BIN (
+    echo "Unable to locate a Java installation. Please set JAVA_HOME or PATH environment variables."
+    exit /b 1
+) ELSE (
+    "%JAVA_BIN%" -version > NUL 2> NUL
+    IF !ERRORLEVEL!==9009 (
+        echo "java.exe does not exist where specified. Please check JAVA_HOME or PATH environment variables."
+        exit /b 1
+    )
+)
+
+REM use default memory settings, if not specified
+IF "%JAVA_OPTS%"=="" SET JAVA_OPTS=-Xms256m -Xmx500m -XX:MaxPermSize=256m
+
+REM set up the classpath
+SET INITIAL_CLASSPATH=%BROOKLYN_HOME%conf;%BROOKLYN_HOME%lib\patch\*;%BROOKLYN_HOME%lib\brooklyn\*;%BROOKLYN_HOME%lib\dropins\*
+REM specify additional CP args in BROOKLYN_CLASSPATH
+IF NOT "%BROOKLYN_CLASSPATH%"=="" SET "INITIAL_CLASSPATH=%BROOKLYN_CLASSPATH%;%INITIAL_CLASSPATH%"
+
+REM force resolution of localhost to be loopback, otherwise we hit problems
+REM TODO should be changed in code
+SET JAVA_OPTS=-Dbrooklyn.location.localhost.address=127.0.0.1 %JAVA_OPTS%
+
+REM workaround for http://bugs.sun.com/view_bug.do?bug_id=4787931
+SET JAVA_OPTS=-Duser.home="%USERPROFILE%" %JAVA_OPTS%
+
+REM start Brooklyn
+REM NO easy way to find process PID!!!
+pushd %BROOKLYN_HOME%
+
+"%JAVA_BIN%" %JAVA_OPTS% -cp "%INITIAL_CLASSPATH%" org.apache.brooklyn.cli.Main %*
+
+popd
+
+ENDLOCAL
+GOTO :EOF
+
+:joinpath
+    SET Path1=%~1
+    SET Path2=%~2
+    IF {%Path1:~-1,1%}=={\} (SET "%3=%Path1%%Path2%") ELSE (SET "%3=%Path1%\%Path2%")
+GOTO :EOF
+
+:whereis
+    REM Doesn't handle paths with quotes in the PATH variable
+    SET "%2=%~$PATH:1"
+GOTO :EOF
+
+:registry_value
+    FOR /F "skip=2 tokens=2*" %%A IN ('REG QUERY %1 /v %2 2^>nul') DO SET "%3=%%B"
+GOTO :EOF
+
+:registry_home
+    CALL :registry_value %1 CurrentVersion JAVA_VERSION
+    CALL :registry_value "%~1\%JAVA_VERSION%" JavaHome JAVA_HOME
+GOTO :EOF

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/src/main/dist/bin/brooklyn.ps1
----------------------------------------------------------------------
diff --git a/dist/src/main/dist/bin/brooklyn.ps1 b/dist/src/main/dist/bin/brooklyn.ps1
new file mode 100644
index 0000000..6780ed2
--- /dev/null
+++ b/dist/src/main/dist/bin/brooklyn.ps1
@@ -0,0 +1,135 @@
+#!ps1
+#
+# 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.
+#
+# Brooklyn
+#
+
+$ErrorActionPreference = "Stop";
+
+$ROOT = split-path -parent $MyInvocation.MyCommand.Definition
+
+# discover BROOKLYN_HOME if not set, by attempting to resolve absolute path of this command (brooklyn)
+if ( $env:BROOKLYN_HOME -eq $null ) {
+    $BROOKLYN_HOME = split-path -parent $ROOT
+} else {
+    $BROOKLYN_HOME = $env:BROOKLYN_HOME
+}
+
+# Discover the location of Java.
+# Use JAVA_HOME environment variable, if available;
+# else, search registry for Java installations;
+# else, check the path;
+# else fail.
+$bin = [System.IO.Path]::Combine("bin", "java.exe")
+if ( $env:JAVA_HOME -ne $null ) {
+    $javahome = $env:JAVA_HOME
+    $javabin = [System.IO.Path]::Combine($javahome, $bin)
+}
+if ( $javabin -eq $null ) {
+    $reglocations = ( 'HKLM:\SOFTWARE\JavaSoft\Java Runtime Environment',
+                      'HKLM:\SOFTWARE\Wow6432Node\JavaSoft\Java Runtime Environment' )
+    $jres = @{}
+    foreach ($loc in $reglocations) {
+        $item = Get-Item $loc -ErrorAction SilentlyContinue
+        if ($item -eq $null) { continue }
+        foreach ($key in Get-ChildItem $loc) {
+            $version = $key.PSChildName
+            $jrehome = $key.GetValue("JavaHome")
+            $jres.Add($version, $jrehome)
+        }
+    }
+    # TODO - this does a simple sort on the registry key name (the JRE version). This is not ideal - better would be
+    # to understand semantic versioning, filter out incompatible JREs (1.5 and earlier), prefer known good JREs (1.6
+    # or 1.7) and pick the highest patchlevel.
+    $last = ( $jres.Keys | Sort-Object | Select-Object -Last 1 )
+    if ( $last -ne $null ) {
+        $javahome = $jres.Get_Item($last)
+        $javabin = [System.IO.Path]::Combine($javahome, $bin)
+    }
+}
+if ( $javabin -eq $null ) {
+    $where = Get-Command "java.exe" -ErrorAction SilentlyContinue
+    if ( $where -ne $null ) {
+        $javabin = $where.Definition
+        $bindir = [System.IO.Path]::GetDirectoryName($javabin)
+        $javahome = [System.IO.Path]::GetDirectoryName($bindir)
+    }
+}
+
+if ( $javabin -eq $null ) {
+    throw "Unable to locate a Java installation. Please set JAVA_HOME or PATH environment variables."
+} elseif ( $( Get-Item $javabin -ErrorAction SilentlyContinue ) -eq $null ) {
+    throw "java.exe does not exist where specified. Please check JAVA_HOME or PATH environment variables."
+}
+
+# set up the classpath
+$cp = Get-ChildItem ${BROOKLYN_HOME}\conf | Select-Object -ExpandProperty FullName
+
+if ( Test-Path ${BROOKLYN_HOME}\lib\patch ) {
+    $cp += Get-ChildItem ${BROOKLYN_HOME}\lib\patch | Select-Object -ExpandProperty FullName
+}
+
+$cp += Get-ChildItem ${BROOKLYN_HOME}\lib\brooklyn | Select-Object -ExpandProperty FullName
+
+if ( Test-Path ${BROOKLYN_HOME}\lib\dropins ) {
+    $cp += Get-ChildItem ${BROOKLYN_HOME}\lib\dropins | Select-Object -ExpandProperty FullName
+}
+
+$INITIAL_CLASSPATH = $cp -join ';'
+
+# specify additional CP args in BROOKLYN_CLASSPATH
+if ( ! ( $env:BROOKLYN_CLASSPATH -eq $null )) {
+    $INITIAL_CLASSPATH = "$($INITIAL_CLASSPATH);$($env:BROOKLYN_CLASSPATH)"
+}
+
+# start to build up the arguments to the java invocation
+$javaargs = @()
+
+# add the user's java opts, or use default memory settings, if not specified
+if ( $env:JAVA_OPTS -eq $null ) {
+    $javaargs +="-Xms256m -Xmx1g -XX:MaxPermSize=256m"
+} else {
+    $javaargs +=$env:JAVA_OPTS
+}
+
+# force resolution of localhost to be loopback, otherwise we hit problems
+# TODO should be changed in code
+$javaargs += "-Dbrooklyn.localhost.address=127.0.0.1 $($JAVA_OPTS)"
+
+# workaround for http://bugs.sun.com/view_bug.do?bug_id=4787931
+$javaargs += "-Duser.home=`"$env:USERPROFILE`""
+
+# add the classpath
+$javaargs += "-cp"
+$javaargs += "`"$($INITIAL_CLASSPATH)`""
+
+# main class
+$javaargs += "org.apache.brooklyn.cli.Main"
+
+# copy in the arguments that were given to this script
+$javaargs += $args
+
+# start Brooklyn
+$process = Start-Process -FilePath $javabin -ArgumentList $javaargs -NoNewWindow -PassThru
+
+# save PID
+Set-Content -Path ${BROOKLYN_HOME}\pid_java -Value $($process.Id)
+
+# wait for it to finish
+$process.WaitForExit()

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/src/main/dist/conf/logback.xml
----------------------------------------------------------------------
diff --git a/dist/src/main/dist/conf/logback.xml b/dist/src/main/dist/conf/logback.xml
new file mode 100644
index 0000000..e70862c
--- /dev/null
+++ b/dist/src/main/dist/conf/logback.xml
@@ -0,0 +1,14 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<configuration>
+
+    <!-- to supply custom logging, either change this file, supply your own logback-main.xml 
+         (overriding the default provided on the classpath) or any of the files it references; 
+         see the Logging section of the Brooklyn web site for more information -->
+
+    <property name="logging.basename" scope="context" value="brooklyn" />
+    <property name="logging.dir" scope="context" value="./" />
+
+    <include resource="logback-main.xml"/>
+    
+</configuration>
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/src/main/license/README.md
----------------------------------------------------------------------
diff --git a/dist/src/main/license/README.md b/dist/src/main/license/README.md
new file mode 100644
index 0000000..0d3b52b
--- /dev/null
+++ b/dist/src/main/license/README.md
@@ -0,0 +1,2 @@
+See /usage/dist/licensing/README.md for an explanation of this directory.
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/dist/src/main/license/files/DISCLAIMER
----------------------------------------------------------------------
diff --git a/dist/src/main/license/files/DISCLAIMER b/dist/src/main/license/files/DISCLAIMER
new file mode 100644
index 0000000..9e6119b
--- /dev/null
+++ b/dist/src/main/license/files/DISCLAIMER
@@ -0,0 +1,8 @@
+
+Apache Brooklyn is an effort undergoing incubation at The Apache Software Foundation (ASF), 
+sponsored by the Apache Incubator. Incubation is required of all newly accepted projects until 
+a further review indicates that the infrastructure, communications, and decision making process 
+have stabilized in a manner consistent with other successful ASF projects. While incubation 
+status is not necessarily a reflection of the completeness or stability of the code, it does 
+indicate that the project has yet to be fully endorsed by the ASF.
+


[40/51] [abbrv] brooklyn-dist git commit: move subdir from incubator up a level as it is promoted to its own repo (first non-incubator commit!)

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/vagrant/pom.xml
----------------------------------------------------------------------
diff --git a/vagrant/pom.xml b/vagrant/pom.xml
new file mode 100644
index 0000000..fbe6539
--- /dev/null
+++ b/vagrant/pom.xml
@@ -0,0 +1,83 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+    
+     http://www.apache.org/licenses/LICENSE-2.0
+    
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+    <modelVersion>4.0.0</modelVersion>
+    <packaging>pom</packaging>
+
+    <artifactId>brooklyn-vagrant</artifactId>
+
+    <name>Brooklyn Vagrant Getting Started Environment</name>
+    <description>
+        Brooklyn Getting Started Vagrant environment archive, includes all required
+        files to start Brooklyn and sample BYON nodes for use.
+    </description>
+
+    <parent>
+        <groupId>org.apache.brooklyn</groupId>
+        <artifactId>brooklyn-dist-root</artifactId>
+        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+        <relativePath>../pom.xml</relativePath>
+    </parent>
+
+    <build>
+        <plugins>
+            <plugin>
+                <artifactId>maven-assembly-plugin</artifactId>
+                <executions>
+                    <execution>
+                        <id>build-distribution-archive</id>
+                        <phase>package</phase>
+                        <goals>
+                            <goal>single</goal>
+                        </goals>
+                        <configuration>
+                            <appendAssemblyId>true</appendAssemblyId>
+                            <descriptors>
+                                <descriptor>src/main/config/build-distribution.xml</descriptor>
+                            </descriptors>
+                          <!-- finalName affects name in `target/` but we cannot influence name when it is attached/installed,
+                               so `apache-` prefix would be lost there. to keep it consistent this is commented out, 
+                               but would be nice to have if there is a way!
+                            <finalName>apache-brooklyn-${project.version}</finalName>
+                          -->
+                            <formats>
+                                <format>tar.gz</format>
+                                <format>zip</format>
+                            </formats>
+                        </configuration>
+                    </execution>
+                </executions>
+            </plugin>
+        </plugins>
+        <pluginManagement>
+            <plugins>
+                <plugin>
+                    <groupId>org.apache.rat</groupId>
+                    <artifactId>apache-rat-plugin</artifactId>
+                    <configuration>
+                        <excludes combine.children="append">
+                            <exclude>src/main/vagrant/README.md</exclude>
+                        </excludes>
+                    </configuration>
+                </plugin>
+            </plugins>
+        </pluginManagement>
+    </build>
+</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/vagrant/src/main/config/build-distribution.xml
----------------------------------------------------------------------
diff --git a/vagrant/src/main/config/build-distribution.xml b/vagrant/src/main/config/build-distribution.xml
new file mode 100644
index 0000000..823ad2a
--- /dev/null
+++ b/vagrant/src/main/config/build-distribution.xml
@@ -0,0 +1,33 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+    
+     http://www.apache.org/licenses/LICENSE-2.0
+    
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<assembly xmlns="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2 http://maven.apache.org/xsd/assembly-1.1.2.xsd">
+    <id>dist</id>
+    <formats><!-- empty, intended for caller to specify --></formats>
+    <fileSets>
+        <fileSet>
+            <directory>${project.basedir}/src/main/vagrant</directory>
+            <outputDirectory></outputDirectory>
+            <fileMode>0644</fileMode>
+            <directoryMode>0755</directoryMode>
+        </fileSet>
+    </fileSets>
+</assembly>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/vagrant/src/main/vagrant/README.md
----------------------------------------------------------------------
diff --git a/vagrant/src/main/vagrant/README.md b/vagrant/src/main/vagrant/README.md
new file mode 100644
index 0000000..2f5573c
--- /dev/null
+++ b/vagrant/src/main/vagrant/README.md
@@ -0,0 +1,41 @@
+
+# [![**Brooklyn**](https://brooklyn.apache.org/style/img/apache-brooklyn-logo-244px-wide.png)](http://brooklyn.apache.org/)
+
+### Using Vagrant with Brooklyn -SNAPSHOT builds
+
+##### Install a community-managed version from Maven
+1. No action is required other than setting the  `BROOKLYN_VERSION:` environment variable in `servers.yaml` to a `-SNAPSHOT` version. For example:
+
+   ```
+   env:
+     BROOKLYN_VERSION: 0.9.0-SNAPSHOT
+   ```
+
+2. You may proceed to use the `Vagrantfile` as normal; `vagrant up`, `vagrant destroy` etc.
+
+##### Install a locally built `-dist.tar.gz`
+
+1. Set the `BROOKLYN_VERSION:` environment variable in `servers.yaml` to your current `-SNAPSHOT` version. For example:
+
+   ```
+   env:
+     BROOKLYN_VERSION: 0.9.0-SNAPSHOT
+   ```
+
+2. Set the `INSTALL_FROM_LOCAL_DIST:` environment variable in `servers.yaml` to `true`. For example:
+
+   ```
+   env:
+     INSTALL_FROM_LOCAL_DIST: true
+   ```
+
+
+3. Copy your locally built `-dist.tar.gz` archive to the same directory as the Vagrantfile (this directory is mounted in the Vagrant VM at `/vagrant/`).
+
+   For example to copy a locally built `0.9.0-SNAPSHOT` dist:
+
+   ```
+   cp ~/.m2/repository/org/apache/brooklyn/brooklyn-dist/0.9.0-SNAPSHOT/brooklyn-dist-0.9.0-SNAPSHOT-dist.tar.gz .
+   ```
+
+4. You may proceed to use the `Vagrantfile` as normal; `vagrant up`, `vagrant destroy` etc.
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/vagrant/src/main/vagrant/Vagrantfile
----------------------------------------------------------------------
diff --git a/vagrant/src/main/vagrant/Vagrantfile b/vagrant/src/main/vagrant/Vagrantfile
new file mode 100644
index 0000000..fb35a15
--- /dev/null
+++ b/vagrant/src/main/vagrant/Vagrantfile
@@ -0,0 +1,76 @@
+# -*- mode: ruby -*-
+# vi: set ft=ruby :
+#
+# 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.
+#
+
+# Specify minimum Vagrant version and Vagrant API version
+Vagrant.require_version ">= 1.8.1"
+VAGRANTFILE_API_VERSION = "2"
+
+# Update OS (Debian/RedHat based only)
+UPDATE_OS_CMD = "(sudo apt-get update && sudo apt-get -y upgrade) || (sudo yum -y update)"
+
+# Require YAML module
+require 'yaml'
+
+# Read YAML file with box details
+yaml_cfg = YAML.load_file(__dir__ + '/servers.yaml')
+
+# Create boxes
+Vagrant.configure(VAGRANTFILE_API_VERSION) do |config|
+
+  # Iterate through server entries in YAML file
+  yaml_cfg["servers"].each do |server|
+    config.vm.define server["name"] do |server_config|
+
+      server_config.vm.box = server["box"]
+
+      server_config.vm.box_check_update = yaml_cfg["default_config"]["check_newer_vagrant_box"]
+
+      if server.has_key?("ip")
+        server_config.vm.network "private_network", ip: server["ip"]
+      end
+
+      if server.has_key?("forwarded_ports")
+        server["forwarded_ports"].each do |ports|
+          server_config.vm.network "forwarded_port", guest: ports["guest"], host: ports["host"], guest_ip: ports["guest_ip"]
+        end
+      end
+
+      server_config.vm.hostname = server["name"]
+      server_config.vm.provider :virtualbox do |vb|
+        vb.name = server["name"]
+        vb.memory = server["ram"]
+        vb.cpus = server["cpus"]
+      end
+
+      if yaml_cfg["default_config"]["run_os_update"]
+        server_config.vm.provision "shell", privileged: false, inline: UPDATE_OS_CMD
+      end
+
+      if server["shell"] && server["shell"]["cmd"]
+        server["shell"]["cmd"].each do |cmd|
+          server_config.vm.provision "shell", privileged: false, inline: cmd, env: server["shell"]["env"]
+        end
+      end
+
+      server_config.vm.post_up_message = server["post_up_message"]
+    end
+  end
+end
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/vagrant/src/main/vagrant/files/brooklyn.properties
----------------------------------------------------------------------
diff --git a/vagrant/src/main/vagrant/files/brooklyn.properties b/vagrant/src/main/vagrant/files/brooklyn.properties
new file mode 100644
index 0000000..0784ff3
--- /dev/null
+++ b/vagrant/src/main/vagrant/files/brooklyn.properties
@@ -0,0 +1,23 @@
+#
+# 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.
+#
+
+# Disabling security on the Vagrant Brooklyn instance for training purposes
+brooklyn.webconsole.security.provider = org.apache.brooklyn.rest.security.provider.AnyoneSecurityProvider
+
+# Note: BYON locations are loaded from the files/vagrant-catalog.bom on startup
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/vagrant/src/main/vagrant/files/brooklyn.service
----------------------------------------------------------------------
diff --git a/vagrant/src/main/vagrant/files/brooklyn.service b/vagrant/src/main/vagrant/files/brooklyn.service
new file mode 100644
index 0000000..28b0fea
--- /dev/null
+++ b/vagrant/src/main/vagrant/files/brooklyn.service
@@ -0,0 +1,32 @@
+#
+# 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.
+#
+
+[Unit]
+Description=Apache Brooklyn service
+Documentation=http://brooklyn.apache.org/documentation/index.html
+
+[Service]
+ExecStart=/home/vagrant/apache-brooklyn/bin/brooklyn launch --persist auto --persistenceDir /vagrant/brooklyn-persisted-state --catalogAdd /vagrant/files/vagrant-catalog.bom
+WorkingDirectory=/home/vagrant/apache-brooklyn
+Restart=on-abort
+User=vagrant
+Group=vagrant
+
+[Install]
+WantedBy=multi-user.target

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/vagrant/src/main/vagrant/files/install_brooklyn.sh
----------------------------------------------------------------------
diff --git a/vagrant/src/main/vagrant/files/install_brooklyn.sh b/vagrant/src/main/vagrant/files/install_brooklyn.sh
new file mode 100755
index 0000000..9c52017
--- /dev/null
+++ b/vagrant/src/main/vagrant/files/install_brooklyn.sh
@@ -0,0 +1,92 @@
+#!/usr/bin/env bash
+
+#
+# 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.
+#
+
+BROOKLYN_VERSION=""
+INSTALL_FROM_LOCAL_DIST="false"
+TMP_ARCHIVE_NAME=apache-brooklyn.tar.gz
+
+do_help() {
+  echo "./install.sh -v <Brooklyn Version> [-l <install from local file: true|false>]"
+  exit 1
+}
+
+while getopts ":hv:l:" opt; do
+    case "$opt" in
+    v)  BROOKLYN_VERSION=$OPTARG ;;
+        # using a true/false argopt rather than just flag to allow easier integration with servers.yaml config
+    l)  INSTALL_FROM_LOCAL_DIST=$OPTARG ;;
+    h)  do_help;;
+    esac
+done
+
+# Exit if any step fails
+set -e
+
+if [ "x${BROOKLYN_VERSION}" == "x" ]; then
+  echo "Error: you must supply a Brooklyn version [-v]"
+  do_help
+fi
+
+if [ ! "${INSTALL_FROM_LOCAL_DIST}" == "true" ]; then
+  if [ ! -z "${BROOKLYN_VERSION##*-SNAPSHOT}" ] ; then
+    # url for official release versions
+    BROOKLYN_URL="https://www.apache.org/dyn/closer.lua?action=download&filename=brooklyn/apache-brooklyn-${BROOKLYN_VERSION}/apache-brooklyn-${BROOKLYN_VERSION}-bin.tar.gz"
+    BROOKLYN_DIR="apache-brooklyn-${BROOKLYN_VERSION}-bin"
+  else
+    # url for community-managed snapshots
+    BROOKLYN_URL="https://repository.apache.org/service/local/artifact/maven/redirect?r=snapshots&g=org.apache.brooklyn&a=brooklyn-dist&v=${BROOKLYN_VERSION}&c=dist&e=tar.gz"
+    BROOKLYN_DIR="brooklyn-dist-${BROOKLYN_VERSION}"
+  fi
+else
+  echo "Installing from a local -dist archive [ /vagrant/brooklyn-dist-${BROOKLYN_VERSION}-dist.tar.gz]"
+  # url to install from mounted /vagrant dir
+  BROOKLYN_URL="file:///vagrant/brooklyn-dist-${BROOKLYN_VERSION}-dist.tar.gz"
+  BROOKLYN_DIR="brooklyn-dist-${BROOKLYN_VERSION}"
+
+  # ensure local file exists
+  if [ ! -f /vagrant/brooklyn-dist-${BROOKLYN_VERSION}-dist.tar.gz ]; then
+    echo "Error: file not found /vagrant/brooklyn-dist-${BROOKLYN_VERSION}-dist.tar.gz"
+    exit 1
+  fi
+fi
+
+echo "Installing Apache Brooklyn version ${BROOKLYN_VERSION} from [${BROOKLYN_URL}]"
+
+echo "Downloading Brooklyn release archive"
+curl --fail --silent --show-error --location --output ${TMP_ARCHIVE_NAME} "${BROOKLYN_URL}"
+echo "Extracting Brooklyn release archive"
+tar zxf ${TMP_ARCHIVE_NAME}
+
+echo "Creating Brooklyn dirs and symlinks"
+ln -s ${BROOKLYN_DIR} apache-brooklyn
+sudo mkdir -p /var/log/brooklyn
+sudo chown -R vagrant:vagrant /var/log/brooklyn
+mkdir -p /home/vagrant/.brooklyn
+
+echo "Copying default vagrant Brooklyn properties file"
+cp /vagrant/files/brooklyn.properties /home/vagrant/.brooklyn/
+chmod 600 /home/vagrant/.brooklyn/brooklyn.properties
+
+echo "Installing JRE"
+sudo sh -c 'export DEBIAN_FRONTEND=noninteractive; apt-get install --yes openjdk-8-jre-headless'
+
+echo "Copying Brooklyn systemd service unit file"
+sudo cp /vagrant/files/brooklyn.service /etc/systemd/system/brooklyn.service
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/vagrant/src/main/vagrant/files/logback.xml
----------------------------------------------------------------------
diff --git a/vagrant/src/main/vagrant/files/logback.xml b/vagrant/src/main/vagrant/files/logback.xml
new file mode 100644
index 0000000..1560d8b
--- /dev/null
+++ b/vagrant/src/main/vagrant/files/logback.xml
@@ -0,0 +1,32 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+
+<configuration scan="true">
+
+    <!-- to supply custom logging, either change this file, supply your own logback-main.xml
+         (overriding the default provided on the classpath) or any of the files it references;
+         see the Logging section of the Brooklyn web site for more information -->
+
+    <property name="logging.basename" scope="context" value="brooklyn" />
+    <property name="logging.dir" scope="context" value="/var/log/brooklyn/" />
+
+    <include resource="logback-main.xml"/>
+
+</configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/vagrant/src/main/vagrant/files/vagrant-catalog.bom
----------------------------------------------------------------------
diff --git a/vagrant/src/main/vagrant/files/vagrant-catalog.bom b/vagrant/src/main/vagrant/files/vagrant-catalog.bom
new file mode 100644
index 0000000..d8b8450
--- /dev/null
+++ b/vagrant/src/main/vagrant/files/vagrant-catalog.bom
@@ -0,0 +1,82 @@
+#
+# 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.
+#
+brooklyn.catalog:
+  items:
+  - id: byon1
+    name: Vagrant BYON VM 1
+    version: 0.9.0-SNAPSHOT  # BROOKLYN_VERSION
+    itemType: location
+    item:
+      type: byon
+      brooklyn.config:
+        user: vagrant
+        password: vagrant
+        hosts:
+        - 10.10.10.101
+
+  - id: byon2
+    name: Vagrant BYON VM 2
+    version: 0.9.0-SNAPSHOT  # BROOKLYN_VERSION
+    itemType: location
+    item:
+      type: byon
+      brooklyn.config:
+        user: vagrant
+        password: vagrant
+        hosts:
+        - 10.10.10.102
+
+  - id: byon3
+    name: Vagrant BYON VM 3
+    version: 0.9.0-SNAPSHOT  # BROOKLYN_VERSION
+    itemType: location
+    item:
+      type: byon
+      brooklyn.config:
+        user: vagrant
+        password: vagrant
+        hosts:
+        - 10.10.10.103
+
+  - id: byon4
+    name: Vagrant BYON VM 4
+    version: 0.9.0-SNAPSHOT  # BROOKLYN_VERSION
+    itemType: location
+    item:
+      type: byon
+      brooklyn.config:
+        user: vagrant
+        password: vagrant
+        hosts:
+        - 10.10.10.104
+
+  - id: byon-all
+    name: Vagrant BYON VM 1-4
+    version: 0.9.0-SNAPSHOT  # BROOKLYN_VERSION
+    itemType: location
+    item:
+      type: byon
+      brooklyn.config:
+        user: vagrant
+        password: vagrant
+        hosts:
+        - 10.10.10.101
+        - 10.10.10.102
+        - 10.10.10.103
+        - 10.10.10.104

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/vagrant/src/main/vagrant/servers.yaml
----------------------------------------------------------------------
diff --git a/vagrant/src/main/vagrant/servers.yaml b/vagrant/src/main/vagrant/servers.yaml
new file mode 100644
index 0000000..3959fff
--- /dev/null
+++ b/vagrant/src/main/vagrant/servers.yaml
@@ -0,0 +1,73 @@
+#
+# 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.
+#
+#
+# Default Config
+#   check_newer_vagrant_box
+#     enable/disable the vagrant check for an updated box
+#   run_os_update
+#     enable/disable running a yum/apt-get update on box start
+#
+# Brooklyn Server Config
+#   shell:env:BROOKLYN_VERSION
+#     specifies the version of Brooklyn to install, be aware that for SNAPSHOTS you
+#     may wish to download a local -dist.tar.gz for the latest version.
+#   shell:env:INSTALL_FROM_LOCAL_DIST
+#     if set to `true` Vagrant will install from a local -dist.tar.gz stored in /vagrant
+#     on the guest VM (which is mounted from the Vagrantfile directory). You must
+#     ensure that a -dist.tar.gz archive has been copied to this directory on your host.
+
+---
+default_config:
+    check_newer_vagrant_box: true
+    run_os_update: true
+servers:
+  - name: brooklyn
+    box: ubuntu/vivid64
+    ram: 2048
+    cpus: 4
+    ip: 10.10.10.100
+    shell:
+      env:
+        BROOKLYN_VERSION: 0.9.0-SNAPSHOT
+        INSTALL_FROM_LOCAL_DIST: false
+      cmd:
+        - /vagrant/files/install_brooklyn.sh -v ${BROOKLYN_VERSION} -l ${INSTALL_FROM_LOCAL_DIST}
+        - sudo systemctl start brooklyn
+        - sudo systemctl enable brooklyn
+  - name: byon1
+    box: ubuntu/vivid64
+    ram: 512
+    cpus: 2
+    ip: 10.10.10.101
+  - name: byon2
+    box: ubuntu/vivid64
+    ram: 512
+    cpus: 2
+    ip: 10.10.10.102
+  - name: byon3
+    box: ubuntu/vivid64
+    ram: 512
+    cpus: 2
+    ip: 10.10.10.103
+  - name: byon4
+    box: ubuntu/vivid64
+    ram: 512
+    cpus: 2
+    ip: 10.10.10.104
+...


[19/51] [abbrv] brooklyn-dist git commit: [DIST] reparent the downstream project so it doesn't get rat check, plus comments

Posted by he...@apache.org.
[DIST] reparent the downstream project so it doesn't get rat check, plus comments


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

Branch: refs/heads/master
Commit: 9d9e2cedd88bd952448d99078ec4d4aca263044e
Parents: ff5a57c
Author: Alex Heneveld <al...@cloudsoftcorp.com>
Authored: Mon Dec 21 11:18:03 2015 +0000
Committer: Alex Heneveld <al...@cloudsoftcorp.com>
Committed: Mon Dec 21 16:43:39 2015 +0000

----------------------------------------------------------------------
 brooklyn-dist/downstream-parent/pom.xml | 9 +++++++--
 1 file changed, 7 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/9d9e2ced/brooklyn-dist/downstream-parent/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/downstream-parent/pom.xml b/brooklyn-dist/downstream-parent/pom.xml
index e8f4fe0..9b7cc73 100644
--- a/brooklyn-dist/downstream-parent/pom.xml
+++ b/brooklyn-dist/downstream-parent/pom.xml
@@ -22,9 +22,14 @@
 
   <parent>
     <groupId>org.apache.brooklyn</groupId>
-    <artifactId>brooklyn-dist-root</artifactId>
+    <artifactId>brooklyn-server</artifactId>
     <version>0.9.SPLITWIP-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-    <relativePath>../pom.xml</relativePath>
+    <relativePath>../../brooklyn-server/pom.xml</relativePath>
+    <!-- TODO this uses server root pom as a way to get version info without rat check;
+         it means it inherits apache pom, which might not be desired.
+         probably cleaner NOT to have a downstream-parent, instead for project to redeclare their tasks.
+         (yes it violates DRY, but until Maven 4 supporting Mixins that is probably better than
+         hacks in a parent hierarchy to which people won't have visibility. -->
   </parent>
 
   <artifactId>brooklyn-downstream-parent</artifactId>


[48/51] [abbrv] brooklyn-dist git commit: move subdir from incubator up a level as it is promoted to its own repo (first non-incubator commit!)

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/binary/jtidy
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/jtidy b/brooklyn-dist/dist/licensing/licenses/binary/jtidy
deleted file mode 100644
index 0bcb614..0000000
--- a/brooklyn-dist/dist/licensing/licenses/binary/jtidy
+++ /dev/null
@@ -1,53 +0,0 @@
-JTidy License
-
-  Java HTML Tidy - JTidy
-  HTML parser and pretty printer
-  
-  Copyright (c) 1998-2000 World Wide Web Consortium (Massachusetts
-  Institute of Technology, Institut National de Recherche en
-  Informatique et en Automatique, Keio University). All Rights
-  Reserved.
-  
-  Contributing Author(s):
-  
-     Dave Raggett <ds...@w3.org>
-     Andy Quick <ac...@sympatico.ca> (translation to Java)
-     Gary L Peskin <ga...@firstech.com> (Java development)
-     Sami Lempinen <sa...@lempinen.net> (release management)
-     Fabrizio Giustina <fgiust at users.sourceforge.net>
-  
-  The contributing author(s) would like to thank all those who
-  helped with testing, bug fixes, and patience.  This wouldn't
-  have been possible without all of you.
-  
-  COPYRIGHT NOTICE:
-   
-  This software and documentation is provided "as is," and
-  the copyright holders and contributing author(s) make no
-  representations or warranties, express or implied, including
-  but not limited to, warranties of merchantability or fitness
-  for any particular purpose or that the use of the software or
-  documentation will not infringe any third party patents,
-  copyrights, trademarks or other rights. 
-  
-  The copyright holders and contributing author(s) will not be
-  liable for any direct, indirect, special or consequential damages
-  arising out of any use of the software or documentation, even if
-  advised of the possibility of such damage.
-  
-  Permission is hereby granted to use, copy, modify, and distribute
-  this source code, or portions hereof, documentation and executables,
-  for any purpose, without fee, subject to the following restrictions:
-  
-  1. The origin of this source code must not be misrepresented.
-  2. Altered versions must be plainly marked as such and must
-     not be misrepresented as being the original source.
-  3. This Copyright notice may not be removed or altered from any
-     source or altered source distribution.
-   
-  The copyright holders and contributing author(s) specifically
-  permit, without fee, and encourage the use of this source code
-  as a component for supporting the Hypertext Markup Language in
-  commercial products. If you use this source code in a product,
-  acknowledgment is not required but would be appreciated.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/binary/jython
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/jython b/brooklyn-dist/dist/licensing/licenses/binary/jython
deleted file mode 100644
index b2258d4..0000000
--- a/brooklyn-dist/dist/licensing/licenses/binary/jython
+++ /dev/null
@@ -1,27 +0,0 @@
-Jython License
-
-  Jython 2.0, 2.1 License
-  
-  Copyright (c) 2000, 2001, 2002, 2003, 2004, 2005, 2006, 2007 Jython Developers All rights reserved.
-  
-  Redistribution and use in source and binary forms, with or without modification, are permitted provided 
-  that the following conditions are met:
-  
-  Redistributions of source code must retain the above copyright notice, this list of conditions and the 
-  following disclaimer.
-  
-  Redistributions in binary form must reproduce the above copyright notice, this list of conditions and 
-  the following disclaimer in the documentation and/or other materials provided with the distribution.
-  Neither the name of the Jython Developers nor the names of its contributors may be used to endorse or 
-  promote products derived from this software without specific prior written permission.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS'' AND ANY EXPRESS OR IMPLIED 
-  WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A 
-  PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE REGENTS OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
-  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO, 
-  PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) 
-  HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING 
-  NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
-  POSSIBILITY OF SUCH DAMAGE.
-  
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/binary/metastuff-bsd-style
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/metastuff-bsd-style b/brooklyn-dist/dist/licensing/licenses/binary/metastuff-bsd-style
deleted file mode 100644
index 6bb4ef6..0000000
--- a/brooklyn-dist/dist/licensing/licenses/binary/metastuff-bsd-style
+++ /dev/null
@@ -1,43 +0,0 @@
-MetaStuff BSD Style License
-
-  Copyright 2001-2005 (C) MetaStuff, Ltd. All Rights Reserved.
-  
-  Redistribution and use of this software and associated documentation
-  ("Software"), with or without modification, are permitted provided
-  that the following conditions are met:
-  
-  1. Redistributions of source code must retain copyright
-     statements and notices.  Redistributions must also contain a
-     copy of this document.
-  
-  2. Redistributions in binary form must reproduce the
-     above copyright notice, this list of conditions and the
-     following disclaimer in the documentation and/or other
-     materials provided with the distribution.
-  
-  3. The name "DOM4J" must not be used to endorse or promote
-     products derived from this Software without prior written
-     permission of MetaStuff, Ltd.  For written permission,
-     please contact dom4j-info@metastuff.com.
-  
-  4. Products derived from this Software may not be called "DOM4J"
-     nor may "DOM4J" appear in their names without prior written
-     permission of MetaStuff, Ltd. DOM4J is a registered
-     trademark of MetaStuff, Ltd.
-  
-  5. Due credit should be given to the DOM4J Project -
-     http://www.dom4j.org
-  
-  THIS SOFTWARE IS PROVIDED BY METASTUFF, LTD. AND CONTRIBUTORS
-  ``AS IS'' AND ANY EXPRESSED OR IMPLIED WARRANTIES, INCLUDING, BUT
-  NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND
-  FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED.  IN NO EVENT SHALL
-  METASTUFF, LTD. OR ITS CONTRIBUTORS BE LIABLE FOR ANY DIRECT,
-  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES
-  (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
-  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION)
-  HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT,
-  STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE)
-  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED
-  OF THE POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/binary/xpp3_indiana_university
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/xpp3_indiana_university b/brooklyn-dist/dist/licensing/licenses/binary/xpp3_indiana_university
deleted file mode 100644
index 7d69a29..0000000
--- a/brooklyn-dist/dist/licensing/licenses/binary/xpp3_indiana_university
+++ /dev/null
@@ -1,45 +0,0 @@
-Indiana University Extreme! Lab Software License, Version 1.1.1
-
-  Copyright (c) 2002 Extreme! Lab, Indiana University. All rights reserved.
-  
-  Redistribution and use in source and binary forms, with or without
-  modification, are permitted provided that the following conditions
-  are met:
-  
-  1. Redistributions of source code must retain the above copyright notice,
-     this list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright
-     notice, this list of conditions and the following disclaimer in
-     the documentation and/or other materials provided with the distribution.
-  
-  3. The end-user documentation included with the redistribution, if any,
-     must include the following acknowledgment:
-  
-    "This product includes software developed by the Indiana University
-    Extreme! Lab (http://www.extreme.indiana.edu/)."
-  
-  Alternately, this acknowledgment may appear in the software itself,
-  if and wherever such third-party acknowledgments normally appear.
-  
-  4. The names "Indiana Univeristy" and "Indiana Univeristy Extreme! Lab"
-  must not be used to endorse or promote products derived from this
-  software without prior written permission. For written permission,
-  please contact http://www.extreme.indiana.edu/.
-  
-  5. Products derived from this software may not use "Indiana Univeristy"
-  name nor may "Indiana Univeristy" appear in their name, without prior
-  written permission of the Indiana University.
-  
-  THIS SOFTWARE IS PROVIDED "AS IS" AND ANY EXPRESSED OR IMPLIED
-  WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF
-  MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED.
-  IN NO EVENT SHALL THE AUTHORS, COPYRIGHT HOLDERS OR ITS CONTRIBUTORS
-  BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR
-  CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF
-  SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR PROFITS; OR
-  BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY,
-  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR
-  OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF
-  ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/BSD-2-Clause
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/BSD-2-Clause b/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/BSD-2-Clause
deleted file mode 100644
index 832c10e..0000000
--- a/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/BSD-2-Clause
+++ /dev/null
@@ -1,23 +0,0 @@
-The BSD 2-Clause License
-
-  Redistribution and use in source and binary forms, with or without
-  modification, are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, this
-  list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice,
-  this list of conditions and the following disclaimer in the documentation
-  and/or other materials provided with the distribution.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
-  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
-  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
-  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
-  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
-  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
-  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
-  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/BSD-3-Clause
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/BSD-3-Clause b/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/BSD-3-Clause
deleted file mode 100644
index be2692c..0000000
--- a/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/BSD-3-Clause
+++ /dev/null
@@ -1,27 +0,0 @@
-The BSD 3-Clause License ("New BSD")
-
-  Redistribution and use in source and binary forms, with or without modification,
-  are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, 
-  this list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice, 
-  this list of conditions and the following disclaimer in the documentation 
-  and/or other materials provided with the distribution.
-  
-  3. Neither the name of the copyright holder nor the names of its contributors 
-  may be used to endorse or promote products derived from this software without 
-  specific prior written permission.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
-  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
-  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
-  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
-  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
-  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
-  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
-  POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/MIT
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/MIT b/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/MIT
deleted file mode 100644
index 71dfb45..0000000
--- a/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/MIT
+++ /dev/null
@@ -1,20 +0,0 @@
-The MIT License ("MIT")
-
-  Permission is hereby granted, free of charge, to any person obtaining a copy
-  of this software and associated documentation files (the "Software"), to deal
-  in the Software without restriction, including without limitation the rights
-  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
-  copies of the Software, and to permit persons to whom the Software is
-  furnished to do so, subject to the following conditions:
-  
-  The above copyright notice and this permission notice shall be included in
-  all copies or substantial portions of the Software.
-  
-  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
-  THE SOFTWARE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/server-cli/MIT
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/server-cli/MIT b/brooklyn-dist/dist/licensing/licenses/server-cli/MIT
deleted file mode 100644
index 71dfb45..0000000
--- a/brooklyn-dist/dist/licensing/licenses/server-cli/MIT
+++ /dev/null
@@ -1,20 +0,0 @@
-The MIT License ("MIT")
-
-  Permission is hereby granted, free of charge, to any person obtaining a copy
-  of this software and associated documentation files (the "Software"), to deal
-  in the Software without restriction, including without limitation the rights
-  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
-  copies of the Software, and to permit persons to whom the Software is
-  furnished to do so, subject to the following conditions:
-  
-  The above copyright notice and this permission notice shall be included in
-  all copies or substantial portions of the Software.
-  
-  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
-  THE SOFTWARE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/source/BSD-2-Clause
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/source/BSD-2-Clause b/brooklyn-dist/dist/licensing/licenses/source/BSD-2-Clause
deleted file mode 100644
index 832c10e..0000000
--- a/brooklyn-dist/dist/licensing/licenses/source/BSD-2-Clause
+++ /dev/null
@@ -1,23 +0,0 @@
-The BSD 2-Clause License
-
-  Redistribution and use in source and binary forms, with or without
-  modification, are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, this
-  list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice,
-  this list of conditions and the following disclaimer in the documentation
-  and/or other materials provided with the distribution.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
-  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
-  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
-  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
-  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
-  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
-  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
-  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/source/BSD-3-Clause
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/source/BSD-3-Clause b/brooklyn-dist/dist/licensing/licenses/source/BSD-3-Clause
deleted file mode 100644
index be2692c..0000000
--- a/brooklyn-dist/dist/licensing/licenses/source/BSD-3-Clause
+++ /dev/null
@@ -1,27 +0,0 @@
-The BSD 3-Clause License ("New BSD")
-
-  Redistribution and use in source and binary forms, with or without modification,
-  are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, 
-  this list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice, 
-  this list of conditions and the following disclaimer in the documentation 
-  and/or other materials provided with the distribution.
-  
-  3. Neither the name of the copyright holder nor the names of its contributors 
-  may be used to endorse or promote products derived from this software without 
-  specific prior written permission.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
-  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
-  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
-  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
-  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
-  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
-  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
-  POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/licenses/source/MIT
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/source/MIT b/brooklyn-dist/dist/licensing/licenses/source/MIT
deleted file mode 100644
index 71dfb45..0000000
--- a/brooklyn-dist/dist/licensing/licenses/source/MIT
+++ /dev/null
@@ -1,20 +0,0 @@
-The MIT License ("MIT")
-
-  Permission is hereby granted, free of charge, to any person obtaining a copy
-  of this software and associated documentation files (the "Software"), to deal
-  in the Software without restriction, including without limitation the rights
-  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
-  copies of the Software, and to permit persons to whom the Software is
-  furnished to do so, subject to the following conditions:
-  
-  The above copyright notice and this permission notice shall be included in
-  all copies or substantial portions of the Software.
-  
-  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
-  THE SOFTWARE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/make-all-licenses.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/make-all-licenses.sh b/brooklyn-dist/dist/licensing/make-all-licenses.sh
deleted file mode 100755
index b08d17f..0000000
--- a/brooklyn-dist/dist/licensing/make-all-licenses.sh
+++ /dev/null
@@ -1,65 +0,0 @@
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#  http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-# generates LICENSE files for source and binary,
-# and for each of `projects-with-custom-licenses`
-
-set -e
-
-# update the extras-files file from projects-with-custom-licenses
-cat projects-with-custom-licenses | awk '{ printf("%s/src/main/license/source-inclusions.yaml:", $0); }' | sed 's/:$//' > extras-files
-
-unset BROOKLYN_LICENSE_SPECIALS
-unset BROOKLYN_LICENSE_EXTRAS_FILES
-unset BROOKLYN_LICENSE_MODE
-
-# source build, at root and each sub-project
-export BROOKLYN_LICENSE_MODE=source
-echo MAKING LICENSES FOR: ${BROOKLYN_LICENSE_MODE}
-export BROOKLYN_LICENSE_SPECIALS=-DonlyExtras=true 
-./make-one-license.sh > LICENSE.autogenerated
-cp LICENSE.autogenerated ../../../LICENSE
-# overwrite any existing licenses at root
-for x in ../../../brooklyn-*/LICENSE ; do cp LICENSE.autogenerated $x ; done
-unset BROOKLYN_LICENSE_SPECIALS
-unset BROOKLYN_LICENSE_MODE
-
-# binary build, in dist
-export BROOKLYN_LICENSE_MODE=binary
-echo MAKING LICENSES FOR: ${BROOKLYN_LICENSE_MODE}
-./make-one-license.sh > LICENSE.autogenerated
-cp LICENSE.autogenerated ../src/main/license/files/LICENSE
-unset BROOKLYN_LICENSE_MODE
-
-# individual projects
-for x in `cat projects-with-custom-licenses` ; do
-  export BROOKLYN_LICENSE_MODE=`basename $x`
-  echo MAKING LICENSES FOR: ${BROOKLYN_LICENSE_MODE}
-  export BROOKLYN_LICENSE_SPECIALS=-DonlyExtras=true
-  export BROOKLYN_LICENSE_EXTRAS_FILES=$x/src/main/license/source-inclusions.yaml
-  cp licenses/`basename $x`/* licenses/source
-  ./make-one-license.sh > LICENSE.autogenerated || ( echo FAILED. See details in tmp_stdout/err. && false )
-  cp LICENSE.autogenerated ../$x/src/main/license/files/LICENSE
-  # also copy to root of that project *if* there is already a LICENSE file there
-  [ -f ../$x/LICENSE ] && cp LICENSE.autogenerated ../$x/LICENSE || true
-  unset BROOKLYN_LICENSE_SPECIALS
-  unset BROOKLYN_LICENSE_EXTRAS_FILES
-  unset BROOKLYN_LICENSE_MODE
-done
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/make-one-license.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/make-one-license.sh b/brooklyn-dist/dist/licensing/make-one-license.sh
deleted file mode 100755
index 5bcb35b..0000000
--- a/brooklyn-dist/dist/licensing/make-one-license.sh
+++ /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.
-#
-
-set -e
-
-# generates a LICENSE file, including notices and other licenses as needed
-# uses various env vars BROOKLYN_LICENSE_* to determine appropriate behaviour;
-# see make-licenses.sh for examples
-
-ls MAIN_LICENSE_ASL2 > /dev/null 2> /dev/null || ( echo "Must run in licensing directory (where this script lives)" > /dev/stderr && false )
-
-if [ -z "${BROOKLYN_LICENSE_MODE}" ] ; then echo BROOKLYN_LICENSE_MODE must be set > /dev/stderr ; false ; fi
-
-
-cat << EOF
-
-This software is distributed under the Apache License, version 2.0. See (1) below.
-This software is copyright (c) The Apache Software Foundation and contributors.
-
-Contents:
-
-  (1) This software license: Apache License, version 2.0
-  (2) Notices for bundled software
-  (3) Licenses for bundled software
-
-
-EOF
-
-echo "---------------------------------------------------"
-echo
-echo "(1) This software license: Apache License, version 2.0"
-echo
-cat MAIN_LICENSE_ASL2
-echo
-echo "---------------------------------------------------"
-echo
-echo "(2) Notices for bundled software"
-echo
-pushd .. > /dev/null
-# add -X on next line to get debug info
-mvn org.heneveld.maven:license-audit-maven-plugin:notices \
-        -DlicensesPreferred=ASL2,ASL,EPL1,BSD-2-Clause,BSD-3-Clause,CDDL1.1,CDDL1,CDDL \
-        -DoverridesFile=licensing/overrides.yaml \
-        -DextrasFiles=${BROOKLYN_LICENSE_EXTRAS_FILES:-`cat licensing/extras-files`} \
-        ${BROOKLYN_LICENSE_SPECIALS} \
-        -DoutputFile=licensing/notices.autogenerated \
-    > tmp_stdout 2> tmp_stderr
-rm tmp_std*
-popd > /dev/null
-cat notices.autogenerated
-
-echo
-echo "---------------------------------------------------"
-echo
-echo "(3) Licenses for bundled software"
-echo
-echo Contents:
-echo
-for x in licenses/${BROOKLYN_LICENSE_MODE}/* ; do head -1 $x | awk '{print "  "$0;}' ; done
-echo
-echo
-for x in licenses/${BROOKLYN_LICENSE_MODE}/* ; do cat $x ; echo ; done
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/overrides.yaml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/overrides.yaml b/brooklyn-dist/dist/licensing/overrides.yaml
deleted file mode 100644
index 1285df4..0000000
--- a/brooklyn-dist/dist/licensing/overrides.yaml
+++ /dev/null
@@ -1,385 +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.
-#
-
-
-# overrides file for org.heneveld.license-audit-maven-plugin
-# expands/corrects detail needed for generating license notices
-
-
-# super-projects to suppress notices for sub-projects
-
-- id: org.apache.brooklyn
-  url: http://brooklyn.incubator.apache.org/
-  license: ASL2
-  internal: true
-
-# poms with missing and incorrect data
-
-- id: org.codehaus.jettison:jettison
-  url: https://github.com/codehaus/jettison
-  license: ASL2 
-- id: org.glassfish.external:opendmk_jmxremote_optional_jar
-  url: https://opendmk.java.net/
-  license: CDDL
-- id: javax.validation:validation-api
-  url: http://beanvalidation.org/
-- id: com.squareup.okhttp:okhttp
-  copyright_by: Square, Inc.
-- id: com.squareup.okio:okio
-  copyright_by: Square, Inc.
-- id: com.wordnik:swagger-core_2.9.1
-  copyright_by: SmartBear Software
-- id: com.wordnik:swagger-jaxrs_2.9.1
-  copyright_by: SmartBear Software
-- id: org.bouncycastle  
-  copyright_by: The Legion of the Bouncy Castle Inc. (http://www.bouncycastle.org)
-- id: org.javassist:javassist
-  copyright_by: Shigeru Chiba
-- id: org.mongodb:mongo-java-driver
-  copyright_by: MongoDB, Inc
-- id: org.apache.httpcomponents:httpclient:*
-  url: http://hc.apache.org/httpcomponents-client-ga
-- id: javax.annotation:jsr250-api:*
-  url: https://jcp.org/en/jsr/detail?id=250
-- id: javax.ws.rs:jsr311-api:*
-  url: https://jsr311.java.net/
-- id: com.thoughtworks.xstream:*:*
-  url: http://x-stream.github.io/
-- id: com.fasterxml.jackson:*:*
-  url: http://wiki.fasterxml.com/JacksonHome
-
-- id: org.hibernate:jtidy:r8-20060801
-  license:
-  - url: "http://sourceforge.net/p/jtidy/code/HEAD/tree/trunk/jtidy/LICENSE.txt?revision=95"
-    name: Java HTML Tidy License
-    comment: Original link http://svn.sourceforge.net/viewvc/*checkout*/jtidy/trunk/jtidy/LICENSE.txt?revision=95 is no longer valid
-
-- id: dom4j:dom4j:1.6.1
-  url: "http://dom4j.sourceforge.net/"
-  license:
-  - name: MetaStuff BSD style license (3-clause)
-    url: http://dom4j.sourceforge.net/dom4j-1.6.1/license.html
-
-- id: org.python:jython-standalone:2.7-b3
-  copyright_by: Jython Developers
-  license:
-  - url: http://www.jython.org/license.html
-    name: Jython Software License
-    comment: Original link http://www.jython.org/Project/license.html is no longer valid
-
-- id: xpp3:xpp3_min:*
-  copyright_by: Extreme! Lab, Indiana University
-  license:
-  - url: https://github.com/apache/openmeetings/blob/a95714ce3f7e587d13d3d0bb3b4f570be15c67a5/LICENSE#L1361
-    name: "Indiana University Extreme! Lab Software License, vesion 1.1.1"
-    comment: |
-      The license applies to the Xpp3 classes (all classes below the org.xmlpull package with exception of classes directly in package org.xmlpull.v1);
-      original link http://www.extreme.indiana.edu/viewcvs/~checkout~/XPP3/java/LICENSE.txt is no longer valid
-  ## as we pull in xmlpull separately we do not use this, and having a single above simplifies the automation:
-  #  - url: http://creativecommons.org/licenses/publicdomain
-  #    name: Public Domain
-  #    comment: "The license applies to the XmlPull API (all classes directly in the org.xmlpull.v1 package)"
-
-
-# info on non-maven projects
-
-# used in UI
-- id: jquery-core:1.7.2
-  url: http://jquery.com/
-  description: JS library for manipulating HTML and eventing
-  name: jQuery JavaScript Library
-  files: jquery.js
-  version: 1.7.2
-  organization: { name: "The jQuery Foundation", url: "http://jquery.org/" }
-  license: MIT
-  notices: 
-  - Copyright (c) John Resig (2005-2011)
-  - "Includes code fragments from sizzle.js:"
-  - "  Copyright (c) The Dojo Foundation"
-  - "  Available at http://sizzlejs.com"
-  - "  Used under the MIT license"
-
-- id: jquery-core:1.8.0
-  url: http://jquery.com/
-  description: JS library for manipulating HTML and eventing
-  name: jQuery JavaScript Library
-  files: jquery.js
-  version: 1.8.0
-  organization: { name: "The jQuery Foundation", url: "http://jquery.org/" }
-  license: MIT
-  notices:
-  - Copyright (c) The jQuery Foundation, Inc. and other contributors (2005-2012)
-  - "Includes code fragments from sizzle.js:"
-  # NB: sizzle copyright changed from Dojo Foundation in 1.7.2
-  - "  Copyright (c) The jQuery Foundation, Inc. and other contributors (2012)"
-  - "  Available at http://sizzlejs.com"
-  - "  Used under the MIT license"
-# used in docs (not reported)
-- id: jquery-core:2.1.1
-  url: http://jquery.com/
-  description: JS library for manipulating HTML and eventing
-  name: jQuery JavaScript Library
-  files: jquery.js
-  version: 2.1.1
-  organization: { name: "The jQuery Foundation", url: "http://jquery.org/" }
-  license: MIT
-  notices: 
-  - Copyright (c) The jQuery Foundation, Inc. and other contributors (2005-2014)
-  - "Includes code fragments from sizzle.js:"
-  # NB: sizzle copyright changed from Dojo Foundation in 1.7.2
-  - "  Copyright (c) The jQuery Foundation, Inc. and other contributors (2013)"
-  - "  Available at http://sizzlejs.com"
-  - "  Used under the MIT license"
-
-# not used anymore? swagger-ui includes what it needs, it seems.
-- id: swagger:2.1.6
-  name: Swagger JS
-  files: swagger-client.js
-  version: 2.1.6
-  url: https://github.com/swagger-api/swagger-js
-  license: ASL2
-  notice: Copyright (c) SmartBear Software (2011-2015)
-
-- id: swagger-ui:2.1.4
-  files: swagger*.{js,css,html}
-  name: Swagger UI
-  version: 2.1.4
-  url: https://github.com/swagger-api/swagger-ui
-  license: ASL2
-  notice: Copyright (c) SmartBear Software (2011-2015)
-  
-- id: jquery.wiggle.min.js
-  name: jQuery Wiggle
-  version: swagger-ui:1.0.1
-  notices: 
-  - Copyright (c) WonderGroup and Jordan Thomas (2010)
-  - Previously online at http://labs.wondergroup.com/demos/mini-ui/index.html.
-  # that is link in copyright but it is no longer valid; url below is same person
-  - The version included here is from the Swagger UI distribution.
-  url: https://github.com/jordanthomas/jquery-wiggle
-  license: MIT
-
-- id: require.js
-  name: RequireJS 
-  files: require.js, text.js
-  version: 2.0.6 
-  url: http://requirejs.org/
-  organization: { name: "The Dojo Foundation", url: "http://dojofoundation.org/" }
-  notice: Copyright (c) The Dojo Foundation (2010-2012)
-  license: MIT
-
-- id: require.js/r.js
-  # new ID because this is a different version to the above
-  name: RequireJS (r.js maven plugin)
-  files: r.js
-  version: 2.1.6 
-  url: http://github.com/jrburke/requirejs
-  organization: { name: "The Dojo Foundation", url: "http://dojofoundation.org/" }
-  notices:
-  - Copyright (c) The Dojo Foundation (2009-2013)
-  - "Includes code fragments for source-map and other functionality:" 
-  - "  Copyright (c) The Mozilla Foundation and contributors (2011)"
-  - "  Used under the BSD 2-Clause license."
-  - "Includes code fragments for parse-js and other functionality:" 
-  - "  Copyright (c) Mihai Bazon (2010, 2012)"
-  - "  Used under the BSD 2-Clause license."
-  - "Includes code fragments for uglifyjs/consolidator:" 
-  - "  Copyright (c) Robert Gust-Bardon (2012)"
-  - "  Used under the BSD 2-Clause license."
-  - "Includes code fragments for the esprima parser:" 
-  - "  Copyright (c):"
-  - "    Ariya Hidayat (2011, 2012)"
-  - "    Mathias Bynens (2012)"
-  - "    Joost-Wim Boekesteijn (2012)"
-  - "    Kris Kowal (2012)"
-  - "    Yusuke Suzuki (2012)"
-  - "    Arpad Borsos (2012)"
-  - "  Used under the BSD 2-Clause license."
-  license: MIT
-
-- id: backbone.js
-  version: 1.0.0
-  url: http://backbonejs.org
-  organization: { name: "DocumentCloud Inc.", url: "http://www.documentcloud.org/" }
-  notice: Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2010-2013)
-  license: MIT
-
-- id: backbone.js:1.1.2
-  version: 1.1.2
-  url: http://backbonejs.org
-  organization: { name: "DocumentCloud Inc.", url: "http://www.documentcloud.org/" }
-  notice: Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2010-2014)
-  license: MIT
-
-- id: bootstrap.js
-  version: 2.0.4
-  url: http://twitter.github.com/bootstrap/javascript.html#transitions
-  notice: Copyright (c) Twitter, Inc. (2012)
-  license: ASL2
- 
-# used in docs (not needed for licensing) 
-- id: bootstrap.js:3.1.1
-  version: 3.1.1
-  url: http://getbootstrap.com/
-  notice: Copyright (c) Twitter, Inc. (2011-2014)
-  license: MIT
-  
-- id: underscore.js
-  version: 1.4.4
-  files: underscore*.{js,map}
-  url: http://underscorejs.org
-  organization: { name: "DocumentCloud Inc.", url: "http://www.documentcloud.org/" }
-  notice: Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2009-2013)
-  license: MIT
-
-# used in CLI (and in docs)
-- id: underscore.js:1.7.0
-  version: 1.7.0
-  files: underscore*.{js,map}
-  url: http://underscorejs.org
-  organization: { name: "DocumentCloud Inc.", url: "http://www.documentcloud.org/" }
-  notice: "Copyright (c) Jeremy Ashkenas, DocumentCloud and Investigative Reporters & Editors (2009-2014)"
-  license: MIT
-
-- id: async.js
-  version: 0.1.1
-  url: https://github.com/p15martin/google-maps-hello-world/blob/master/js/libs/async.js
-  # ORIGINALLY https://github.com/millermedeiros/requirejs-plugins
-  organization: { name: "Miller Medeiros", url: "https://github.com/millermedeiros/" }
-  description: RequireJS plugin for async dependency load like JSONP and Google Maps
-  notice: Copyright (c) Miller Medeiros (2011)
-  license: MIT 
-
-- id: handlebars.js
-  files: handlebars*.js
-  version: 1.0-rc1
-  url: https://github.com/wycats/handlebars.js 
-  organization: { name: "Yehuda Katz", url: "https://github.com/wycats/" }
-  notice: Copyright (c) Yehuda Katz (2012)
-  license: MIT
-
-- id: handlebars.js:2.0.0
-  files: handlebars*.js
-  version: 2.0.0
-  url: https://github.com/wycats/handlebars.js
-  organization: { name: "Yehuda Katz", url: "https://github.com/wycats/" }
-  notice: Copyright (c) Yehuda Katz (2014)
-  license: MIT
-
-- id: jquery.ba-bbq.js
-  name: "jQuery BBQ: Back Button & Query Library"
-  files: jquery.ba-bbq*.js
-  version: 1.2.1
-  url: http://benalman.com/projects/jquery-bbq-plugin/
-  organization: { name: "\"Cowboy\" Ben Alman", url: "http://benalman.com/" }
-  notice: Copyright (c) "Cowboy" Ben Alman (2010)"
-  license: MIT
-
-- id: moment.js
-  version: 2.1.0
-  url: http://momentjs.com
-  organization: { name: "Tim Wood", url: "http://momentjs.com" }
-  notice: Copyright (c) Tim Wood, Iskren Chernev, Moment.js contributors (2011-2014)
-  license: MIT
-
-- id: ZeroClipboard
-  files: ZeroClipboard.*
-  version: 1.3.1
-  url: http://zeroclipboard.org/
-  organization: { name: "ZeroClipboard contributors", url: "https://github.com/zeroclipboard" }
-  notice: Copyright (c) Jon Rohan, James M. Greene (2014)
-  license: MIT
-
-- id: jquery.dataTables
-  files: jquery.dataTables.{js,css}
-  name: DataTables Table plug-in for jQuery
-  version: 1.9.4
-  url: http://www.datatables.net/
-  organization: { name: "SpryMedia Ltd", url: "http://sprymedia.co.uk/" }
-  notice: Copyright (c) Allan Jardine (2008-2012)
-  license: BSD-3-Clause
-
-- id: js-uri
-  files: URI.js
-  version: 0.1
-  url: http://code.google.com/p/js-uri/
-  organization: { name: "js-uri contributors", url: "https://code.google.com/js-uri" }
-  license: BSD-3-Clause
-  # inferred
-  notice: Copyright (c) js-uri contributors (2013)
-
-- id: js-yaml.js
-  version: 3.2.7
-  organization: { name: "Vitaly Puzrin", url: "https://github.com/nodeca/" }
-  url: https://github.com/nodeca/
-  notice: Copyright (c) Vitaly Puzrin (2011-2015)
-  license: MIT
-
-- id: jquery.form.js
-  name: jQuery Form Plugin
-  version: "3.09"
-  url: https://github.com/malsup/form
-  # also http://malsup.com/jquery/form/
-  organization: { name: "Mike Alsup", url: "http://malsup.com/" }
-  notice: Copyright (c) M. Alsup (2006-2013)
-  license: MIT
-
-# used for CLI to build catalog
-- id: typeahead.js
-  version: 0.10.5
-  url: https://github.com/twitter/typeahead.js
-  organization: { name: "Twitter, Inc", url: "http://twitter.com" }
-  notice: Copyright (c) Twitter, Inc. and other contributors (2013-2014)
-  license: MIT
-
-# used for CLI to build catalog
-- id: marked.js
-  version: 0.3.1
-  url: https://github.com/chjj/marked
-  organization: { name: "Christopher Jeffrey", url: "https://github.com/chjj" }
-  notice: Copyright (c) Christopher Jeffrey (2011-2014)
-  license: MIT
-
-# DOCS files
-#
-# we don't do a distributable docs build -- they are just online.
-# (docs are excluded from the source build, and not bundled with the binary build.)
-# so these are not used currently; but for completeness and in case we change our minds,
-# here they are:
-
-# * different versions of jquery, bootstrap, and underscore noted above,
-# * media items github octicons and font-awesome fonts, not listed
-# * plus the below:
-
-- id: jquery.superfish.js
-  files: superfish.js
-  name: Superfish jQuery Menu Widget
-  version: 1.4.8
-  url: http://users.tpg.com.au/j_birch/plugins/superfish/
-  notice: Copyright (c) Joel Birch (2008)
-  license: MIT
-
-- id: jquery.cookie.js
-  name: jQuery Cookie Plugin
-  version: 1.3.1
-  url: https://github.com/carhartl/jquery-cookie
-  notice: Copyright (c) 2013 Klaus Hartl
-  license: MIT
-
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/licensing/projects-with-custom-licenses
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/projects-with-custom-licenses b/brooklyn-dist/dist/licensing/projects-with-custom-licenses
deleted file mode 100644
index 97839fc..0000000
--- a/brooklyn-dist/dist/licensing/projects-with-custom-licenses
+++ /dev/null
@@ -1,2 +0,0 @@
-../../brooklyn-ui
-../../brooklyn-server/server-cli

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/pom.xml b/brooklyn-dist/dist/pom.xml
deleted file mode 100644
index 0d01390..0000000
--- a/brooklyn-dist/dist/pom.xml
+++ /dev/null
@@ -1,159 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-    
-     http://www.apache.org/licenses/LICENSE-2.0
-    
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-    <modelVersion>4.0.0</modelVersion>
-    <packaging>jar</packaging>
-
-    <artifactId>brooklyn-dist</artifactId>
-
-    <name>Brooklyn Distribution</name>
-    <description>
-        Brooklyn redistributable package archive, includes all required
-        Jar files and scripts
-    </description>
-
-    <parent>
-        <groupId>org.apache.brooklyn</groupId>
-        <artifactId>brooklyn-dist-root</artifactId>
-        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-        <relativePath>../pom.xml</relativePath>
-    </parent>
-
-    <dependencies>
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-all</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-
-        <!-- TODO include examples -->
-        <!-- TODO include documentation -->
-
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-test-support</artifactId>
-            <version>${project.version}</version>
-            <scope>test</scope>
-        </dependency>
-        <dependency>
-            <groupId>org.testng</groupId>
-            <artifactId>testng</artifactId>
-            <scope>test</scope>
-        </dependency>
-
-    </dependencies>
-
-    <build>
-        <plugins>
-            <plugin>
-                <artifactId>maven-dependency-plugin</artifactId>
-                <!-- copy the config file from the CLI project (could instead use unpack goal with an includes filter) -->
-                <executions>
-                    <execution>
-                        <id>copy</id>
-                        <phase>process-classes</phase>
-                        <goals>
-                            <goal>copy</goal>
-                        </goals>
-                        <configuration>
-                            <artifactItems>
-                                <artifactItem>
-                                    <!-- this can fail in eclipse trying to copy _from_ target/classes.
-                                         see http://jira.codehaus.org/browse/MDEP-259 -->
-                                    <groupId>${project.groupId}</groupId>
-                                    <artifactId>brooklyn-cli</artifactId>
-                                    <version>${project.version}</version>
-                                    <type>bom</type>
-                                    <classifier>dist</classifier>
-                                    <overWrite>true</overWrite>
-                                    <outputDirectory>target</outputDirectory>
-                                    <destFileName>default.catalog.bom</destFileName>
-                                </artifactItem>
-                            </artifactItems>
-                        </configuration>
-                    </execution>
-                </executions>
-            </plugin>
-            <plugin>
-                <groupId>org.apache.rat</groupId>
-                <artifactId>apache-rat-plugin</artifactId>
-                <configuration>
-                    <excludes combine.children="append">
-                        <!-- Exclude sample config files because they are illustrative, intended for changing -->
-                        <exclude>src/main/dist/conf/**</exclude>
-                        <exclude>src/main/dist/README.md</exclude>
-                        <exclude>licensing/licenses/**</exclude>
-                        <exclude>licensing/README.md</exclude>
-                        <exclude>licensing/*LICENSE*</exclude>
-                        <exclude>licensing/*.autogenerated</exclude>
-                        <exclude>licensing/projects-with-custom-licenses</exclude>
-                        <exclude>licensing/extras-files</exclude>
-                    </excludes>
-                  </configuration>
-            </plugin>
-            <plugin>
-                <artifactId>maven-assembly-plugin</artifactId>
-                <executions>
-                    <execution>
-                        <id>build-distribution-dir</id>
-                        <phase>package</phase>
-                        <goals>
-                            <goal>single</goal>
-                        </goals>
-                        <configuration>
-                            <appendAssemblyId>true</appendAssemblyId>
-                            <descriptors>
-                                <descriptor>src/main/config/build-distribution.xml</descriptor>
-                            </descriptors>
-                            <finalName>brooklyn</finalName>
-                            <includeBaseDirectory>false</includeBaseDirectory>
-                            <formats>
-                                <format>dir</format>
-                            </formats>
-                            <attach>false</attach>
-                        </configuration>
-                    </execution>
-                    <execution>
-                        <id>build-distribution-archive</id>
-                        <phase>package</phase>
-                        <goals>
-                            <goal>single</goal>
-                        </goals>
-                        <configuration>
-                            <appendAssemblyId>true</appendAssemblyId>
-                            <descriptors>
-                                <descriptor>src/main/config/build-distribution.xml</descriptor>
-                            </descriptors>
-                          <!-- finalName affects name in `target/` but we cannot influence name when it is attached/installed,
-                               so `apache-` prefix would be lost there. to keep it consistent this is commented out, 
-                               but would be nice to have if there is a way!
-                            <finalName>apache-brooklyn-${project.version}</finalName>
-                          -->
-                            <formats>
-                                <format>tar.gz</format>
-                                <format>zip</format>
-                            </formats>
-                        </configuration>
-                    </execution>
-                </executions>
-            </plugin>
-        </plugins>
-    </build>
-</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/src/main/config/build-distribution.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/config/build-distribution.xml b/brooklyn-dist/dist/src/main/config/build-distribution.xml
deleted file mode 100644
index f543292..0000000
--- a/brooklyn-dist/dist/src/main/config/build-distribution.xml
+++ /dev/null
@@ -1,95 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-    
-     http://www.apache.org/licenses/LICENSE-2.0
-    
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-<assembly xmlns="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2"
-        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-        xsi:schemaLocation="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2 http://maven.apache.org/xsd/assembly-1.1.2.xsd">
-    <id>dist</id>
-    <formats><!-- empty, intended for caller to specify --></formats>
-    <fileSets>
-        <fileSet>
-            <directory>${project.basedir}/../..</directory>
-            <outputDirectory></outputDirectory>
-            <fileMode>0644</fileMode>
-            <directoryMode>0755</directoryMode>
-            <includes>
-                <include>DISCLAIMER*</include>
-            </includes>
-        </fileSet>
-        <fileSet>
-            <directory>${project.basedir}/src/main/license/files</directory>
-            <outputDirectory></outputDirectory>
-            <fileMode>0644</fileMode>
-            <directoryMode>0755</directoryMode>
-        </fileSet>
-        <fileSet>
-            <directory>${project.basedir}/src/main/dist/bin</directory>
-            <outputDirectory>bin</outputDirectory>
-            <fileMode>0755</fileMode>
-            <directoryMode>0755</directoryMode>
-        </fileSet>
-        <fileSet>
-            <!-- Add an empty dropins folder (so need to reference an existing dir, and exclude everything) -->
-            <directory>${project.basedir}/src/main/dist</directory>
-            <outputDirectory>lib/dropins</outputDirectory>
-            <directoryMode>0755</directoryMode>
-            <excludes>
-                <exclude>**/*</exclude>
-            </excludes>
-        </fileSet>
-        <fileSet>
-            <directory>${project.basedir}/target</directory>
-            <outputDirectory>conf/brooklyn</outputDirectory>
-            <fileMode>0644</fileMode>
-            <directoryMode>0755</directoryMode>
-            <includes>
-                <include>default.catalog.bom</include>
-            </includes>
-        </fileSet>
-        <fileSet>
-            <!-- Add an empty patch folder (so need to reference an existing dir, and exclude everything) -->
-            <directory>${project.basedir}/src/main/dist</directory>
-            <outputDirectory>lib/patch</outputDirectory>
-            <directoryMode>0755</directoryMode>
-            <excludes>
-                <exclude>**/*</exclude>
-            </excludes>
-        </fileSet>
-        <fileSet>
-            <directory>${project.basedir}/src/main/dist</directory>
-            <outputDirectory></outputDirectory>
-            <fileMode>0644</fileMode>
-            <directoryMode>0755</directoryMode>
-            <excludes>
-                <exclude>bin/*</exclude>
-            </excludes>
-        </fileSet>
-    </fileSets>
-    <!-- TODO include documentation -->
-    <!-- TODO include examples -->
-    <dependencySets>
-        <dependencySet>
-            <useProjectArtifact>false</useProjectArtifact>
-            <outputDirectory>lib/brooklyn</outputDirectory>
-            <fileMode>0644</fileMode>
-            <directoryMode>0755</directoryMode>
-            <outputFileNameMapping>${artifact.groupId}-${artifact.artifactId}-${artifact.version}${dashClassifier?}.${artifact.extension}</outputFileNameMapping>
-        </dependencySet>
-    </dependencySets>
-</assembly>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/src/main/dist/README.md
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/dist/README.md b/brooklyn-dist/dist/src/main/dist/README.md
deleted file mode 100644
index 406bccd..0000000
--- a/brooklyn-dist/dist/src/main/dist/README.md
+++ /dev/null
@@ -1,17 +0,0 @@
-
-# [![**Brooklyn**](https://brooklyn.apache.org/style/img/apache-brooklyn-logo-244px-wide.png)](http://brooklyn.apache.org/)
-
-### Apache Brooklyn
-
-This is the distribution of Apache Brooklyn.
-
-As a quick start, run:
-
-    ./bin/brooklyn launch
-
-For server CLI info, use:
-
-    ./bin/brooklyn help
-
-And to learn more, including the full user's guide, visit [brooklyn.apache.org](http://brooklyn.apache.org/).
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/src/main/dist/bin/.gitattributes
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/dist/bin/.gitattributes b/brooklyn-dist/dist/src/main/dist/bin/.gitattributes
deleted file mode 100644
index 4e2b719..0000000
--- a/brooklyn-dist/dist/src/main/dist/bin/.gitattributes
+++ /dev/null
@@ -1,3 +0,0 @@
-#Don't auto-convert line endings for shell scripts on Windows (breaks the scripts)
-brooklyn text eol=lf
-cloud-explorer text eol=lf

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/src/main/dist/bin/brooklyn
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/dist/bin/brooklyn b/brooklyn-dist/dist/src/main/dist/bin/brooklyn
deleted file mode 100755
index 370bc93..0000000
--- a/brooklyn-dist/dist/src/main/dist/bin/brooklyn
+++ /dev/null
@@ -1,51 +0,0 @@
-#!/usr/bin/env bash
-#
-# 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.
-#
-# Brooklyn
-#
-
-#set -x # debug
-
-# discover BROOKLYN_HOME if not set, by attempting to resolve absolute path of this command
-ROOT=$(cd "$(dirname "$0")/.." && pwd -P)
-if [ -z "$BROOKLYN_HOME" ] ; then
-    BROOKLYN_HOME=$(cd "$(dirname "$(readlink -f "$0" 2> /dev/null || readlink "$0" 2> /dev/null || echo "$0")")/.." && pwd)
-fi
-export ROOT BROOKLYN_HOME
-
-# use default memory settings, if not specified
-if [ -z "${JAVA_OPTS}" ] ; then
-    JAVA_OPTS="-Xms256m -Xmx1g -XX:MaxPermSize=256m"
-fi
-
-# set up the classpath
-INITIAL_CLASSPATH=${BROOKLYN_HOME}/conf:${BROOKLYN_HOME}/lib/patch/*:${BROOKLYN_HOME}/lib/brooklyn/*:${BROOKLYN_HOME}/lib/dropins/*
-# specify additional CP args in BROOKLYN_CLASSPATH
-if [ ! -z "${BROOKLYN_CLASSPATH}" ]; then
-    INITIAL_CLASSPATH=${BROOKLYN_CLASSPATH}:${INITIAL_CLASSPATH}
-fi
-export INITIAL_CLASSPATH
-
-# force resolution of localhost to be loopback, otherwise we hit problems
-# TODO should be changed in code
-JAVA_OPTS="-Dbrooklyn.location.localhost.address=127.0.0.1 ${JAVA_OPTS}"
-
-# start Brooklyn
-echo $$ > "$ROOT/pid_java"
-exec java ${JAVA_OPTS} -cp "${INITIAL_CLASSPATH}" org.apache.brooklyn.cli.Main "$@"

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/src/main/dist/bin/brooklyn.bat
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/dist/bin/brooklyn.bat b/brooklyn-dist/dist/src/main/dist/bin/brooklyn.bat
deleted file mode 100644
index 90e300e..0000000
--- a/brooklyn-dist/dist/src/main/dist/bin/brooklyn.bat
+++ /dev/null
@@ -1,111 +0,0 @@
-@echo off
-REM Licensed to the Apache Software Foundation (ASF) under one
-REM or more contributor license agreements.  See the NOTICE file
-REM distributed with this work for additional information
-REM regarding copyright ownership.  The ASF licenses this file
-REM to you under the Apache License, Version 2.0 (the
-REM "License"); you may not use this file except in compliance
-REM with the License.  You may obtain a copy of the License at
-REM 
-REM   http://www.apache.org/licenses/LICENSE-2.0
-REM 
-REM Unless required by applicable law or agreed to in writing,
-REM software distributed under the License is distributed on an
-REM "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-REM KIND, either express or implied.  See the License for the
-REM specific language governing permissions and limitations
-REM under the License.
-
-SETLOCAL EnableDelayedExpansion
-
-REM discover BROOKLYN_HOME if not set, by attempting to resolve absolute path of this command (brooklyn.bat)
-IF NOT DEFINED BROOKLYN_HOME (
-    SET "WORKING_FOLDER=%~dp0"
-    
-    REM stript trailing slash
-    SET "WORKING_FOLDER=!WORKING_FOLDER:~0,-1!"
-    
-    REM get parent folder (~dp works only for batch file params and loop indexes)
-    FOR %%i in ("!WORKING_FOLDER!") DO SET "BROOKLYN_HOME=%%~dpi"
-)
-
-REM Discover the location of Java.
-REM Use JAVA_HOME environment variable, if available;
-REM else, check the path;
-REM else, search registry for Java installations;
-REM else fail.
-
-IF DEFINED JAVA_HOME (
-    CALL :joinpath "%JAVA_HOME%" bin\java.exe JAVA_BIN
-)
-
-IF NOT DEFINED JAVA_BIN (
-    IF NOT DEFINED JAVA_HOME CALL :registry_home "HKLM\SOFTWARE\JavaSoft\Java Runtime Environment"
-    IF NOT DEFINED JAVA_HOME CALL :registry_home "HKLM\SOFTWARE\Wow6432Node\JavaSoft\Java Runtime Environment"
-    IF NOT DEFINED JAVA_HOME CALL :registry_home "HKLM\SOFTWARE\JavaSoft\Java Development Kit"
-    IF NOT DEFINED JAVA_HOME CALL :registry_home "HKLM\SOFTWARE\Wow6432Node\JavaSoft\Java Development Kit"
-    CALL :joinpath "!JAVA_HOME!" bin\java.exe JAVA_BIN
-)
-
-IF NOT DEFINED JAVA_BIN (
-    java.exe -version > NUL 2> NUL
-    echo !ERRORLEVEL!
-    IF NOT !ERRORLEVEL!==9009 SET JAVA_BIN=java.exe
-)
-
-IF NOT DEFINED JAVA_BIN (
-    echo "Unable to locate a Java installation. Please set JAVA_HOME or PATH environment variables."
-    exit /b 1
-) ELSE (
-    "%JAVA_BIN%" -version > NUL 2> NUL
-    IF !ERRORLEVEL!==9009 (
-        echo "java.exe does not exist where specified. Please check JAVA_HOME or PATH environment variables."
-        exit /b 1
-    )
-)
-
-REM use default memory settings, if not specified
-IF "%JAVA_OPTS%"=="" SET JAVA_OPTS=-Xms256m -Xmx500m -XX:MaxPermSize=256m
-
-REM set up the classpath
-SET INITIAL_CLASSPATH=%BROOKLYN_HOME%conf;%BROOKLYN_HOME%lib\patch\*;%BROOKLYN_HOME%lib\brooklyn\*;%BROOKLYN_HOME%lib\dropins\*
-REM specify additional CP args in BROOKLYN_CLASSPATH
-IF NOT "%BROOKLYN_CLASSPATH%"=="" SET "INITIAL_CLASSPATH=%BROOKLYN_CLASSPATH%;%INITIAL_CLASSPATH%"
-
-REM force resolution of localhost to be loopback, otherwise we hit problems
-REM TODO should be changed in code
-SET JAVA_OPTS=-Dbrooklyn.location.localhost.address=127.0.0.1 %JAVA_OPTS%
-
-REM workaround for http://bugs.sun.com/view_bug.do?bug_id=4787931
-SET JAVA_OPTS=-Duser.home="%USERPROFILE%" %JAVA_OPTS%
-
-REM start Brooklyn
-REM NO easy way to find process PID!!!
-pushd %BROOKLYN_HOME%
-
-"%JAVA_BIN%" %JAVA_OPTS% -cp "%INITIAL_CLASSPATH%" org.apache.brooklyn.cli.Main %*
-
-popd
-
-ENDLOCAL
-GOTO :EOF
-
-:joinpath
-    SET Path1=%~1
-    SET Path2=%~2
-    IF {%Path1:~-1,1%}=={\} (SET "%3=%Path1%%Path2%") ELSE (SET "%3=%Path1%\%Path2%")
-GOTO :EOF
-
-:whereis
-    REM Doesn't handle paths with quotes in the PATH variable
-    SET "%2=%~$PATH:1"
-GOTO :EOF
-
-:registry_value
-    FOR /F "skip=2 tokens=2*" %%A IN ('REG QUERY %1 /v %2 2^>nul') DO SET "%3=%%B"
-GOTO :EOF
-
-:registry_home
-    CALL :registry_value %1 CurrentVersion JAVA_VERSION
-    CALL :registry_value "%~1\%JAVA_VERSION%" JavaHome JAVA_HOME
-GOTO :EOF

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/src/main/dist/bin/brooklyn.ps1
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/dist/bin/brooklyn.ps1 b/brooklyn-dist/dist/src/main/dist/bin/brooklyn.ps1
deleted file mode 100644
index 6780ed2..0000000
--- a/brooklyn-dist/dist/src/main/dist/bin/brooklyn.ps1
+++ /dev/null
@@ -1,135 +0,0 @@
-#!ps1
-#
-# 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.
-#
-# Brooklyn
-#
-
-$ErrorActionPreference = "Stop";
-
-$ROOT = split-path -parent $MyInvocation.MyCommand.Definition
-
-# discover BROOKLYN_HOME if not set, by attempting to resolve absolute path of this command (brooklyn)
-if ( $env:BROOKLYN_HOME -eq $null ) {
-    $BROOKLYN_HOME = split-path -parent $ROOT
-} else {
-    $BROOKLYN_HOME = $env:BROOKLYN_HOME
-}
-
-# Discover the location of Java.
-# Use JAVA_HOME environment variable, if available;
-# else, search registry for Java installations;
-# else, check the path;
-# else fail.
-$bin = [System.IO.Path]::Combine("bin", "java.exe")
-if ( $env:JAVA_HOME -ne $null ) {
-    $javahome = $env:JAVA_HOME
-    $javabin = [System.IO.Path]::Combine($javahome, $bin)
-}
-if ( $javabin -eq $null ) {
-    $reglocations = ( 'HKLM:\SOFTWARE\JavaSoft\Java Runtime Environment',
-                      'HKLM:\SOFTWARE\Wow6432Node\JavaSoft\Java Runtime Environment' )
-    $jres = @{}
-    foreach ($loc in $reglocations) {
-        $item = Get-Item $loc -ErrorAction SilentlyContinue
-        if ($item -eq $null) { continue }
-        foreach ($key in Get-ChildItem $loc) {
-            $version = $key.PSChildName
-            $jrehome = $key.GetValue("JavaHome")
-            $jres.Add($version, $jrehome)
-        }
-    }
-    # TODO - this does a simple sort on the registry key name (the JRE version). This is not ideal - better would be
-    # to understand semantic versioning, filter out incompatible JREs (1.5 and earlier), prefer known good JREs (1.6
-    # or 1.7) and pick the highest patchlevel.
-    $last = ( $jres.Keys | Sort-Object | Select-Object -Last 1 )
-    if ( $last -ne $null ) {
-        $javahome = $jres.Get_Item($last)
-        $javabin = [System.IO.Path]::Combine($javahome, $bin)
-    }
-}
-if ( $javabin -eq $null ) {
-    $where = Get-Command "java.exe" -ErrorAction SilentlyContinue
-    if ( $where -ne $null ) {
-        $javabin = $where.Definition
-        $bindir = [System.IO.Path]::GetDirectoryName($javabin)
-        $javahome = [System.IO.Path]::GetDirectoryName($bindir)
-    }
-}
-
-if ( $javabin -eq $null ) {
-    throw "Unable to locate a Java installation. Please set JAVA_HOME or PATH environment variables."
-} elseif ( $( Get-Item $javabin -ErrorAction SilentlyContinue ) -eq $null ) {
-    throw "java.exe does not exist where specified. Please check JAVA_HOME or PATH environment variables."
-}
-
-# set up the classpath
-$cp = Get-ChildItem ${BROOKLYN_HOME}\conf | Select-Object -ExpandProperty FullName
-
-if ( Test-Path ${BROOKLYN_HOME}\lib\patch ) {
-    $cp += Get-ChildItem ${BROOKLYN_HOME}\lib\patch | Select-Object -ExpandProperty FullName
-}
-
-$cp += Get-ChildItem ${BROOKLYN_HOME}\lib\brooklyn | Select-Object -ExpandProperty FullName
-
-if ( Test-Path ${BROOKLYN_HOME}\lib\dropins ) {
-    $cp += Get-ChildItem ${BROOKLYN_HOME}\lib\dropins | Select-Object -ExpandProperty FullName
-}
-
-$INITIAL_CLASSPATH = $cp -join ';'
-
-# specify additional CP args in BROOKLYN_CLASSPATH
-if ( ! ( $env:BROOKLYN_CLASSPATH -eq $null )) {
-    $INITIAL_CLASSPATH = "$($INITIAL_CLASSPATH);$($env:BROOKLYN_CLASSPATH)"
-}
-
-# start to build up the arguments to the java invocation
-$javaargs = @()
-
-# add the user's java opts, or use default memory settings, if not specified
-if ( $env:JAVA_OPTS -eq $null ) {
-    $javaargs +="-Xms256m -Xmx1g -XX:MaxPermSize=256m"
-} else {
-    $javaargs +=$env:JAVA_OPTS
-}
-
-# force resolution of localhost to be loopback, otherwise we hit problems
-# TODO should be changed in code
-$javaargs += "-Dbrooklyn.localhost.address=127.0.0.1 $($JAVA_OPTS)"
-
-# workaround for http://bugs.sun.com/view_bug.do?bug_id=4787931
-$javaargs += "-Duser.home=`"$env:USERPROFILE`""
-
-# add the classpath
-$javaargs += "-cp"
-$javaargs += "`"$($INITIAL_CLASSPATH)`""
-
-# main class
-$javaargs += "org.apache.brooklyn.cli.Main"
-
-# copy in the arguments that were given to this script
-$javaargs += $args
-
-# start Brooklyn
-$process = Start-Process -FilePath $javabin -ArgumentList $javaargs -NoNewWindow -PassThru
-
-# save PID
-Set-Content -Path ${BROOKLYN_HOME}\pid_java -Value $($process.Id)
-
-# wait for it to finish
-$process.WaitForExit()

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/src/main/dist/conf/logback.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/dist/conf/logback.xml b/brooklyn-dist/dist/src/main/dist/conf/logback.xml
deleted file mode 100644
index e70862c..0000000
--- a/brooklyn-dist/dist/src/main/dist/conf/logback.xml
+++ /dev/null
@@ -1,14 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<configuration>
-
-    <!-- to supply custom logging, either change this file, supply your own logback-main.xml 
-         (overriding the default provided on the classpath) or any of the files it references; 
-         see the Logging section of the Brooklyn web site for more information -->
-
-    <property name="logging.basename" scope="context" value="brooklyn" />
-    <property name="logging.dir" scope="context" value="./" />
-
-    <include resource="logback-main.xml"/>
-    
-</configuration>
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/src/main/license/README.md
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/license/README.md b/brooklyn-dist/dist/src/main/license/README.md
deleted file mode 100644
index 0d3b52b..0000000
--- a/brooklyn-dist/dist/src/main/license/README.md
+++ /dev/null
@@ -1,2 +0,0 @@
-See /usage/dist/licensing/README.md for an explanation of this directory.
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/26c4604c/brooklyn-dist/dist/src/main/license/files/DISCLAIMER
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/license/files/DISCLAIMER b/brooklyn-dist/dist/src/main/license/files/DISCLAIMER
deleted file mode 100644
index 9e6119b..0000000
--- a/brooklyn-dist/dist/src/main/license/files/DISCLAIMER
+++ /dev/null
@@ -1,8 +0,0 @@
-
-Apache Brooklyn is an effort undergoing incubation at The Apache Software Foundation (ASF), 
-sponsored by the Apache Incubator. Incubation is required of all newly accepted projects until 
-a further review indicates that the infrastructure, communications, and decision making process 
-have stabilized in a manner consistent with other successful ASF projects. While incubation 
-status is not necessarily a reflection of the completeness or stability of the code, it does 
-indicate that the project has yet to be fully endorsed by the ASF.
-


[32/51] [abbrv] brooklyn-dist git commit: add README.md to rat excludes

Posted by he...@apache.org.
add README.md to rat excludes


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

Branch: refs/heads/master
Commit: eab89f01b0aea0fea6d857e0f77bed7f44b70b69
Parents: dcb2e25
Author: John McCabe <jo...@johnmccabe.net>
Authored: Mon Jan 25 00:57:47 2016 +0000
Committer: John McCabe <jo...@johnmccabe.net>
Committed: Mon Jan 25 00:57:47 2016 +0000

----------------------------------------------------------------------
 brooklyn-dist/vagrant/pom.xml | 13 +++++++++++++
 1 file changed, 13 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/eab89f01/brooklyn-dist/vagrant/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/vagrant/pom.xml b/brooklyn-dist/vagrant/pom.xml
index 3fc1844..fbe6539 100644
--- a/brooklyn-dist/vagrant/pom.xml
+++ b/brooklyn-dist/vagrant/pom.xml
@@ -66,5 +66,18 @@
                 </executions>
             </plugin>
         </plugins>
+        <pluginManagement>
+            <plugins>
+                <plugin>
+                    <groupId>org.apache.rat</groupId>
+                    <artifactId>apache-rat-plugin</artifactId>
+                    <configuration>
+                        <excludes combine.children="append">
+                            <exclude>src/main/vagrant/README.md</exclude>
+                        </excludes>
+                    </configuration>
+                </plugin>
+            </plugins>
+        </pluginManagement>
     </build>
 </project>


[07/51] [abbrv] brooklyn-dist git commit: [SPLITPREP] rearranged to have structure of new repositories

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/src/main/license/files/LICENSE
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/license/files/LICENSE b/brooklyn-dist/dist/src/main/license/files/LICENSE
new file mode 100644
index 0000000..b280a7d
--- /dev/null
+++ b/brooklyn-dist/dist/src/main/license/files/LICENSE
@@ -0,0 +1,2149 @@
+
+This software is distributed under the Apache License, version 2.0. See (1) below.
+This software is copyright (c) The Apache Software Foundation and contributors.
+
+Contents:
+
+  (1) This software license: Apache License, version 2.0
+  (2) Notices for bundled software
+  (3) Licenses for bundled software
+
+
+---------------------------------------------------
+
+(1) This software license: Apache License, version 2.0
+
+
+                                 Apache License
+                           Version 2.0, January 2004
+                        http://www.apache.org/licenses/
+
+   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+
+   1. Definitions.
+
+      "License" shall mean the terms and conditions for use, reproduction,
+      and distribution as defined by Sections 1 through 9 of this document.
+
+      "Licensor" shall mean the copyright owner or entity authorized by
+      the copyright owner that is granting the License.
+
+      "Legal Entity" shall mean the union of the acting entity and all
+      other entities that control, are controlled by, or are under common
+      control with that entity. For the purposes of this definition,
+      "control" means (i) the power, direct or indirect, to cause the
+      direction or management of such entity, whether by contract or
+      otherwise, or (ii) ownership of fifty percent (50%) or more of the
+      outstanding shares, or (iii) beneficial ownership of such entity.
+
+      "You" (or "Your") shall mean an individual or Legal Entity
+      exercising permissions granted by this License.
+
+      "Source" form shall mean the preferred form for making modifications,
+      including but not limited to software source code, documentation
+      source, and configuration files.
+
+      "Object" form shall mean any form resulting from mechanical
+      transformation or translation of a Source form, including but
+      not limited to compiled object code, generated documentation,
+      and conversions to other media types.
+
+      "Work" shall mean the work of authorship, whether in Source or
+      Object form, made available under the License, as indicated by a
+      copyright notice that is included in or attached to the work
+      (an example is provided in the Appendix below).
+
+      "Derivative Works" shall mean any work, whether in Source or Object
+      form, that is based on (or derived from) the Work and for which the
+      editorial revisions, annotations, elaborations, or other modifications
+      represent, as a whole, an original work of authorship. For the purposes
+      of this License, Derivative Works shall not include works that remain
+      separable from, or merely link (or bind by name) to the interfaces of,
+      the Work and Derivative Works thereof.
+
+      "Contribution" shall mean any work of authorship, including
+      the original version of the Work and any modifications or additions
+      to that Work or Derivative Works thereof, that is intentionally
+      submitted to Licensor for inclusion in the Work by the copyright owner
+      or by an individual or Legal Entity authorized to submit on behalf of
+      the copyright owner. For the purposes of this definition, "submitted"
+      means any form of electronic, verbal, or written communication sent
+      to the Licensor or its representatives, including but not limited to
+      communication on electronic mailing lists, source code control systems,
+      and issue tracking systems that are managed by, or on behalf of, the
+      Licensor for the purpose of discussing and improving the Work, but
+      excluding communication that is conspicuously marked or otherwise
+      designated in writing by the copyright owner as "Not a Contribution."
+
+      "Contributor" shall mean Licensor and any individual or Legal Entity
+      on behalf of whom a Contribution has been received by Licensor and
+      subsequently incorporated within the Work.
+
+   2. Grant of Copyright License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      copyright license to reproduce, prepare Derivative Works of,
+      publicly display, publicly perform, sublicense, and distribute the
+      Work and such Derivative Works in Source or Object form.
+
+   3. Grant of Patent License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      (except as stated in this section) patent license to make, have made,
+      use, offer to sell, sell, import, and otherwise transfer the Work,
+      where such license applies only to those patent claims licensable
+      by such Contributor that are necessarily infringed by their
+      Contribution(s) alone or by combination of their Contribution(s)
+      with the Work to which such Contribution(s) was submitted. If You
+      institute patent litigation against any entity (including a
+      cross-claim or counterclaim in a lawsuit) alleging that the Work
+      or a Contribution incorporated within the Work constitutes direct
+      or contributory patent infringement, then any patent licenses
+      granted to You under this License for that Work shall terminate
+      as of the date such litigation is filed.
+
+   4. Redistribution. You may reproduce and distribute copies of the
+      Work or Derivative Works thereof in any medium, with or without
+      modifications, and in Source or Object form, provided that You
+      meet the following conditions:
+
+      (a) You must give any other recipients of the Work or
+          Derivative Works a copy of this License; and
+
+      (b) You must cause any modified files to carry prominent notices
+          stating that You changed the files; and
+
+      (c) You must retain, in the Source form of any Derivative Works
+          that You distribute, all copyright, patent, trademark, and
+          attribution notices from the Source form of the Work,
+          excluding those notices that do not pertain to any part of
+          the Derivative Works; and
+
+      (d) If the Work includes a "NOTICE" text file as part of its
+          distribution, then any Derivative Works that You distribute must
+          include a readable copy of the attribution notices contained
+          within such NOTICE file, excluding those notices that do not
+          pertain to any part of the Derivative Works, in at least one
+          of the following places: within a NOTICE text file distributed
+          as part of the Derivative Works; within the Source form or
+          documentation, if provided along with the Derivative Works; or,
+          within a display generated by the Derivative Works, if and
+          wherever such third-party notices normally appear. The contents
+          of the NOTICE file are for informational purposes only and
+          do not modify the License. You may add Your own attribution
+          notices within Derivative Works that You distribute, alongside
+          or as an addendum to the NOTICE text from the Work, provided
+          that such additional attribution notices cannot be construed
+          as modifying the License.
+
+      You may add Your own copyright statement to Your modifications and
+      may provide additional or different license terms and conditions
+      for use, reproduction, or distribution of Your modifications, or
+      for any such Derivative Works as a whole, provided Your use,
+      reproduction, and distribution of the Work otherwise complies with
+      the conditions stated in this License.
+
+   5. Submission of Contributions. Unless You explicitly state otherwise,
+      any Contribution intentionally submitted for inclusion in the Work
+      by You to the Licensor shall be under the terms and conditions of
+      this License, without any additional terms or conditions.
+      Notwithstanding the above, nothing herein shall supersede or modify
+      the terms of any separate license agreement you may have executed
+      with Licensor regarding such Contributions.
+
+   6. Trademarks. This License does not grant permission to use the trade
+      names, trademarks, service marks, or product names of the Licensor,
+      except as required for reasonable and customary use in describing the
+      origin of the Work and reproducing the content of the NOTICE file.
+
+   7. Disclaimer of Warranty. Unless required by applicable law or
+      agreed to in writing, Licensor provides the Work (and each
+      Contributor provides its Contributions) on an "AS IS" BASIS,
+      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+      implied, including, without limitation, any warranties or conditions
+      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
+      PARTICULAR PURPOSE. You are solely responsible for determining the
+      appropriateness of using or redistributing the Work and assume any
+      risks associated with Your exercise of permissions under this License.
+
+   8. Limitation of Liability. In no event and under no legal theory,
+      whether in tort (including negligence), contract, or otherwise,
+      unless required by applicable law (such as deliberate and grossly
+      negligent acts) or agreed to in writing, shall any Contributor be
+      liable to You for damages, including any direct, indirect, special,
+      incidental, or consequential damages of any character arising as a
+      result of this License or out of the use or inability to use the
+      Work (including but not limited to damages for loss of goodwill,
+      work stoppage, computer failure or malfunction, or any and all
+      other commercial damages or losses), even if such Contributor
+      has been advised of the possibility of such damages.
+
+   9. Accepting Warranty or Additional Liability. While redistributing
+      the Work or Derivative Works thereof, You may choose to offer,
+      and charge a fee for, acceptance of support, warranty, indemnity,
+      or other liability obligations and/or rights consistent with this
+      License. However, in accepting such obligations, You may act only
+      on Your own behalf and on Your sole responsibility, not on behalf
+      of any other Contributor, and only if You agree to indemnify,
+      defend, and hold each Contributor harmless for any liability
+      incurred by, or claims asserted against, such Contributor by reason
+      of your accepting any such warranty or additional liability.
+
+
+---------------------------------------------------
+
+(2) Notices for bundled software
+
+This project includes the software: aopalliance
+  Available at: http://aopalliance.sourceforge.net
+  Version used: 1.0
+  Used under the following license: Public Domain
+
+This project includes the software: asm
+  Available at: http://asm.objectweb.org/
+  Developed by: ObjectWeb (http://www.objectweb.org/)
+  Version used: 3.3.1
+  Used under the following license: BSD License (http://asm.objectweb.org/license.html)
+
+This project includes the software: async.js
+  Available at: https://github.com/p15martin/google-maps-hello-world/blob/master/js/libs/async.js
+  Developed by: Miller Medeiros (https://github.com/millermedeiros/)
+  Version used: 0.1.1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Miller Medeiros (2011)
+
+This project includes the software: backbone.js
+  Available at: http://backbonejs.org
+  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
+  Version used: 1.0.0
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2010-2013)
+
+This project includes the software: bootstrap.js
+  Available at: http://twitter.github.com/bootstrap/javascript.html#transitions
+  Version used: 2.0.4
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+  Copyright (c) Twitter, Inc. (2012)
+
+This project includes the software: ch.qos.logback
+  Available at: http://logback.qos.ch
+  Developed by: QOS.ch (http://www.qos.ch)
+  Version used: 1.0.7
+  Used under the following license: Eclipse Public License, version 1.0 (http://www.eclipse.org/legal/epl-v10.html)
+
+This project includes the software: com.fasterxml.jackson.core
+  Available at: http://wiki.fasterxml.com/JacksonHome
+  Developed by: FasterXML (http://fasterxml.com/)
+  Version used: 2.4.2; 2.4.0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.fasterxml.jackson.jaxrs
+  Available at: http://wiki.fasterxml.com/JacksonHome
+  Developed by: FasterXML (http://fasterxml.com/)
+  Version used: 2.4.2
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.fasterxml.jackson.module
+  Available at: http://wiki.fasterxml.com/JacksonJAXBAnnotations
+  Developed by: FasterXML (http://fasterxml.com/)
+  Version used: 2.4.2
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.google.code.findbugs
+  Available at: http://findbugs.sourceforge.net/
+  Version used: 2.0.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.google.code.gson
+  Available at: http://code.google.com/p/google-gson/
+  Developed by: Google, Inc. (http://www.google.com)
+  Version used: 2.3
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.google.guava
+  Available at: http://code.google.com/p/guava-libraries
+  Version used: 17.0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.google.http-client
+  Available at: http://code.google.com/p/google-http-java-client/
+  Developed by: Google (http://www.google.com/)
+  Version used: 1.18.0-rc
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.google.inject
+  Available at: http://code.google.com/p/google-guice/
+  Developed by: Google, Inc. (http://www.google.com)
+  Version used: 3.0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.google.inject.extensions
+  Available at: http://code.google.com/p/google-guice/
+  Developed by: Google, Inc. (http://www.google.com)
+  Version used: 3.0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.googlecode.concurrentlinkedhashmap
+  Available at: http://code.google.com/p/concurrentlinkedhashmap
+  Version used: 1.0_jdk5
+  Used under the following license: Apache License (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.jamesmurty.utils
+  Available at: https://github.com/jmurty/java-xmlbuilder
+  Version used: 1.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+
+This project includes the software: com.jayway.jsonpath
+  Available at: https://github.com/jayway/JsonPath
+  Version used: 2.0.0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.jcraft
+  Available at: http://www.jcraft.com/jsch-agent-proxy/
+  Developed by: JCraft,Inc. (http://www.jcraft.com/)
+  Version used: 0.0.8
+  Used under the following license: The BSD 3-Clause (New BSD) License (http://www.jcraft.com/jsch-agent-proxy/LICENSE.txt)
+
+This project includes the software: com.maxmind.db
+  Available at: http://dev.maxmind.com/
+  Developed by: MaxMind, Inc. (http://www.maxmind.com/)
+  Version used: 0.3.4
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.html)
+
+This project includes the software: com.maxmind.geoip2
+  Available at: http://dev.maxmind.com/geoip/geoip2/web-services
+  Developed by: MaxMind, Inc. (http://www.maxmind.com/)
+  Version used: 0.8.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.html)
+
+This project includes the software: com.squareup.okhttp
+  Available at: https://github.com/square/okhttp
+  Version used: 2.2.0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.squareup.okio
+  Available at: https://github.com/square/okio
+  Version used: 1.2.0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: com.sun.jersey
+  Available at: https://jersey.java.net/
+  Developed by: Oracle Corporation (http://www.oracle.com/)
+  Version used: 1.18.1
+  Used under the following license: Common Development and Distribution License, version 1.1 (http://glassfish.java.net/public/CDDL+GPL_1_1.html)
+
+This project includes the software: com.sun.jersey.contribs
+  Available at: https://jersey.java.net/
+  Developed by: Oracle Corporation (http://www.oracle.com/)
+  Version used: 1.18.1
+  Used under the following license: Common Development and Distribution License, version 1.1 (http://glassfish.java.net/public/CDDL+GPL_1_1.html)
+
+This project includes the software: com.thoughtworks.xstream
+  Available at: http://x-stream.github.io/
+  Developed by: XStream (http://xstream.codehaus.org)
+  Version used: 1.4.7
+  Used under the following license: BSD License (http://xstream.codehaus.org/license.html)
+
+This project includes the software: com.wordnik
+  Available at: https://github.com/wordnik/swagger-core
+  Version used: 1.0.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.html)
+
+This project includes the software: commons-beanutils
+  Available at: http://commons.apache.org/proper/commons-beanutils/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.9.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: commons-codec
+  Available at: http://commons.apache.org/proper/commons-codec/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.9
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: commons-collections
+  Available at: http://commons.apache.org/collections/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 3.2.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: commons-io
+  Available at: http://commons.apache.org/io/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 2.4
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: commons-lang
+  Available at: http://commons.apache.org/lang/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 2.4
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: commons-logging
+  Available at: http://commons.apache.org/proper/commons-logging/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.2
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: dom4j
+  Available at: http://dom4j.sourceforge.net/
+  Developed by: MetaStuff Ltd. (http://sourceforge.net/projects/dom4j)
+  Version used: 1.6.1
+  Used under the following license: MetaStuff BSD style license (3-clause) (http://dom4j.sourceforge.net/dom4j-1.6.1/license.html)
+
+This project includes the software: handlebars.js
+  Available at: https://github.com/wycats/handlebars.js
+  Developed by: Yehuda Katz (https://github.com/wycats/)
+  Inclusive of: handlebars*.js
+  Version used: 1.0-rc1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Yehuda Katz (2012)
+
+This project includes the software: io.airlift
+  Available at: https://github.com/airlift/airline
+  Version used: 0.6
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: io.cloudsoft.windows
+  Available at: http://github.com/cloudsoft/winrm4j
+  Version used: 0.1.0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: javax.annotation
+  Available at: https://jcp.org/en/jsr/detail?id=250
+  Version used: 1.0
+  Used under the following license: Common Development and Distribution License, version 1.0 (https://glassfish.dev.java.net/public/CDDLv1.0.html)
+
+This project includes the software: javax.inject
+  Available at: http://code.google.com/p/atinject/
+  Version used: 1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: javax.servlet
+  Available at: http://servlet-spec.java.net
+  Developed by: GlassFish Community (https://glassfish.dev.java.net)
+  Version used: 3.1.0
+  Used under the following license: CDDL + GPLv2 with classpath exception (https://glassfish.dev.java.net/nonav/public/CDDL+GPL.html)
+
+This project includes the software: javax.validation
+  Version used: 1.0.0.GA
+  Used under the following license: Apache License, version 2.0 (in-project reference: license.txt)
+
+This project includes the software: javax.ws.rs
+  Available at: https://jsr311.java.net/
+  Developed by: Sun Microsystems, Inc (http://www.sun.com/)
+  Version used: 1.1.1
+  Used under the following license: CDDL License (http://www.opensource.org/licenses/cddl1.php)
+
+This project includes the software: jQuery JavaScript Library
+  Available at: http://jquery.com/
+  Developed by: The jQuery Foundation (http://jquery.org/)
+  Inclusive of: jquery.js
+  Version used: 1.7.2
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) John Resig (2005-2011)
+  Includes code fragments from sizzle.js:
+    Copyright (c) The Dojo Foundation
+    Available at http://sizzlejs.com
+    Used under the MIT license
+
+This project includes the software: jQuery BBQ: Back Button & Query Library
+  Available at: http://benalman.com/projects/jquery-bbq-plugin/
+  Developed by: "Cowboy" Ben Alman (http://benalman.com/)
+  Inclusive of: jquery.ba-bbq*.js
+  Version used: 1.2.1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) "Cowboy" Ben Alman (2010)"
+
+This project includes the software: DataTables Table plug-in for jQuery
+  Available at: http://www.datatables.net/
+  Developed by: SpryMedia Ltd (http://sprymedia.co.uk/)
+  Inclusive of: jquery.dataTables.{js,css}
+  Version used: 1.9.4
+  Used under the following license: The BSD 3-Clause (New BSD) License (http://opensource.org/licenses/BSD-3-Clause)
+  Copyright (c) Allan Jardine (2008-2012)
+
+This project includes the software: jQuery Form Plugin
+  Available at: https://github.com/malsup/form
+  Developed by: Mike Alsup (http://malsup.com/)
+  Inclusive of: jquery.form.js
+  Version used: 3.09
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) M. Alsup (2006-2013)
+
+This project includes the software: jQuery Wiggle
+  Available at: https://github.com/jordanthomas/jquery-wiggle
+  Inclusive of: jquery.wiggle.min.js
+  Version used: swagger-ui:1.0.1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) WonderGroup and Jordan Thomas (2010)
+  Previously online at http://labs.wondergroup.com/demos/mini-ui/index.html.
+  The version included here is from the Swagger UI distribution.
+
+This project includes the software: js-uri
+  Available at: http://code.google.com/p/js-uri/
+  Developed by: js-uri contributors (https://code.google.com/js-uri)
+  Inclusive of: URI.js
+  Version used: 0.1
+  Used under the following license: The BSD 3-Clause (New BSD) License (http://opensource.org/licenses/BSD-3-Clause)
+  Copyright (c) js-uri contributors (2013)
+
+This project includes the software: js-yaml.js
+  Available at: https://github.com/nodeca/
+  Developed by: Vitaly Puzrin (https://github.com/nodeca/)
+  Version used: 3.2.7
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Vitaly Puzrin (2011-2015)
+
+This project includes the software: moment.js
+  Available at: http://momentjs.com
+  Developed by: Tim Wood (http://momentjs.com)
+  Version used: 2.1.0
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Tim Wood, Iskren Chernev, Moment.js contributors (2011-2014)
+
+This project includes the software: net.iharder
+  Available at: http://iharder.net/base64/
+  Version used: 2.3.8
+  Used under the following license: Public domain
+
+This project includes the software: net.java.dev.jna
+  Available at: https://github.com/twall/jna
+  Version used: 4.0.0
+  Used under the following license: Apache License, version 2.0 (http://www.gnu.org/licenses/licenses.html)
+
+This project includes the software: net.minidev
+  Available at: http://www.minidev.net/
+  Developed by: Chemouni Uriel (http://www.minidev.net/)
+  Version used: 2.1.1; 1.0.2
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: net.schmizz
+  Available at: http://github.com/shikhar/sshj
+  Version used: 0.8.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.99soft.guice
+  Available at: http://99soft.github.com/rocoto/
+  Developed by: 99 Software Foundation (http://www.99soft.org/)
+  Version used: 6.2
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.commons
+  Available at: http://commons.apache.org/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 3.1; 1.4
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.felix
+  Available at: http://felix.apache.org/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 4.4.0
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.httpcomponents
+  Available at: http://hc.apache.org/httpcomponents-client-ga http://hc.apache.org/httpcomponents-core-ga
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 4.4.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.jclouds
+  Available at: http://jclouds.apache.org/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.9.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.jclouds.api
+  Available at: http://jclouds.apache.org/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.9.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.jclouds.common
+  Available at: http://jclouds.apache.org/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.9.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.jclouds.driver
+  Available at: http://jclouds.apache.org/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.9.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.jclouds.labs
+  Available at: http://jclouds.apache.org/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.9.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.apache.jclouds.provider
+  Available at: http://jclouds.apache.org/
+  Developed by: The Apache Software Foundation (http://www.apache.org/)
+  Version used: 1.9.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.bouncycastle
+  Available at: http://www.bouncycastle.org/java.html
+  Version used: 1.49
+  Used under the following license: Bouncy Castle Licence (http://www.bouncycastle.org/licence.html)
+
+This project includes the software: org.codehaus.groovy
+  Available at: http://groovy.codehaus.org/
+  Developed by: The Codehaus (http://codehaus.org)
+  Version used: 2.3.7
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.codehaus.jackson
+  Available at: http://jackson.codehaus.org
+  Developed by: FasterXML (http://fasterxml.com)
+  Version used: 1.9.13
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.codehaus.jettison
+  Version used: 1.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+
+This project includes the software: org.eclipse.jetty
+  Available at: http://www.eclipse.org/jetty
+  Developed by: Webtide (http://webtide.com)
+  Version used: 9.2.13.v20150730
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+
+This project includes the software: org.freemarker
+  Available at: http://freemarker.org/
+  Version used: 2.3.22
+  Used under the following license: Apache License, version 2.0 (http://freemarker.org/LICENSE.txt)
+
+This project includes the software: org.glassfish.external
+  Version used: 1.0-b01-ea
+  Used under the following license: Common Development and Distribution License (http://opensource.org/licenses/CDDL-1.0)
+
+This project includes the software: org.hibernate
+  Available at: http://jtidy.sourceforge.net
+  Version used: r8-20060801
+  Used under the following license: Java HTML Tidy License (http://sourceforge.net/p/jtidy/code/HEAD/tree/trunk/jtidy/LICENSE.txt?revision=95)
+
+This project includes the software: org.javassist
+  Available at: http://www.javassist.org/
+  Version used: 3.16.1-GA
+  Used under the following license: Apache License, version 2.0 (http://www.mozilla.org/MPL/MPL-1.1.html)
+
+This project includes the software: org.jvnet.mimepull
+  Available at: http://mimepull.java.net
+  Developed by: Oracle Corporation (http://www.oracle.com/)
+  Version used: 1.9.3
+  Used under the following license: Common Development and Distribution License, version 1.1 (https://glassfish.java.net/public/CDDL+GPL_1_1.html)
+
+This project includes the software: org.mongodb
+  Available at: http://www.mongodb.org
+  Version used: 3.0.3
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0.txt)
+
+This project includes the software: org.python
+  Available at: http://www.jython.org/
+  Version used: 2.7-b3
+  Used under the following license: Jython Software License (http://www.jython.org/license.html)
+
+This project includes the software: org.reflections
+  Available at: http://code.google.com/p/reflections/
+  Version used: 0.9.9-RC1
+  Used under the following license: WTFPL (http://www.wtfpl.net/)
+
+This project includes the software: org.scala-lang
+  Available at: http://www.scala-lang.org/
+  Developed by: LAMP/EPFL (http://lamp.epfl.ch/)
+  Version used: 2.9.1-1
+  Used under the following license: BSD License (http://www.scala-lang.org/downloads/license.html)
+
+This project includes the software: org.slf4j
+  Available at: http://www.slf4j.org
+  Developed by: QOS.ch (http://www.qos.ch)
+  Version used: 1.6.6
+  Used under the following license: The MIT License (http://www.opensource.org/licenses/mit-license.php)
+
+This project includes the software: org.tukaani
+  Available at: http://tukaani.org/xz/java.html
+  Version used: 1.0
+  Used under the following license: Public Domain
+
+This project includes the software: org.yaml
+  Available at: http://www.snakeyaml.org
+  Version used: 1.11
+  Used under the following license: Apache License, version 2.0 (in-project reference: LICENSE.txt)
+
+This project includes the software: RequireJS
+  Available at: http://requirejs.org/
+  Developed by: The Dojo Foundation (http://dojofoundation.org/)
+  Inclusive of: require.js, text.js
+  Version used: 2.0.6
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) The Dojo Foundation (2010-2012)
+
+This project includes the software: RequireJS (r.js maven plugin)
+  Available at: http://github.com/jrburke/requirejs
+  Developed by: The Dojo Foundation (http://dojofoundation.org/)
+  Inclusive of: r.js
+  Version used: 2.1.6
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) The Dojo Foundation (2009-2013)
+  Includes code fragments for source-map and other functionality:
+    Copyright (c) The Mozilla Foundation and contributors (2011)
+    Used under the BSD 2-Clause license.
+  Includes code fragments for parse-js and other functionality:
+    Copyright (c) Mihai Bazon (2010, 2012)
+    Used under the BSD 2-Clause license.
+  Includes code fragments for uglifyjs/consolidator:
+    Copyright (c) Robert Gust-Bardon (2012)
+    Used under the BSD 2-Clause license.
+  Includes code fragments for the esprima parser:
+    Copyright (c):
+      Ariya Hidayat (2011, 2012)
+      Mathias Bynens (2012)
+      Joost-Wim Boekesteijn (2012)
+      Kris Kowal (2012)
+      Yusuke Suzuki (2012)
+      Arpad Borsos (2012)
+    Used under the BSD 2-Clause license.
+
+This project includes the software: Swagger JS
+  Available at: https://github.com/wordnik/swagger-js
+  Inclusive of: swagger.js
+  Version used: 1.0.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+  Copyright (c) SmartBear Software (2011-2015)
+
+This project includes the software: Swagger UI
+  Available at: https://github.com/wordnik/swagger-ui
+  Inclusive of: swagger-ui.js
+  Version used: 1.0.1
+  Used under the following license: Apache License, version 2.0 (http://www.apache.org/licenses/LICENSE-2.0)
+  Copyright (c) SmartBear Software (2011-2015)
+
+This project includes the software: typeahead.js
+  Available at: https://github.com/twitter/typeahead.js
+  Developed by: Twitter, Inc (http://twitter.com)
+  Version used: 0.10.5
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Twitter, Inc. and other contributors (2013-2014)
+
+This project includes the software: underscore.js
+  Available at: http://underscorejs.org
+  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
+  Inclusive of: underscore*.{js,map}
+  Version used: 1.4.4
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2009-2013)
+
+This project includes the software: underscore.js:1.7.0
+  Available at: http://underscorejs.org
+  Developed by: DocumentCloud Inc. (http://www.documentcloud.org/)
+  Inclusive of: underscore*.{js,map}
+  Version used: 1.7.0
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Jeremy Ashkenas, DocumentCloud and Investigative Reporters & Editors (2009-2014)
+
+This project includes the software: xmlpull
+  Available at: http://www.xmlpull.org
+  Version used: 1.1.3.1
+  Used under the following license: Public Domain (http://www.xmlpull.org/v1/download/unpacked/LICENSE.txt)
+
+This project includes the software: xpp3
+  Available at: http://www.extreme.indiana.edu/xgws/xsoap/xpp/mxp1/
+  Developed by: Extreme! Lab, Indiana University (http://www.extreme.indiana.edu/)
+  Version used: 1.1.4c
+  Used under the following license: Indiana University Extreme! Lab Software License, vesion 1.1.1 (https://github.com/apache/openmeetings/blob/a95714ce3f7e587d13d3d0bb3b4f570be15c67a5/LICENSE#L1361)
+
+This project includes the software: ZeroClipboard
+  Available at: http://zeroclipboard.org/
+  Developed by: ZeroClipboard contributors (https://github.com/zeroclipboard)
+  Inclusive of: ZeroClipboard.*
+  Version used: 1.3.1
+  Used under the following license: The MIT License (http://opensource.org/licenses/MIT)
+  Copyright (c) Jon Rohan, James M. Greene (2014)
+
+
+---------------------------------------------------
+
+(3) Licenses for bundled software
+
+Contents:
+
+  Apache License, Version 2.0
+  The BSD 2-Clause License
+  The BSD 3-Clause License ("New BSD")
+  COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.0
+  COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.1
+  Eclipse Public License, version 1.0
+  The MIT License ("MIT")
+  WTF Public License
+  Bouncy Castle License
+  JTidy License
+  Jython License
+  MetaStuff BSD Style License
+  Indiana University Extreme! Lab Software License, Version 1.1.1
+
+
+Apache License, Version 2.0
+
+  Apache License
+  Version 2.0, January 2004
+  http://www.apache.org/licenses/
+  
+  TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+  
+  1. Definitions.
+  
+  "License" shall mean the terms and conditions for use, reproduction,
+  and distribution as defined by Sections 1 through 9 of this document.
+  
+  "Licensor" shall mean the copyright owner or entity authorized by
+  the copyright owner that is granting the License.
+  
+  "Legal Entity" shall mean the union of the acting entity and all
+  other entities that control, are controlled by, or are under common
+  control with that entity. For the purposes of this definition,
+  "control" means (i) the power, direct or indirect, to cause the
+  direction or management of such entity, whether by contract or
+  otherwise, or (ii) ownership of fifty percent (50%) or more of the
+  outstanding shares, or (iii) beneficial ownership of such entity.
+  
+  "You" (or "Your") shall mean an individual or Legal Entity
+  exercising permissions granted by this License.
+  
+  "Source" form shall mean the preferred form for making modifications,
+  including but not limited to software source code, documentation
+  source, and configuration files.
+  
+  "Object" form shall mean any form resulting from mechanical
+  transformation or translation of a Source form, including but
+  not limited to compiled object code, generated documentation,
+  and conversions to other media types.
+  
+  "Work" shall mean the work of authorship, whether in Source or
+  Object form, made available under the License, as indicated by a
+  copyright notice that is included in or attached to the work
+  (an example is provided in the Appendix below).
+  
+  "Derivative Works" shall mean any work, whether in Source or Object
+  form, that is based on (or derived from) the Work and for which the
+  editorial revisions, annotations, elaborations, or other modifications
+  represent, as a whole, an original work of authorship. For the purposes
+  of this License, Derivative Works shall not include works that remain
+  separable from, or merely link (or bind by name) to the interfaces of,
+  the Work and Derivative Works thereof.
+  
+  "Contribution" shall mean any work of authorship, including
+  the original version of the Work and any modifications or additions
+  to that Work or Derivative Works thereof, that is intentionally
+  submitted to Licensor for inclusion in the Work by the copyright owner
+  or by an individual or Legal Entity authorized to submit on behalf of
+  the copyright owner. For the purposes of this definition, "submitted"
+  means any form of electronic, verbal, or written communication sent
+  to the Licensor or its representatives, including but not limited to
+  communication on electronic mailing lists, source code control systems,
+  and issue tracking systems that are managed by, or on behalf of, the
+  Licensor for the purpose of discussing and improving the Work, but
+  excluding communication that is conspicuously marked or otherwise
+  designated in writing by the copyright owner as "Not a Contribution."
+  
+  "Contributor" shall mean Licensor and any individual or Legal Entity
+  on behalf of whom a Contribution has been received by Licensor and
+  subsequently incorporated within the Work.
+  
+  2. Grant of Copyright License. Subject to the terms and conditions of
+  this License, each Contributor hereby grants to You a perpetual,
+  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+  copyright license to reproduce, prepare Derivative Works of,
+  publicly display, publicly perform, sublicense, and distribute the
+  Work and such Derivative Works in Source or Object form.
+  
+  3. Grant of Patent License. Subject to the terms and conditions of
+  this License, each Contributor hereby grants to You a perpetual,
+  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+  (except as stated in this section) patent license to make, have made,
+  use, offer to sell, sell, import, and otherwise transfer the Work,
+  where such license applies only to those patent claims licensable
+  by such Contributor that are necessarily infringed by their
+  Contribution(s) alone or by combination of their Contribution(s)
+  with the Work to which such Contribution(s) was submitted. If You
+  institute patent litigation against any entity (including a
+  cross-claim or counterclaim in a lawsuit) alleging that the Work
+  or a Contribution incorporated within the Work constitutes direct
+  or contributory patent infringement, then any patent licenses
+  granted to You under this License for that Work shall terminate
+  as of the date such litigation is filed.
+  
+  4. Redistribution. You may reproduce and distribute copies of the
+  Work or Derivative Works thereof in any medium, with or without
+  modifications, and in Source or Object form, provided that You
+  meet the following conditions:
+  
+  (a) You must give any other recipients of the Work or
+  Derivative Works a copy of this License; and
+  
+  (b) You must cause any modified files to carry prominent notices
+  stating that You changed the files; and
+  
+  (c) You must retain, in the Source form of any Derivative Works
+  that You distribute, all copyright, patent, trademark, and
+  attribution notices from the Source form of the Work,
+  excluding those notices that do not pertain to any part of
+  the Derivative Works; and
+  
+  (d) If the Work includes a "NOTICE" text file as part of its
+  distribution, then any Derivative Works that You distribute must
+  include a readable copy of the attribution notices contained
+  within such NOTICE file, excluding those notices that do not
+  pertain to any part of the Derivative Works, in at least one
+  of the following places: within a NOTICE text file distributed
+  as part of the Derivative Works; within the Source form or
+  documentation, if provided along with the Derivative Works; or,
+  within a display generated by the Derivative Works, if and
+  wherever such third-party notices normally appear. The contents
+  of the NOTICE file are for informational purposes only and
+  do not modify the License. You may add Your own attribution
+  notices within Derivative Works that You distribute, alongside
+  or as an addendum to the NOTICE text from the Work, provided
+  that such additional attribution notices cannot be construed
+  as modifying the License.
+  
+  You may add Your own copyright statement to Your modifications and
+  may provide additional or different license terms and conditions
+  for use, reproduction, or distribution of Your modifications, or
+  for any such Derivative Works as a whole, provided Your use,
+  reproduction, and distribution of the Work otherwise complies with
+  the conditions stated in this License.
+  
+  5. Submission of Contributions. Unless You explicitly state otherwise,
+  any Contribution intentionally submitted for inclusion in the Work
+  by You to the Licensor shall be under the terms and conditions of
+  this License, without any additional terms or conditions.
+  Notwithstanding the above, nothing herein shall supersede or modify
+  the terms of any separate license agreement you may have executed
+  with Licensor regarding such Contributions.
+  
+  6. Trademarks. This License does not grant permission to use the trade
+  names, trademarks, service marks, or product names of the Licensor,
+  except as required for reasonable and customary use in describing the
+  origin of the Work and reproducing the content of the NOTICE file.
+  
+  7. Disclaimer of Warranty. Unless required by applicable law or
+  agreed to in writing, Licensor provides the Work (and each
+  Contributor provides its Contributions) on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+  implied, including, without limitation, any warranties or conditions
+  of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
+  PARTICULAR PURPOSE. You are solely responsible for determining the
+  appropriateness of using or redistributing the Work and assume any
+  risks associated with Your exercise of permissions under this License.
+  
+  8. Limitation of Liability. In no event and under no legal theory,
+  whether in tort (including negligence), contract, or otherwise,
+  unless required by applicable law (such as deliberate and grossly
+  negligent acts) or agreed to in writing, shall any Contributor be
+  liable to You for damages, including any direct, indirect, special,
+  incidental, or consequential damages of any character arising as a
+  result of this License or out of the use or inability to use the
+  Work (including but not limited to damages for loss of goodwill,
+  work stoppage, computer failure or malfunction, or any and all
+  other commercial damages or losses), even if such Contributor
+  has been advised of the possibility of such damages.
+  
+  9. Accepting Warranty or Additional Liability. While redistributing
+  the Work or Derivative Works thereof, You may choose to offer,
+  and charge a fee for, acceptance of support, warranty, indemnity,
+  or other liability obligations and/or rights consistent with this
+  License. However, in accepting such obligations, You may act only
+  on Your own behalf and on Your sole responsibility, not on behalf
+  of any other Contributor, and only if You agree to indemnify,
+  defend, and hold each Contributor harmless for any liability
+  incurred by, or claims asserted against, such Contributor by reason
+  of your accepting any such warranty or additional liability.
+  
+
+The BSD 2-Clause License
+
+  Redistribution and use in source and binary forms, with or without
+  modification, are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, this
+  list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice,
+  this list of conditions and the following disclaimer in the documentation
+  and/or other materials provided with the distribution.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
+  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
+  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
+  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
+  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
+  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
+  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
+  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
+  
+
+The BSD 3-Clause License ("New BSD")
+
+  Redistribution and use in source and binary forms, with or without modification,
+  are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, 
+  this list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice, 
+  this list of conditions and the following disclaimer in the documentation 
+  and/or other materials provided with the distribution.
+  
+  3. Neither the name of the copyright holder nor the names of its contributors 
+  may be used to endorse or promote products derived from this software without 
+  specific prior written permission.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
+  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
+  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
+  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
+  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
+  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
+  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
+  POSSIBILITY OF SUCH DAMAGE.
+  
+
+COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.0
+
+  1. Definitions.
+  
+  1.1. "Contributor" means each individual or entity that
+  creates or contributes to the creation of Modifications.
+  
+  1.2. "Contributor Version" means the combination of the
+  Original Software, prior Modifications used by a
+  Contributor (if any), and the Modifications made by that
+  particular Contributor.
+  
+  1.3. "Covered Software" means (a) the Original Software, or
+  (b) Modifications, or (c) the combination of files
+  containing Original Software with files containing
+  Modifications, in each case including portions thereof.
+  
+  1.4. "Executable" means the Covered Software in any form
+  other than Source Code. 
+  
+  1.5. "Initial Developer" means the individual or entity
+  that first makes Original Software available under this
+  License. 
+  
+  1.6. "Larger Work" means a work which combines Covered
+  Software or portions thereof with code not governed by the
+  terms of this License.
+  
+  1.7. "License" means this document.
+  
+  1.8. "Licensable" means having the right to grant, to the
+  maximum extent possible, whether at the time of the initial
+  grant or subsequently acquired, any and all of the rights
+  conveyed herein.
+  
+  1.9. "Modifications" means the Source Code and Executable
+  form of any of the following: 
+  
+  A. Any file that results from an addition to,
+  deletion from or modification of the contents of a
+  file containing Original Software or previous
+  Modifications; 
+  
+  B. Any new file that contains any part of the
+  Original Software or previous Modification; or 
+  
+  C. Any new file that is contributed or otherwise made
+  available under the terms of this License.
+  
+  1.10. "Original Software" means the Source Code and
+  Executable form of computer software code that is
+  originally released under this License. 
+  
+  1.11. "Patent Claims" means any patent claim(s), now owned
+  or hereafter acquired, including without limitation,
+  method, process, and apparatus claims, in any patent
+  Licensable by grantor. 
+  
+  1.12. "Source Code" means (a) the common form of computer
+  software code in which modifications are made and (b)
+  associated documentation included in or with such code.
+  
+  1.13. "You" (or "Your") means an individual or a legal
+  entity exercising rights under, and complying with all of
+  the terms of, this License. For legal entities, "You"
+  includes any entity which controls, is controlled by, or is
+  under common control with You. For purposes of this
+  definition, "control" means (a) the power, direct or
+  indirect, to cause the direction or management of such
+  entity, whether by contract or otherwise, or (b) ownership
+  of more than fifty percent (50%) of the outstanding shares
+  or beneficial ownership of such entity.
+  
+  2. License Grants. 
+  
+  2.1. The Initial Developer Grant.
+  
+  Conditioned upon Your compliance with Section 3.1 below and
+  subject to third party intellectual property claims, the
+  Initial Developer hereby grants You a world-wide,
+  royalty-free, non-exclusive license: 
+  
+  (a) under intellectual property rights (other than
+  patent or trademark) Licensable by Initial Developer,
+  to use, reproduce, modify, display, perform,
+  sublicense and distribute the Original Software (or
+  portions thereof), with or without Modifications,
+  and/or as part of a Larger Work; and 
+  
+  (b) under Patent Claims infringed by the making,
+  using or selling of Original Software, to make, have
+  made, use, practice, sell, and offer for sale, and/or
+  otherwise dispose of the Original Software (or
+  portions thereof). 
+  
+  (c) The licenses granted in Sections 2.1(a) and (b)
+  are effective on the date Initial Developer first
+  distributes or otherwise makes the Original Software
+  available to a third party under the terms of this
+  License. 
+  
+  (d) Notwithstanding Section 2.1(b) above, no patent
+  license is granted: (1) for code that You delete from
+  the Original Software, or (2) for infringements
+  caused by: (i) the modification of the Original
+  Software, or (ii) the combination of the Original
+  Software with other software or devices. 
+  
+  2.2. Contributor Grant.
+  
+  Conditioned upon Your compliance with Section 3.1 below and
+  subject to third party intellectual property claims, each
+  Contributor hereby grants You a world-wide, royalty-free,
+  non-exclusive license:
+  
+  (a) under intellectual property rights (other than
+  patent or trademark) Licensable by Contributor to
+  use, reproduce, modify, display, perform, sublicense
+  and distribute the Modifications created by such
+  Contributor (or portions thereof), either on an
+  unmodified basis, with other Modifications, as
+  Covered Software and/or as part of a Larger Work; and
+  
+  (b) under Patent Claims infringed by the making,
+  using, or selling of Modifications made by that
+  Contributor either alone and/or in combination with
+  its Contributor Version (or portions of such
+  combination), to make, use, sell, offer for sale,
+  have made, and/or otherwise dispose of: (1)
+  Modifications made by that Contributor (or portions
+  thereof); and (2) the combination of Modifications
+  made by that Contributor with its Contributor Version
+  (or portions of such combination). 
+  
+  (c) The licenses granted in Sections 2.2(a) and
+  2.2(b) are effective on the date Contributor first
+  distributes or otherwise makes the Modifications
+  available to a third party. 
+  
+  (d) Notwithstanding Section 2.2(b) above, no patent
+  license is granted: (1) for any code that Contributor
+  has deleted from the Contributor Version; (2) for
+  infringements caused by: (i) third party
+  modifications of Contributor Version, or (ii) the
+  combination of Modifications made by that Contributor
+  with other software (except as part of the
+  Contributor Version) or other devices; or (3) under
+  Patent Claims infringed by Covered Software in the
+  absence of Modifications made by that Contributor. 
+  
+  3. Distribution Obligations.
+  
+  3.1. Availability of Source Code.
+  
+  Any Covered Software that You distribute or otherwise make
+  available in Executable form must also be made available in
+  Source Code form and that Source Code form must be
+  distributed only under the terms of this License. You must
+  include a copy of this License with every copy of the
+  Source Code form of the Covered Software You distribute or
+  otherwise make available. You must inform recipients of any
+  such Covered Software in Executable form as to how they can
+  obtain such Covered Software in Source Code form in a
+  reasonable manner on or through a medium customarily used
+  for software exchange.
+  
+  3.2. Modifications.
+  
+  The Modifications that You create or to which You
+  contribute are governed by the terms of this License. You
+  represent that You believe Your Modifications are Your
+  original creation(s) and/or You have sufficient rights to
+  grant the rights conveyed by this License.
+  
+  3.3. Required Notices.
+  
+  You must include a notice in each of Your Modifications
+  that identifies You as the Contributor of the Modification.
+  You may not remove or alter any copyright, patent or
+  trademark notices contained within the Covered Software, or
+  any notices of licensing or any descriptive text giving
+  attribution to any Contributor or the Initial Developer.
+  
+  3.4. Application of Additional Terms.
+  
+  You may not offer or impose any terms on any Covered
+  Software in Source Code form that alters or restricts the
+  applicable version of this License or the recipients"
+  rights hereunder. You may choose to offer, and to charge a
+  fee for, warranty, support, indemnity or liability
+  obligations to one or more recipients of Covered Software.
+  However, you may do so only on Your own behalf, and not on
+  behalf of the Initial Developer or any Contributor. You
+  must make it absolutely clear that any such warranty,
+  support, indemnity or liability obligation is offered by
+  You alone, and You hereby agree to indemnify the Initial
+  Developer and every Contributor for any liability incurred
+  by the Initial Developer or such Contributor as a result of
+  warranty, support, indemnity or liability terms You offer.
+      
+  3.5. Distribution of Executable Versions.
+  
+  You may distribute the Executable form of the Covered
+  Software under the terms of this License or under the terms
+  of a license of Your choice, which may contain terms
+  different from this License, provided that You are in
+  compliance with the terms of this License and that the
+  license for the Executable form does not attempt to limit
+  or alter the recipient"s rights in the Source Code form
+  from the rights set forth in this License. If You
+  distribute the Covered Software in Executable form under a
+  different license, You must make it absolutely clear that
+  any terms which differ from this License are offered by You
+  alone, not by the Initial Developer or Contributor. You
+  hereby agree to indemnify the Initial Developer and every
+  Contributor for any liability incurred by the Initial
+  Developer or such Contributor as a result of any such terms
+  You offer.
+  
+  3.6. Larger Works.
+  
+  You may create a Larger Work by combining Covered Software
+  with other code not governed by the terms of this License
+  and distribute the Larger Work as a single product. In such
+  a case, You must make sure the requirements of this License
+  are fulfilled for the Covered Software. 
+  
+  4. Versions of the License. 
+  
+  4.1. New Versions.
+  
+  Sun Microsystems, Inc. is the initial license steward and
+  may publish revised and/or new versions of this License
+  from time to time. Each version will be given a
+  distinguishing version number. Except as provided in
+  Section 4.3, no one other than the license steward has the
+  right to modify this License. 
+  
+  4.2. Effect of New Versions.
+  
+  You may always continue to use, distribute or otherwise
+  make the Covered Software available under the terms of the
+  version of the License under which You originally received
+  the Covered Software. If the Initial Developer includes a
+  notice in the Original Software prohibiting it from being
+  distributed or otherwise made available under any
+  subsequent version of the License, You must distribute and
+  make the Covered Software available under the terms of the
+  version of the License under which You originally received
+  the Covered Software. Otherwise, You may also choose to
+  use, distribute or otherwise make the Covered Software
+  available under the terms of any subsequent version of the
+  License published by the license steward. 
+  
+  4.3. Modified Versions.
+  
+  When You are an Initial Developer and You want to create a
+  new license for Your Original Software, You may create and
+  use a modified version of this License if You: (a) rename
+  the license and remove any references to the name of the
+  license steward (except to note that the license differs
+  from this License); and (b) otherwise make it clear that
+  the license contains terms which differ from this License.
+  
+  5. DISCLAIMER OF WARRANTY.
+  
+  COVERED SOFTWARE IS PROVIDED UNDER THIS LICENSE ON AN "AS IS"
+  BASIS, WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED,
+  INCLUDING, WITHOUT LIMITATION, WARRANTIES THAT THE COVERED
+  SOFTWARE IS FREE OF DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR
+  PURPOSE OR NON-INFRINGING. THE ENTIRE RISK AS TO THE QUALITY AND
+  PERFORMANCE OF THE COVERED SOFTWARE IS WITH YOU. SHOULD ANY
+  COVERED SOFTWARE PROVE DEFECTIVE IN ANY RESPECT, YOU (NOT THE
+  INITIAL DEVELOPER OR ANY OTHER CONTRIBUTOR) ASSUME THE COST OF
+  ANY NECESSARY SERVICING, REPAIR OR CORRECTION. THIS DISCLAIMER OF
+  WARRANTY CONSTITUTES AN ESSENTIAL PART OF THIS LICENSE. NO USE OF
+  ANY COVERED SOFTWARE IS AUTHORIZED HEREUNDER EXCEPT UNDER THIS
+  DISCLAIMER. 
+  
+  6. TERMINATION. 
+  
+  6.1. This License and the rights granted hereunder will
+  terminate automatically if You fail to comply with terms
+  herein and fail to cure such breach within 30 days of
+  becoming aware of the breach. Provisions which, by their
+  nature, must remain in effect beyond the termination of
+  this License shall survive.
+  
+  6.2. If You assert a patent infringement claim (excluding
+  declaratory judgment actions) against Initial Developer or
+  a Contributor (the Initial Developer or Contributor against
+  whom You assert such claim is referred to as "Participant")
+  alleging that the Participant Software (meaning the
+  Contributor Version where the Participant is a Contributor
+  or the Original Software where the Participant is the
+  Initial Developer) directly or indirectly infringes any
+  patent, then any and all rights granted directly or
+  indirectly to You by such Participant, the Initial
+  Developer (if the Initial Developer is not the Participant)
+  and all Contributors under Sections 2.1 and/or 2.2 of this
+  License shall, upon 60 days notice from Participant
+  terminate prospectively and automatically at the expiration
+  of such 60 day notice period, unless if within such 60 day
+  period You withdraw Your claim with respect to the
+  Participant Software against such Participant either
+  unilaterally or pursuant to a written agreement with
+  Participant.
+  
+  6.3. In the event of termination under Sections 6.1 or 6.2
+  above, all end user licenses that have been validly granted
+  by You or any distributor hereunder prior to termination
+  (excluding licenses granted to You by any distributor)
+  shall survive termination.
+  
+  7. LIMITATION OF LIABILITY.
+  
+  UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT
+  (INCLUDING NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE
+  INITIAL DEVELOPER, ANY OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF
+  COVERED SOFTWARE, OR ANY SUPPLIER OF ANY OF SUCH PARTIES, BE
+  LIABLE TO ANY PERSON FOR ANY INDIRECT, SPECIAL, INCIDENTAL, OR
+  CONSEQUENTIAL DAMAGES OF ANY CHARACTER INCLUDING, WITHOUT
+  LIMITATION, DAMAGES FOR LOST PROFITS, LOSS OF GOODWILL, WORK
+  STOPPAGE, COMPUTER FAILURE OR MALFUNCTION, OR ANY AND ALL OTHER
+  COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH PARTY SHALL HAVE BEEN
+  INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS LIMITATION OF
+  LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL
+  INJURY RESULTING FROM SUCH PARTY"S NEGLIGENCE TO THE EXTENT
+  APPLICABLE LAW PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO
+  NOT ALLOW THE EXCLUSION OR LIMITATION OF INCIDENTAL OR
+  CONSEQUENTIAL DAMAGES, SO THIS EXCLUSION AND LIMITATION MAY NOT
+  APPLY TO YOU.
+  
+  8. U.S. GOVERNMENT END USERS.
+  
+  The Covered Software is a "commercial item," as that term is
+  defined in 48 C.F.R. 2.101 (Oct. 1995), consisting of "commercial
+  computer software" (as that term is defined at 48 C.F.R. "
+  252.227-7014(a)(1)) and "commercial computer software
+  documentation" as such terms are used in 48 C.F.R. 12.212 (Sept.
+  1995). Consistent with 48 C.F.R. 12.212 and 48 C.F.R. 227.7202-1
+  through 227.7202-4 (June 1995), all U.S. Government End Users
+  acquire Covered Software with only those rights set forth herein.
+  This U.S. Government Rights clause is in lieu of, and supersedes,
+  any other FAR, DFAR, or other clause or provision that addresses
+  Government rights in computer software under this License.
+  
+  9. MISCELLANEOUS.
+  
+  This License represents the complete agreement concerning subject
+  matter hereof. If any provision of this License is held to be
+  unenforceable, such provision shall be reformed only to the
+  extent necessary to make it enforceable. This License shall be
+  governed by the law of the jurisdiction specified in a notice
+  contained within the Original Software (except to the extent
+  applicable law, if any, provides otherwise), excluding such
+  jurisdiction"s conflict-of-law provisions. Any litigation
+  relating to this License shall be subject to the jurisdiction of
+  the courts located in the jurisdiction and venue specified in a
+  notice contained within the Original Software, with the losing
+  party responsible for costs, including, without limitation, court
+  costs and reasonable attorneys" fees and expenses. The
+  application of the United Nations Convention on Contracts for the
+  International Sale of Goods is expressly excluded. Any law or
+  regulation which provides that the language of a contract shall
+  be construed against the drafter shall not apply to this License.
+  You agree that You alone are responsible for compliance with the
+  United States export administration regulations (and the export
+  control laws and regulation of any other countries) when You use,
+  distribute or otherwise make available any Covered Software.
+  
+  10. RESPONSIBILITY FOR CLAIMS.
+  
+  As between Initial Developer and the Contributors, each party is
+  responsible for claims and damages arising, directly or
+  indirectly, out of its utilization of rights under this License
+  and You agree to work with Initial Developer and Contributors to
+  distribute such responsibility on an equitable basis. Nothing
+  herein is intended or shall be deemed to constitute any admission
+  of liability.
+  
+
+COMMON DEVELOPMENT AND DISTRIBUTION LICENSE (CDDL) Version 1.1
+
+  1. Definitions.
+  
+  1.1. “Contributor” means each individual or entity that creates or contributes
+  to the creation of Modifications.
+  
+  1.2. “Contributor Version” means the combination of the Original Software,
+  prior Modifications used by a Contributor (if any), and the Modifications made
+  by that particular Contributor.
+  
+  1.3. “Covered Software” means (a) the Original Software, or (b) Modifications,
+  or (c) the combination of files containing Original Software with files
+  containing Modifications, in each case including portions thereof.
+  
+  1.4. “Executable” means the Covered Software in any form other than Source
+  Code.
+  
+  1.5. “Initial Developer” means the individual or entity that first makes
+  Original Software available under this License.
+  
+  1.6. “Larger Work” means a work which combines Covered Software or portions
+  thereof with code not governed by the terms of this License.
+  
+  1.7. “License” means this document.
+  
+  1.8. “Licensable” means having the right to grant, to the maximum extent
+  possible, whether at the time of the initial grant or subsequently acquired,
+  any and all of the rights conveyed herein.
+  
+  1.9. “Modifications” means the Source Code and Executable form of any of the
+  following:
+  
+  A. Any file that results from an addition to, deletion from or modification of
+  the contents of a file containing Original Software or previous Modifications;
+  
+  B. Any new file that contains any part of the Original Software or previous
+  Modification; or
+  
+  C. Any new file that is contributed or otherwise made available under the terms
+  of this License.
+  
+  1.10. “Original Software” means the Source Code and Executable form of computer
+  software code that is originally released under this License.
+  
+  1.11. “Patent Claims” means any patent claim(s), now owned or hereafter
+  acquired, including without limitation, method, process, and apparatus claims,
+  in any patent Licensable by grantor.
+  
+  1.12. “Source Code” means (a) the common form of computer software code in
+  which modifications are made and (b) associated documentation included in or
+  with such code.
+  
+  1.13. “You” (or “Your”) means an individual or a legal entity exercising rights
+  under, and complying with all of the terms of, this License. For legal
+  entities, “You” includes any entity which controls, is controlled by, or is
+  under common control with You. For purposes of this definition, “control” means
+  (a) the power, direct or indirect, to cause the direction or management of such
+  entity, whether by contract or otherwise, or (b) ownership of more than fifty
+  percent (50%) of the outstanding shares or beneficial ownership of such entity.
+  
+  2. License Grants.
+  
+  2.1. The Initial Developer Grant.  Conditioned upon Your compliance with
+  Section 3.1 below and subject to third party intellectual property claims, the
+  Initial Developer hereby grants You a world-wide, royalty-free, non-exclusive
+  license:
+  
+  (a) under intellectual property rights (other than patent or trademark)
+  Licensable by Initial Developer, to use, reproduce, modify, display, perform,
+  sublicense and distribute the Original Software (or portions thereof), with or
+  without Modifications, and/or as part of a Larger Work; and
+  
+  (b) under Patent Claims infringed by the making, using or selling of Original
+  Software, to make, have made, use, practice, sell, and offer for sale, and/or
+  otherwise dispose of the Original Software (or portions thereof).
+  
+  (c) The licenses granted in Sections 2.1(a) and (b) are effective on the date
+  Initial Developer first distributes or otherwise makes the Original Software
+  available to a third party under the terms of this License.
+  
+  (d) Notwithstanding Section 2.1(b) above, no patent license is granted: (1) for
+  code that You delete from the Original Software, or (2) for infringements
+  caused by: (i) the modification of the Original Software, or (ii) the
+  combination of the Original Software with other software or devices.
+  
+  2.2. Contributor Grant.  Conditioned upon Your compliance with Section 3.1
+  below and subject to third party intellectual property claims, each Contributor
+  hereby grants You a world-wide, royalty-free, non-exclusive license:
+  
+  (a) under intellectual property rights (other than patent or trademark)
+  Licensable by Contributor to use, reproduce, modify, display, perform,
+  sublicense and distribute the Modifications created by such Contributor (or
+  portions thereof), either on an unmodified basis, with other Modifications, as
+  Covered Software and/or as part of a Larger Work; and
+  
+  (b) under Patent Claims infringed by the making, using, or selling of
+  Modifications made by that Contributor either alone and/or in combination with
+  its Contributor Version (or portions of such combination), to make, use, sell,
+  offer for sale, have made, and/or otherwise dispose of: (1) Modifications made
+  by that Contributor (or portions thereof); and (2) the combination of
+  Modifications made by that Contributor with its Contributor Version (or
+  portions of such combination).
+  
+  (c) The licenses granted in Sections 2.2(a) and 2.2(b) are effective on the
+  date Contributor first distributes or otherwise makes the Modifications
+  available to a third party.
+  
+  (d) Notwithstanding Section 2.2(b) above, no patent license is granted: (1) for
+  any code that Contributor has deleted from the Contributor Version; (2) for
+  infringements caused by: (i) third party modifications of Contributor Version,
+  or (ii) the combination of Modifications made by that Contributor with other
+  software (except as part of the Contributor Version) or other devices; or (3)
+  under Patent Claims infringed by Covered Software in the absence of
+  Modifications made by that Contributor.
+  
+  3. Distribution Obligations.
+  
+  3.1. Availability of Source Code.  Any Covered Software that You distribute or
+  otherwise make available in Executable form must also be made available in
+  Source Code form and that Source Code form must be distributed only under the
+  terms of this License. You must include a copy of this License with every copy
+  of the Source Code form of the Covered Software You distribute or otherwise
+  make available. You must inform recipients of any such Covered Software in
+  Executable form as to how they can obtain such Covered Software in Source Code
+  form in a reasonable manner on or through a medium customarily used for
+  software exchange.
+  
+  3.2. Modifications.  The Modifications that You create or to which You
+  contribute are governed by the terms of this License. You represent that You
+  believe Your Modifications are Your original creation(s) and/or You have
+  sufficient rights to grant the rights conveyed by this License.
+  
+  3.3. Required Notices.  You must include a notice in each of Your Modifications
+  that identifies You as the Contributor of the Modification. You may not remove
+  or alter any copyright, patent or trademark notices contained within the
+  Covered Software, or any notices of licensing or any descriptive text giving
+  attribution to any Contributor or the Initial Developer.
+  
+  3.4. Application of Additional Terms.  You may not offer or impose any terms on
+  any Covered Software in Source Code form that alters or restricts the
+  applicable version of this License or the recipients' rights hereunder. You may
+  choose to offer, and to charge a fee for, warranty, support, indemnity or
+  liability obligations to one or more recipients of Covered Software. However,
+  you may do so only on Your own behalf, and not on behalf of the Initial
+  Developer or any Contributor. You must make it absolutely clear that any such
+  warranty, support, indemnity or liability obligation is offered by You alone,
+  and You hereby agree to indemnify the Initial Developer and every Contributor
+  for any liability incurred by the Initial Developer or such Contributor as a
+  result of warranty, support, indemnity or liability terms You offer.
+  
+  3.5. Distribution of Executable Versions.  You may distribute the Executable
+  form of the Covered Software under the terms of this License or under the terms
+  of a license of Your choice, which may contain terms different from this
+  License, provided that You are in compliance with the terms of this License and
+  that the license for the Executable form does not attempt to limit or alter the
+  recipient's rights in the Source Code form from the rights set forth in this
+  License. If You distribute the Covered Software in Executable form under a
+  different license, You must make it absolutely clear that any terms which
+  differ from this License are offered by You alone, not by the Initial Developer
+  or Contributor. You hereby agree to indemnify the Initial Developer and every
+  Contributor for any liability incurred by the Initial Developer or such
+  Contributor as a result of any such terms You offer.
+  
+  3.6. Larger Works.  You may create a Larger Work by combining Covered Software
+  with other code not governed by the terms of this License and distribute the
+  Larger Work as a single product. In such a case, You must make sure the
+  requirements of this License are fulfilled for the Covered Software.
+  
+  4. Versions of the License.
+  
+  4.1. New Versions.  Oracle is the initial license steward and may publish
+  revised and/or new versions of this License from time to time. Each version
+  will be given a distinguishing version number. Except as provided in Section
+  4.3, no one other than the license steward has the right to modify this
+  License.
+  
+  4.2. Effect of New Versions.  You may always continue to use, distribute or
+  otherwise make the Covered Software available under the terms of the version of
+  the License under which You originally received the Covered Software. If the
+  Initial Developer includes a notice in the Original Software prohibiting it
+  from being distributed or otherwise made available under any subsequent version
+  of the License, You must distribute and make the Covered Software available
+  under the terms of the version of the License under which You originally
+  received the Covered Software. Otherwise, You may also choose to use,
+  distribute or otherwise make the Covered Software available under the terms of
+  any subsequent version of the License published by the license steward.
+  
+  4.3. Modified Versions.  When You are an Initial Developer and You want to
+  create a new license for Your Original Software, You may create and use a
+  modified version of this License if You: (a) rename the license and remove any
+  references to the name of the license steward (except to note that the license
+  differs from this License); and (b) otherwise make it clear that the license
+  contains terms which differ from this License.
+  
+  5. DISCLAIMER OF WARRANTY.  COVERED SOFTWARE IS PROVIDED UNDER THIS LICENSE ON
+  AN “AS IS” BASIS, WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED,
+  INCLUDING, WITHOUT LIMITATION, WARRANTIES THAT THE COVERED SOFTWARE IS FREE OF
+  DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR PURPOSE OR NON-INFRINGING. THE
+  ENTIRE RISK AS TO THE QUALITY AND PERFORMANCE OF THE COVERED SOFTWARE IS WITH
+  YOU. SHOULD ANY COVERED SOFTWARE PROVE DEFECTIVE IN ANY RESPECT, YOU (NOT THE
+  INITIAL DEVELOPER OR ANY OTHER CONTRIBUTOR) ASSUME THE COST OF ANY NECESSARY
+  SERVICING, REPAIR OR CORRECTION. THIS DISCLAIMER OF WARRANTY CONSTITUTES AN
+  ESSENTIAL PART OF THIS LICENSE. NO USE OF ANY COVERED SOFTWARE IS AUTHORIZED
+  HEREUNDER EXCEPT UNDER THIS DISCLAIMER.
+  
+  6. TERMINATION.
+  
+  6.1. This License and the rights granted hereunder will terminate automatically
+  if You fail to comply with terms herein and fail to cure such breach within 30
+  days of becoming aware of the breach. Provisions which, by their nature, must
+  remain in effect beyond the termination of this License shall survive.
+  
+  6.2. If You assert a patent infringement claim (excluding declaratory judgment
+  actions) against Initial Developer or a Contributor (the Initial Developer or
+  Contributor against whom You assert such claim is referred to as “Participant”)
+  alleging that the Participant Software (meaning the Contributor Version where
+  the Participant is a Contributor or the Original Software where the Participant
+  is the Initial Developer) directly or indirectly infringes any patent, then any
+  and all rights granted directly or indirectly to You by such Participant, the
+  Initial Developer (if the Initial Developer is not the Participant) and all
+  Contributors under Sections 2.1 and/or 2.2 of this License shall, upon 60 days
+  notice from Participant terminate prospectively and automatically at the
+  expiration of such 60 day notice period, unless if within such 60 day period
+  You withdraw Your claim with respect to the Participant Software against such
+  Participant either unilaterally or pursuant to a written agreement with
+  Participant.
+  
+  6.3. If You assert a patent infringement claim against Participant alleging
+  that the Participant Software directly or indirectly infringes any patent where
+  such claim is resolved (such as by license or settlement) prior to the
+  initiation of patent infringement litigation, then the reasonable value of the
+  licenses granted by such Participant under Sections 2.1 or 2.2 shall be taken
+  into account in determining the amount or value of any payment or license.
+  
+  6.4. In the event of termination under Sections 6.1 or 6.2 above, all end user
+  licenses that have been validly granted by You or any distributor hereunder
+  prior to termination (excluding licenses granted to You by any distributor)
+  shall survive termination.
+  
+  7. LIMITATION OF LIABILITY.
+  
+  UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT (INCLUDING
+  NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE INITIAL DEVELOPER, ANY
+  OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF COVERED SOFTWARE, OR ANY SUPPLIER OF
+  ANY OF SUCH PARTIES, BE LIABLE TO ANY PERSON FOR ANY INDIRECT, SPECIAL,
+  INCIDENTAL, OR CONSEQUENTIAL DAMAGES OF ANY CHARACTER INCLUDING, WITHOUT
+  LIMITATION, DAMAGES FOR LOSS OF GOODWILL, WORK STOPPAGE, COMPUTER FAILURE OR
+  MALFUNCTION, OR ANY AND ALL OTHER COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH
+  PARTY SHALL HAVE BEEN INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS
+  LIMITATION OF LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL
+  INJURY RESULTING FROM SUCH PARTY'S NEGLIGENCE TO THE EXTENT APPLICABLE LAW
+  PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO NOT ALLOW THE EXCLUSION OR
+  LIMITATION OF INCIDENTAL OR CONSEQUENTIAL DAMAGES, SO THIS EXCLUSION AND
+  LIMITATION MAY NOT APPLY TO YOU.
+  
+  8. U.S. GOVERNMENT END USERS.
+  
+  The Covered Software is a “commercial item,” as that term is defined in 48
+  C.F.R. 2.101 (Oct. 1995), consisting of “commercial computer software” (as that
+  term is defined at 48 C.F.R. § 252.227-7014(a)(1)) and “commercial computer
+  software documentation” as such terms are used in 48 C.F.R. 12.212 (Sept.
+  1995). Consistent with 48 C.F.R. 12.212 and 48 C.F.R. 227.7202-1 through
+  227.7202-4 (June 1995), all U.S. Government End Users acquire Covered Software
+  with only those rights set forth herein. This U.S. Government Rights clause is
+  in lieu of, and supersedes, any other FAR, DFAR, or other clause or provision
+  that addresses Government rights in computer software under this License.
+  
+  9. MISCELLANEOUS.
+  
+  This License represents the complete agreement concerning subject matter
+  hereof. If any provision of this License is held to be unenforceable, such
+  provision shall be reformed only to the extent necessary to make it
+  enforceable. This License shall be governed by the law of the jurisdiction
+  specified in a notice contained within the Original Software (except to the
+  extent applicable law, if any, provides otherwise), excluding such
+  jurisdiction's conflict-of-law provisions. Any litigation relating to this
+  License shall be subject to the jurisdiction of the courts located in the
+  jurisdiction and venue specified in a notice contained within the Original
+  Software, with the losing party responsible for costs, including, without
+  limitation, court costs and reasonable attorneys' fees and expenses. The
+  application of the United Nations Convention on Contracts for the International
+  Sale of Goods is expressly excluded. Any law or regulation which provides that
+  the language of a contract shall be construed against the drafter shall not
+  apply to this License. You agree that You alone are responsible for compliance
+  with the United States export administration regulations (and the export
+  control laws and regulation of any other countries) when You use, distribute or
+  otherwise make available any Covered Software.
+  
+  10. RESPONSIBILITY FOR CLAIMS.
+  
+  As between Initial Developer and the Contributors, each party is responsible
+  for claims and damages arising, directly or indirectly, out of its utilization
+  of rights under this License and You agree to work with Initial Developer and
+  Contributors to distribute such responsibility on an equitable basis. Nothing
+  herein is intended or shall be deemed to constitute any admission of liability.
+  
+  NOTICE PURSUANT TO SECTION 9 OF THE COMMON DEVELOPMENT AND DISTRIBUTION LICENSE
+  (CDDL) The code released under the CDDL shall be governed by the laws of the
+  State of California (excluding conflict-of-law provisions). Any litigation
+  relating to this License shall be subject to the jurisdiction of the Federal
+  Courts of the Northern District of California and the state courts of the State
+  of California, with venue lying in Santa Clara County, California.
+
+
+Eclipse Public License, version 1.0
+
+  THE ACCOMPANYING PROGRAM IS PROVIDED UNDER THE TERMS OF THIS ECLIPSE PUBLIC
+  LICENSE ("AGREEMENT"). ANY USE, REPRODUCTION OR DISTRIBUTION OF THE PROGRAM
+  CONSTITUTES RECIPIENT'S ACCEPTANCE OF THIS AGREEMENT.
+  
+  1. DEFINITIONS
+  
+  "Contribution" means:
+  
+  a) in the case of the initial Contributor, the initial code and documentation
+  distributed under this Agreement, and b) in the case of each subsequent
+  Contributor:
+  
+  i) changes to the Program, and
+  
+  ii) additions to the Program;
+  
+  where such changes and/or additions to the Program originate from and are
+  distributed by that particular Contributor. A Contribution 'originates' from a
+  Contributor if it was added to the Program by such Contributor itself or anyone
+  acting on such Contributor's behalf. Contributions do not include additions to
+  the Program which: (i) are separate modules of software distributed in
+  conjunction with the Program under their own license agreement, and (ii) are
+  not derivative works of the Program.
+  
+  "Contributor" means any person or entity that distributes the Program.
+  
+  "Licensed Patents " mean patent claims licensable by a Contributor which are
+  necessarily infringed by the use or sale of its Contribution alone or when
+  combined with the Program.
+  
+  "Program" means the Contributions distributed in accordance with this
+  Agreement.
+  
+  "Recipient" means anyone who receives the Program under this Agreement,


<TRUNCATED>

[23/51] [abbrv] brooklyn-dist git commit: correct references used in license-readme-generation for new project structure

Posted by he...@apache.org.
correct references used in license-readme-generation for new project structure


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

Branch: refs/heads/master
Commit: f61d6ac88e9775808fc467656a0a0328c68b5bf9
Parents: 00d8f4c
Author: Alex Heneveld <al...@cloudsoftcorp.com>
Authored: Fri Jan 15 15:04:11 2016 +0000
Committer: Alex Heneveld <al...@cloudsoftcorp.com>
Committed: Fri Jan 15 15:05:34 2016 +0000

----------------------------------------------------------------------
 brooklyn-dist/dist/licensing/extras-files       |  2 +-
 .../licensing/licenses/brooklyn-ui/BSD-2-Clause | 23 +++++++++++++++++
 .../licensing/licenses/brooklyn-ui/BSD-3-Clause | 27 ++++++++++++++++++++
 .../dist/licensing/licenses/brooklyn-ui/MIT     | 20 +++++++++++++++
 brooklyn-dist/dist/licensing/licenses/cli/MIT   | 20 ---------------
 .../dist/licensing/licenses/jsgui/BSD-2-Clause  | 23 -----------------
 .../dist/licensing/licenses/jsgui/BSD-3-Clause  | 27 --------------------
 brooklyn-dist/dist/licensing/licenses/jsgui/MIT | 20 ---------------
 .../dist/licensing/licenses/server-cli/MIT      | 20 +++++++++++++++
 .../licensing/projects-with-custom-licenses     |  4 +--
 10 files changed, 93 insertions(+), 93 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/f61d6ac8/brooklyn-dist/dist/licensing/extras-files
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/extras-files b/brooklyn-dist/dist/licensing/extras-files
index bb4a3b3..cbba9c5 100644
--- a/brooklyn-dist/dist/licensing/extras-files
+++ b/brooklyn-dist/dist/licensing/extras-files
@@ -1 +1 @@
-../jsgui/src/main/license/source-inclusions.yaml:../cli/src/main/license/source-inclusions.yaml
+../../brooklyn-ui/src/main/license/source-inclusions.yaml:../../brooklyn-server/server-cli/src/main/license/source-inclusions.yaml

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/f61d6ac8/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/BSD-2-Clause
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/BSD-2-Clause b/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/BSD-2-Clause
new file mode 100644
index 0000000..832c10e
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/BSD-2-Clause
@@ -0,0 +1,23 @@
+The BSD 2-Clause License
+
+  Redistribution and use in source and binary forms, with or without
+  modification, are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, this
+  list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice,
+  this list of conditions and the following disclaimer in the documentation
+  and/or other materials provided with the distribution.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
+  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
+  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
+  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
+  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
+  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
+  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
+  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/f61d6ac8/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/BSD-3-Clause
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/BSD-3-Clause b/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/BSD-3-Clause
new file mode 100644
index 0000000..be2692c
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/BSD-3-Clause
@@ -0,0 +1,27 @@
+The BSD 3-Clause License ("New BSD")
+
+  Redistribution and use in source and binary forms, with or without modification,
+  are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, 
+  this list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice, 
+  this list of conditions and the following disclaimer in the documentation 
+  and/or other materials provided with the distribution.
+  
+  3. Neither the name of the copyright holder nor the names of its contributors 
+  may be used to endorse or promote products derived from this software without 
+  specific prior written permission.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
+  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
+  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
+  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
+  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
+  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
+  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
+  POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/f61d6ac8/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/MIT
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/MIT b/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/MIT
new file mode 100644
index 0000000..71dfb45
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/brooklyn-ui/MIT
@@ -0,0 +1,20 @@
+The MIT License ("MIT")
+
+  Permission is hereby granted, free of charge, to any person obtaining a copy
+  of this software and associated documentation files (the "Software"), to deal
+  in the Software without restriction, including without limitation the rights
+  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
+  copies of the Software, and to permit persons to whom the Software is
+  furnished to do so, subject to the following conditions:
+  
+  The above copyright notice and this permission notice shall be included in
+  all copies or substantial portions of the Software.
+  
+  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
+  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
+  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
+  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
+  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
+  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
+  THE SOFTWARE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/f61d6ac8/brooklyn-dist/dist/licensing/licenses/cli/MIT
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/cli/MIT b/brooklyn-dist/dist/licensing/licenses/cli/MIT
deleted file mode 100644
index 71dfb45..0000000
--- a/brooklyn-dist/dist/licensing/licenses/cli/MIT
+++ /dev/null
@@ -1,20 +0,0 @@
-The MIT License ("MIT")
-
-  Permission is hereby granted, free of charge, to any person obtaining a copy
-  of this software and associated documentation files (the "Software"), to deal
-  in the Software without restriction, including without limitation the rights
-  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
-  copies of the Software, and to permit persons to whom the Software is
-  furnished to do so, subject to the following conditions:
-  
-  The above copyright notice and this permission notice shall be included in
-  all copies or substantial portions of the Software.
-  
-  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
-  THE SOFTWARE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/f61d6ac8/brooklyn-dist/dist/licensing/licenses/jsgui/BSD-2-Clause
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/jsgui/BSD-2-Clause b/brooklyn-dist/dist/licensing/licenses/jsgui/BSD-2-Clause
deleted file mode 100644
index 832c10e..0000000
--- a/brooklyn-dist/dist/licensing/licenses/jsgui/BSD-2-Clause
+++ /dev/null
@@ -1,23 +0,0 @@
-The BSD 2-Clause License
-
-  Redistribution and use in source and binary forms, with or without
-  modification, are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, this
-  list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice,
-  this list of conditions and the following disclaimer in the documentation
-  and/or other materials provided with the distribution.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
-  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
-  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
-  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
-  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
-  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
-  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
-  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/f61d6ac8/brooklyn-dist/dist/licensing/licenses/jsgui/BSD-3-Clause
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/jsgui/BSD-3-Clause b/brooklyn-dist/dist/licensing/licenses/jsgui/BSD-3-Clause
deleted file mode 100644
index be2692c..0000000
--- a/brooklyn-dist/dist/licensing/licenses/jsgui/BSD-3-Clause
+++ /dev/null
@@ -1,27 +0,0 @@
-The BSD 3-Clause License ("New BSD")
-
-  Redistribution and use in source and binary forms, with or without modification,
-  are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, 
-  this list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice, 
-  this list of conditions and the following disclaimer in the documentation 
-  and/or other materials provided with the distribution.
-  
-  3. Neither the name of the copyright holder nor the names of its contributors 
-  may be used to endorse or promote products derived from this software without 
-  specific prior written permission.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
-  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
-  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
-  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
-  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
-  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
-  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
-  POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/f61d6ac8/brooklyn-dist/dist/licensing/licenses/jsgui/MIT
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/jsgui/MIT b/brooklyn-dist/dist/licensing/licenses/jsgui/MIT
deleted file mode 100644
index 71dfb45..0000000
--- a/brooklyn-dist/dist/licensing/licenses/jsgui/MIT
+++ /dev/null
@@ -1,20 +0,0 @@
-The MIT License ("MIT")
-
-  Permission is hereby granted, free of charge, to any person obtaining a copy
-  of this software and associated documentation files (the "Software"), to deal
-  in the Software without restriction, including without limitation the rights
-  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
-  copies of the Software, and to permit persons to whom the Software is
-  furnished to do so, subject to the following conditions:
-  
-  The above copyright notice and this permission notice shall be included in
-  all copies or substantial portions of the Software.
-  
-  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
-  THE SOFTWARE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/f61d6ac8/brooklyn-dist/dist/licensing/licenses/server-cli/MIT
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/server-cli/MIT b/brooklyn-dist/dist/licensing/licenses/server-cli/MIT
new file mode 100644
index 0000000..71dfb45
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/server-cli/MIT
@@ -0,0 +1,20 @@
+The MIT License ("MIT")
+
+  Permission is hereby granted, free of charge, to any person obtaining a copy
+  of this software and associated documentation files (the "Software"), to deal
+  in the Software without restriction, including without limitation the rights
+  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
+  copies of the Software, and to permit persons to whom the Software is
+  furnished to do so, subject to the following conditions:
+  
+  The above copyright notice and this permission notice shall be included in
+  all copies or substantial portions of the Software.
+  
+  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
+  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
+  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
+  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
+  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
+  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
+  THE SOFTWARE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/f61d6ac8/brooklyn-dist/dist/licensing/projects-with-custom-licenses
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/projects-with-custom-licenses b/brooklyn-dist/dist/licensing/projects-with-custom-licenses
index ebf210c..97839fc 100644
--- a/brooklyn-dist/dist/licensing/projects-with-custom-licenses
+++ b/brooklyn-dist/dist/licensing/projects-with-custom-licenses
@@ -1,2 +1,2 @@
-../jsgui
-../cli
+../../brooklyn-ui
+../../brooklyn-server/server-cli


[34/51] [abbrv] brooklyn-dist git commit: change-version: improve echo msg

Posted by he...@apache.org.
change-version: improve echo msg

Project: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/repo
Commit: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/commit/61128a9b
Tree: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/tree/61128a9b
Diff: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/diff/61128a9b

Branch: refs/heads/master
Commit: 61128a9b3ae72db9c2302718e409ce816532da2e
Parents: 7f9016f
Author: Aled Sage <al...@gmail.com>
Authored: Mon Jan 25 17:26:15 2016 +0000
Committer: Aled Sage <al...@gmail.com>
Committed: Mon Jan 25 17:26:15 2016 +0000

----------------------------------------------------------------------
 brooklyn-dist/release/change-version.sh | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/61128a9b/brooklyn-dist/release/change-version.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/release/change-version.sh b/brooklyn-dist/release/change-version.sh
index 280c245..4b77749 100755
--- a/brooklyn-dist/release/change-version.sh
+++ b/brooklyn-dist/release/change-version.sh
@@ -66,5 +66,5 @@ if [ ${FILES_COUNT} -ne 0 ]; then
     sed -i.bak -e "/${VERSION_MARKER_NL}/{n;s/${CURRENT_VERSION}/${NEW_VERSION}/g;}" $FILES
 fi
 
-echo "Changed ${CURRENT_VERSION} to ${NEW_VERSION} for "${FILES_COUNT}" files"
+echo "Changed ${VERSION_MARKER} from ${CURRENT_VERSION} to ${NEW_VERSION} for "${FILES_COUNT}" files"
 echo "(Do a \`find . -name \"*.bak\" -delete\`  to delete the backup files.)"


[08/51] [abbrv] brooklyn-dist git commit: [SPLITPREP] rearranged to have structure of new repositories

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/binary/EPL1
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/EPL1 b/brooklyn-dist/dist/licensing/licenses/binary/EPL1
new file mode 100644
index 0000000..6891076
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/binary/EPL1
@@ -0,0 +1,212 @@
+Eclipse Public License, version 1.0
+
+  THE ACCOMPANYING PROGRAM IS PROVIDED UNDER THE TERMS OF THIS ECLIPSE PUBLIC
+  LICENSE ("AGREEMENT"). ANY USE, REPRODUCTION OR DISTRIBUTION OF THE PROGRAM
+  CONSTITUTES RECIPIENT'S ACCEPTANCE OF THIS AGREEMENT.
+  
+  1. DEFINITIONS
+  
+  "Contribution" means:
+  
+  a) in the case of the initial Contributor, the initial code and documentation
+  distributed under this Agreement, and b) in the case of each subsequent
+  Contributor:
+  
+  i) changes to the Program, and
+  
+  ii) additions to the Program;
+  
+  where such changes and/or additions to the Program originate from and are
+  distributed by that particular Contributor. A Contribution 'originates' from a
+  Contributor if it was added to the Program by such Contributor itself or anyone
+  acting on such Contributor's behalf. Contributions do not include additions to
+  the Program which: (i) are separate modules of software distributed in
+  conjunction with the Program under their own license agreement, and (ii) are
+  not derivative works of the Program.
+  
+  "Contributor" means any person or entity that distributes the Program.
+  
+  "Licensed Patents " mean patent claims licensable by a Contributor which are
+  necessarily infringed by the use or sale of its Contribution alone or when
+  combined with the Program.
+  
+  "Program" means the Contributions distributed in accordance with this
+  Agreement.
+  
+  "Recipient" means anyone who receives the Program under this Agreement,
+  including all Contributors.
+  
+  2. GRANT OF RIGHTS
+  
+  a) Subject to the terms of this Agreement, each Contributor hereby grants
+  Recipient a non-exclusive, worldwide, royalty-free copyright license to
+  reproduce, prepare derivative works of, publicly display, publicly perform,
+  distribute and sublicense the Contribution of such Contributor, if any, and
+  such derivative works, in source code and object code form.
+  
+  b) Subject to the terms of this Agreement, each Contributor hereby grants
+  Recipient a non-exclusive, worldwide, royalty-free patent license under
+  Licensed Patents to make, use, sell, offer to sell, import and otherwise
+  transfer the Contribution of such Contributor, if any, in source code and
+  object code form. This patent license shall apply to the combination of the
+  Contribution and the Program if, at the time the Contribution is added by the
+  Contributor, such addition of the Contribution causes such combination to be
+  covered by the Licensed Patents. The patent license shall not apply to any
+  other combinations which include the Contribution. No hardware per se is
+  licensed hereunder.
+  
+  c) Recipient understands that although each Contributor grants the licenses to
+  its Contributions set forth herein, no assurances are provided by any
+  Contributor that the Program does not infringe the patent or other intellectual
+  property rights of any other entity. Each Contributor disclaims any liability
+  to Recipient for claims brought by any other entity based on infringement of
+  intellectual property rights or otherwise. As a condition to exercising the
+  rights and licenses granted hereunder, each Recipient hereby assumes sole
+  responsibility to secure any other intellectual property rights needed, if any.
+  For example, if a third party patent license is required to allow Recipient to
+  distribute the Program, it is Recipient's responsibility to acquire that
+  license before distributing the Program.
+  
+  d) Each Contributor represents that to its knowledge it has sufficient
+  copyright rights in its Contribution, if any, to grant the copyright license
+  set forth in this Agreement.
+  
+  3. REQUIREMENTS
+  
+  A Contributor may choose to distribute the Program in object code form under
+  its own license agreement, provided that:
+  
+  a) it complies with the terms and conditions of this Agreement; and
+  
+  b) its license agreement:
+  
+  i) effectively disclaims on behalf of all Contributors all warranties and
+  conditions, express and implied, including warranties or conditions of title
+  and non-infringement, and implied warranties or conditions of merchantability
+  and fitness for a particular purpose;
+  
+  ii) effectively excludes on behalf of all Contributors all liability for
+  damages, including direct, indirect, special, incidental and consequential
+  damages, such as lost profits;
+  
+  iii) states that any provisions which differ from this Agreement are offered by
+  that Contributor alone and not by any other party; and
+  
+  iv) states that source code for the Program is available from such Contributor,
+  and informs licensees how to obtain it in a reasonable manner on or through a
+  medium customarily used for software exchange.
+  
+  When the Program is made available in source code form:
+  
+  a) it must be made available under this Agreement; and
+  
+  b) a copy of this Agreement must be included with each copy of the Program.
+  
+  Contributors may not remove or alter any copyright notices contained within the
+  Program.
+  
+  Each Contributor must identify itself as the originator of its Contribution, if
+  any, in a manner that reasonably allows subsequent Recipients to identify the
+  originator of the Contribution.
+  
+  4. COMMERCIAL DISTRIBUTION
+  
+  Commercial distributors of software may accept certain responsibilities with
+  respect to end users, business partners and the like. While this license is
+  intended to facilitate the commercial use of the Program, the Contributor who
+  includes the Program in a commercial product offering should do so in a manner
+  which does not create potential liability for other Contributors. Therefore, if
+  a Contributor includes the Program in a commercial product offering, such
+  Contributor ("Commercial Contributor") hereby agrees to defend and indemnify
+  every other Contributor ("Indemnified Contributor") against any losses, damages
+  and costs (collectively "Losses") arising from claims, lawsuits and other legal
+  actions brought by a third party against the Indemnified Contributor to the
+  extent caused by the acts or omissions of such Commercial Contributor in
+  connection with its distribution of the Program in a commercial product
+  offering. The obligations in this section do not apply to any claims or Losses
+  relating to any actual or alleged intellectual property infringement. In order
+  to qualify, an Indemnified Contributor must: a) promptly notify the Commercial
+  Contributor in writing of such claim, and b) allow the Commercial Contributor
+  to control, and cooperate with the Commercial Contributor in, the defense and
+  any related settlement negotiations. The Indemnified Contributor may
+  participate in any such claim at its own expense.
+  
+  For example, a Contributor might include the Program in a commercial product
+  offering, Product X. That Contributor is then a Commercial Contributor. If that
+  Commercial Contributor then makes performance claims, or offers warranties
+  related to Product X, those performance claims and warranties are such
+  Commercial Contributor's responsibility alone. Under this section, the
+  Commercial Contributor would have to defend claims against the other
+  Contributors related to those performance claims and warranties, and if a court
+  requires any other Contributor to pay any damages as a result, the Commercial
+  Contributor must pay those damages.
+  
+  5. NO WARRANTY
+  
+  EXCEPT AS EXPRESSLY SET FORTH IN THIS AGREEMENT, THE PROGRAM IS PROVIDED ON AN
+  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, EITHER EXPRESS OR
+  IMPLIED INCLUDING, WITHOUT LIMITATION, ANY WARRANTIES OR CONDITIONS OF TITLE,
+  NON-INFRINGEMENT, MERCHANTABILITY OR FITNESS FOR A PARTICULAR PURPOSE. Each
+  Recipient is solely responsible for determining the appropriateness of using
+  and distributing the Program and assumes all risks associated with its exercise
+  of rights under this Agreement , including but not limited to the risks and
+  costs of program errors, compliance with applicable laws, damage to or loss of
+  data, programs or equipment, and unavailability or interruption of operations.
+  
+  6. DISCLAIMER OF LIABILITY
+  
+  EXCEPT AS EXPRESSLY SET FORTH IN THIS AGREEMENT, NEITHER RECIPIENT NOR ANY
+  CONTRIBUTORS SHALL HAVE ANY LIABILITY FOR ANY DIRECT, INDIRECT, INCIDENTAL,
+  SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING WITHOUT LIMITATION LOST
+  PROFITS), HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT,
+  STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY
+  WAY OUT OF THE USE OR DISTRIBUTION OF THE PROGRAM OR THE EXERCISE OF ANY RIGHTS
+  GRANTED HEREUNDER, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGES.
+  
+  7. GENERAL
+  
+  If any provision of this Agreement is invalid or unenforceable under applicable
+  law, it shall not affect the validity or enforceability of the remainder of the
+  terms of this Agreement, and without further action by the parties hereto, such
+  provision shall be reformed to the minimum extent necessary to make such
+  provision valid and enforceable.
+  
+  If Recipient institutes patent litigation against any entity (including a
+  cross-claim or counterclaim in a lawsuit) alleging that the Program itself
+  (excluding combinations of the Program with other software or hardware)
+  infringes such Recipient's patent(s), then such Recipient's rights granted
+  under Section 2(b) shall terminate as of the date such litigation is filed.
+  
+  All Recipient's rights under this Agreement shall terminate if it fails to
+  comply with any of the material terms or conditions of this Agreement and does
+  not cure such failure in a reasonable period of time after becoming aware of
+  such noncompliance. If all Recipient's rights under this Agreement terminate,
+  Recipient agrees to cease use and distribution of the Program as soon as
+  reasonably practicable. However, Recipient's obligations under this Agreement
+  and any licenses granted by Recipient relating to the Program shall continue
+  and survive.
+  
+  Everyone is permitted to copy and distribute copies of this Agreement, but in
+  order to avoid inconsistency the Agreement is copyrighted and may only be
+  modified in the following manner. The Agreement Steward reserves the right to
+  publish new versions (including revisions) of this Agreement from time to time.
+  No one other than the Agreement Steward has the right to modify this Agreement.
+  The Eclipse Foundation is the initial Agreement Steward. The Eclipse Foundation
+  may assign the responsibility to serve as the Agreement Steward to a suitable
+  separate entity. Each new version of the Agreement will be given a
+  distinguishing version number. The Program (including Contributions) may always
+  be distributed subject to the version of the Agreement under which it was
+  received. In addition, after a new version of the Agreement is published,
+  Contributor may elect to distribute the Program (including its Contributions)
+  under the new version. Except as expressly stated in Sections 2(a) and 2(b)
+  above, Recipient receives no rights or licenses to the intellectual property of
+  any Contributor under this Agreement, whether expressly, by implication,
+  estoppel or otherwise. All rights in the Program not expressly granted under
+  this Agreement are reserved.
+  
+  This Agreement is governed by the laws of the State of New York and the
+  intellectual property laws of the United States of America. No party to this
+  Agreement will bring a legal action under this Agreement more than one year
+  after the cause of action arose. Each party waives its rights to a jury trial
+  in any resulting litigation.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/binary/MIT
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/MIT b/brooklyn-dist/dist/licensing/licenses/binary/MIT
new file mode 100644
index 0000000..71dfb45
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/binary/MIT
@@ -0,0 +1,20 @@
+The MIT License ("MIT")
+
+  Permission is hereby granted, free of charge, to any person obtaining a copy
+  of this software and associated documentation files (the "Software"), to deal
+  in the Software without restriction, including without limitation the rights
+  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
+  copies of the Software, and to permit persons to whom the Software is
+  furnished to do so, subject to the following conditions:
+  
+  The above copyright notice and this permission notice shall be included in
+  all copies or substantial portions of the Software.
+  
+  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
+  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
+  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
+  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
+  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
+  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
+  THE SOFTWARE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/binary/WTFPL
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/WTFPL b/brooklyn-dist/dist/licensing/licenses/binary/WTFPL
new file mode 100644
index 0000000..03c1695
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/binary/WTFPL
@@ -0,0 +1,15 @@
+WTF Public License
+
+  DO WHAT THE FUCK YOU WANT TO PUBLIC LICENSE, Version 2, December 2004 
+ 
+  Copyright (C) 2004 Sam Hocevar <sa...@hocevar.net> 
+ 
+  Everyone is permitted to copy and distribute verbatim or modified 
+  copies of this license document, and changing it is allowed as long 
+  as the name is changed. 
+ 
+             DO WHAT THE FUCK YOU WANT TO PUBLIC LICENSE 
+    TERMS AND CONDITIONS FOR COPYING, DISTRIBUTION AND MODIFICATION 
+ 
+   0. You just DO WHAT THE FUCK YOU WANT TO.
+ 

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/binary/bouncycastle
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/bouncycastle b/brooklyn-dist/dist/licensing/licenses/binary/bouncycastle
new file mode 100644
index 0000000..8589a0b
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/binary/bouncycastle
@@ -0,0 +1,23 @@
+Bouncy Castle License
+  
+  Copyright (c) 2000 - 2015 The Legion of the Bouncy Castle Inc.
+  (http://www.bouncycastle.org)
+  
+  Permission is hereby granted, free of charge, to any person obtaining a copy of
+  this software and associated documentation files (the "Software"), to deal in
+  the Software without restriction, including without limitation the rights to
+  use, copy, modify, merge, publish, distribute, sublicense, and/or sell copies
+  of the Software, and to permit persons to whom the Software is furnished to do
+  so, subject to the following conditions:
+  
+  The above copyright notice and this permission notice shall be included in all
+  copies or substantial portions of the Software.
+  
+  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
+  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
+  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
+  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
+  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
+  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE
+  SOFTWARE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/binary/jtidy
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/jtidy b/brooklyn-dist/dist/licensing/licenses/binary/jtidy
new file mode 100644
index 0000000..0bcb614
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/binary/jtidy
@@ -0,0 +1,53 @@
+JTidy License
+
+  Java HTML Tidy - JTidy
+  HTML parser and pretty printer
+  
+  Copyright (c) 1998-2000 World Wide Web Consortium (Massachusetts
+  Institute of Technology, Institut National de Recherche en
+  Informatique et en Automatique, Keio University). All Rights
+  Reserved.
+  
+  Contributing Author(s):
+  
+     Dave Raggett <ds...@w3.org>
+     Andy Quick <ac...@sympatico.ca> (translation to Java)
+     Gary L Peskin <ga...@firstech.com> (Java development)
+     Sami Lempinen <sa...@lempinen.net> (release management)
+     Fabrizio Giustina <fgiust at users.sourceforge.net>
+  
+  The contributing author(s) would like to thank all those who
+  helped with testing, bug fixes, and patience.  This wouldn't
+  have been possible without all of you.
+  
+  COPYRIGHT NOTICE:
+   
+  This software and documentation is provided "as is," and
+  the copyright holders and contributing author(s) make no
+  representations or warranties, express or implied, including
+  but not limited to, warranties of merchantability or fitness
+  for any particular purpose or that the use of the software or
+  documentation will not infringe any third party patents,
+  copyrights, trademarks or other rights. 
+  
+  The copyright holders and contributing author(s) will not be
+  liable for any direct, indirect, special or consequential damages
+  arising out of any use of the software or documentation, even if
+  advised of the possibility of such damage.
+  
+  Permission is hereby granted to use, copy, modify, and distribute
+  this source code, or portions hereof, documentation and executables,
+  for any purpose, without fee, subject to the following restrictions:
+  
+  1. The origin of this source code must not be misrepresented.
+  2. Altered versions must be plainly marked as such and must
+     not be misrepresented as being the original source.
+  3. This Copyright notice may not be removed or altered from any
+     source or altered source distribution.
+   
+  The copyright holders and contributing author(s) specifically
+  permit, without fee, and encourage the use of this source code
+  as a component for supporting the Hypertext Markup Language in
+  commercial products. If you use this source code in a product,
+  acknowledgment is not required but would be appreciated.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/binary/jython
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/jython b/brooklyn-dist/dist/licensing/licenses/binary/jython
new file mode 100644
index 0000000..b2258d4
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/binary/jython
@@ -0,0 +1,27 @@
+Jython License
+
+  Jython 2.0, 2.1 License
+  
+  Copyright (c) 2000, 2001, 2002, 2003, 2004, 2005, 2006, 2007 Jython Developers All rights reserved.
+  
+  Redistribution and use in source and binary forms, with or without modification, are permitted provided 
+  that the following conditions are met:
+  
+  Redistributions of source code must retain the above copyright notice, this list of conditions and the 
+  following disclaimer.
+  
+  Redistributions in binary form must reproduce the above copyright notice, this list of conditions and 
+  the following disclaimer in the documentation and/or other materials provided with the distribution.
+  Neither the name of the Jython Developers nor the names of its contributors may be used to endorse or 
+  promote products derived from this software without specific prior written permission.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS'' AND ANY EXPRESS OR IMPLIED 
+  WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A 
+  PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE REGENTS OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
+  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO, 
+  PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) 
+  HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING 
+  NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
+  POSSIBILITY OF SUCH DAMAGE.
+  
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/binary/metastuff-bsd-style
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/metastuff-bsd-style b/brooklyn-dist/dist/licensing/licenses/binary/metastuff-bsd-style
new file mode 100644
index 0000000..6bb4ef6
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/binary/metastuff-bsd-style
@@ -0,0 +1,43 @@
+MetaStuff BSD Style License
+
+  Copyright 2001-2005 (C) MetaStuff, Ltd. All Rights Reserved.
+  
+  Redistribution and use of this software and associated documentation
+  ("Software"), with or without modification, are permitted provided
+  that the following conditions are met:
+  
+  1. Redistributions of source code must retain copyright
+     statements and notices.  Redistributions must also contain a
+     copy of this document.
+  
+  2. Redistributions in binary form must reproduce the
+     above copyright notice, this list of conditions and the
+     following disclaimer in the documentation and/or other
+     materials provided with the distribution.
+  
+  3. The name "DOM4J" must not be used to endorse or promote
+     products derived from this Software without prior written
+     permission of MetaStuff, Ltd.  For written permission,
+     please contact dom4j-info@metastuff.com.
+  
+  4. Products derived from this Software may not be called "DOM4J"
+     nor may "DOM4J" appear in their names without prior written
+     permission of MetaStuff, Ltd. DOM4J is a registered
+     trademark of MetaStuff, Ltd.
+  
+  5. Due credit should be given to the DOM4J Project -
+     http://www.dom4j.org
+  
+  THIS SOFTWARE IS PROVIDED BY METASTUFF, LTD. AND CONTRIBUTORS
+  ``AS IS'' AND ANY EXPRESSED OR IMPLIED WARRANTIES, INCLUDING, BUT
+  NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND
+  FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED.  IN NO EVENT SHALL
+  METASTUFF, LTD. OR ITS CONTRIBUTORS BE LIABLE FOR ANY DIRECT,
+  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES
+  (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
+  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION)
+  HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT,
+  STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE)
+  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED
+  OF THE POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/binary/xpp3_indiana_university
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/binary/xpp3_indiana_university b/brooklyn-dist/dist/licensing/licenses/binary/xpp3_indiana_university
new file mode 100644
index 0000000..7d69a29
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/binary/xpp3_indiana_university
@@ -0,0 +1,45 @@
+Indiana University Extreme! Lab Software License, Version 1.1.1
+
+  Copyright (c) 2002 Extreme! Lab, Indiana University. All rights reserved.
+  
+  Redistribution and use in source and binary forms, with or without
+  modification, are permitted provided that the following conditions
+  are met:
+  
+  1. Redistributions of source code must retain the above copyright notice,
+     this list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright
+     notice, this list of conditions and the following disclaimer in
+     the documentation and/or other materials provided with the distribution.
+  
+  3. The end-user documentation included with the redistribution, if any,
+     must include the following acknowledgment:
+  
+    "This product includes software developed by the Indiana University
+    Extreme! Lab (http://www.extreme.indiana.edu/)."
+  
+  Alternately, this acknowledgment may appear in the software itself,
+  if and wherever such third-party acknowledgments normally appear.
+  
+  4. The names "Indiana Univeristy" and "Indiana Univeristy Extreme! Lab"
+  must not be used to endorse or promote products derived from this
+  software without prior written permission. For written permission,
+  please contact http://www.extreme.indiana.edu/.
+  
+  5. Products derived from this software may not use "Indiana Univeristy"
+  name nor may "Indiana Univeristy" appear in their name, without prior
+  written permission of the Indiana University.
+  
+  THIS SOFTWARE IS PROVIDED "AS IS" AND ANY EXPRESSED OR IMPLIED
+  WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF
+  MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED.
+  IN NO EVENT SHALL THE AUTHORS, COPYRIGHT HOLDERS OR ITS CONTRIBUTORS
+  BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR
+  CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF
+  SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR PROFITS; OR
+  BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY,
+  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR
+  OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF
+  ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/cli/MIT
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/cli/MIT b/brooklyn-dist/dist/licensing/licenses/cli/MIT
new file mode 100644
index 0000000..71dfb45
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/cli/MIT
@@ -0,0 +1,20 @@
+The MIT License ("MIT")
+
+  Permission is hereby granted, free of charge, to any person obtaining a copy
+  of this software and associated documentation files (the "Software"), to deal
+  in the Software without restriction, including without limitation the rights
+  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
+  copies of the Software, and to permit persons to whom the Software is
+  furnished to do so, subject to the following conditions:
+  
+  The above copyright notice and this permission notice shall be included in
+  all copies or substantial portions of the Software.
+  
+  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
+  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
+  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
+  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
+  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
+  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
+  THE SOFTWARE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/jsgui/BSD-2-Clause
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/jsgui/BSD-2-Clause b/brooklyn-dist/dist/licensing/licenses/jsgui/BSD-2-Clause
new file mode 100644
index 0000000..832c10e
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/jsgui/BSD-2-Clause
@@ -0,0 +1,23 @@
+The BSD 2-Clause License
+
+  Redistribution and use in source and binary forms, with or without
+  modification, are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, this
+  list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice,
+  this list of conditions and the following disclaimer in the documentation
+  and/or other materials provided with the distribution.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
+  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
+  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
+  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
+  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
+  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
+  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
+  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/jsgui/BSD-3-Clause
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/jsgui/BSD-3-Clause b/brooklyn-dist/dist/licensing/licenses/jsgui/BSD-3-Clause
new file mode 100644
index 0000000..be2692c
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/jsgui/BSD-3-Clause
@@ -0,0 +1,27 @@
+The BSD 3-Clause License ("New BSD")
+
+  Redistribution and use in source and binary forms, with or without modification,
+  are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, 
+  this list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice, 
+  this list of conditions and the following disclaimer in the documentation 
+  and/or other materials provided with the distribution.
+  
+  3. Neither the name of the copyright holder nor the names of its contributors 
+  may be used to endorse or promote products derived from this software without 
+  specific prior written permission.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
+  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
+  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
+  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
+  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
+  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
+  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
+  POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/jsgui/MIT
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/jsgui/MIT b/brooklyn-dist/dist/licensing/licenses/jsgui/MIT
new file mode 100644
index 0000000..71dfb45
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/jsgui/MIT
@@ -0,0 +1,20 @@
+The MIT License ("MIT")
+
+  Permission is hereby granted, free of charge, to any person obtaining a copy
+  of this software and associated documentation files (the "Software"), to deal
+  in the Software without restriction, including without limitation the rights
+  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
+  copies of the Software, and to permit persons to whom the Software is
+  furnished to do so, subject to the following conditions:
+  
+  The above copyright notice and this permission notice shall be included in
+  all copies or substantial portions of the Software.
+  
+  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
+  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
+  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
+  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
+  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
+  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
+  THE SOFTWARE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/source/BSD-2-Clause
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/source/BSD-2-Clause b/brooklyn-dist/dist/licensing/licenses/source/BSD-2-Clause
new file mode 100644
index 0000000..832c10e
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/source/BSD-2-Clause
@@ -0,0 +1,23 @@
+The BSD 2-Clause License
+
+  Redistribution and use in source and binary forms, with or without
+  modification, are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, this
+  list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice,
+  this list of conditions and the following disclaimer in the documentation
+  and/or other materials provided with the distribution.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
+  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
+  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
+  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
+  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
+  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
+  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
+  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/source/BSD-3-Clause
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/source/BSD-3-Clause b/brooklyn-dist/dist/licensing/licenses/source/BSD-3-Clause
new file mode 100644
index 0000000..be2692c
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/source/BSD-3-Clause
@@ -0,0 +1,27 @@
+The BSD 3-Clause License ("New BSD")
+
+  Redistribution and use in source and binary forms, with or without modification,
+  are permitted provided that the following conditions are met:
+  
+  1. Redistributions of source code must retain the above copyright notice, 
+  this list of conditions and the following disclaimer.
+  
+  2. Redistributions in binary form must reproduce the above copyright notice, 
+  this list of conditions and the following disclaimer in the documentation 
+  and/or other materials provided with the distribution.
+  
+  3. Neither the name of the copyright holder nor the names of its contributors 
+  may be used to endorse or promote products derived from this software without 
+  specific prior written permission.
+  
+  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
+  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
+  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
+  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
+  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
+  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
+  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
+  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
+  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
+  POSSIBILITY OF SUCH DAMAGE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/licenses/source/MIT
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/licenses/source/MIT b/brooklyn-dist/dist/licensing/licenses/source/MIT
new file mode 100644
index 0000000..71dfb45
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/licenses/source/MIT
@@ -0,0 +1,20 @@
+The MIT License ("MIT")
+
+  Permission is hereby granted, free of charge, to any person obtaining a copy
+  of this software and associated documentation files (the "Software"), to deal
+  in the Software without restriction, including without limitation the rights
+  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
+  copies of the Software, and to permit persons to whom the Software is
+  furnished to do so, subject to the following conditions:
+  
+  The above copyright notice and this permission notice shall be included in
+  all copies or substantial portions of the Software.
+  
+  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
+  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
+  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
+  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
+  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
+  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
+  THE SOFTWARE.
+  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/make-all-licenses.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/make-all-licenses.sh b/brooklyn-dist/dist/licensing/make-all-licenses.sh
new file mode 100755
index 0000000..3b62f96
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/make-all-licenses.sh
@@ -0,0 +1,61 @@
+#
+# 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.
+#
+
+# generates LICENSE files for source and binary,
+# and for each of `projects-with-custom-licenses`
+
+set -e
+
+# update the extras-files file from projects-with-custom-licenses
+cat projects-with-custom-licenses | awk '{ printf("%s/src/main/license/source-inclusions.yaml:", $0); }' | sed 's/:$//' > extras-files
+
+unset BROOKLYN_LICENSE_SPECIALS
+unset BROOKLYN_LICENSE_EXTRAS_FILES
+unset BROOKLYN_LICENSE_MODE
+
+# individual projects
+for x in `cat projects-with-custom-licenses` ; do
+  export BROOKLYN_LICENSE_MODE=`basename $x`
+  echo MAKING LICENSES FOR: ${BROOKLYN_LICENSE_MODE}
+  export BROOKLYN_LICENSE_SPECIALS=-DonlyExtras=true
+  export BROOKLYN_LICENSE_EXTRAS_FILES=$x/src/main/license/source-inclusions.yaml
+  cp licenses/`basename $x`/* licenses/source
+  ./make-one-license.sh > LICENSE.autogenerated || ( echo FAILED. See details in tmp_stdout/err. && false )
+  cp LICENSE.autogenerated ../$x/src/main/license/files/LICENSE
+  unset BROOKLYN_LICENSE_SPECIALS
+  unset BROOKLYN_LICENSE_EXTRAS_FILES
+  unset BROOKLYN_LICENSE_MODE
+done
+
+# source build, at root
+export BROOKLYN_LICENSE_MODE=source
+echo MAKING LICENSES FOR: ${BROOKLYN_LICENSE_MODE}
+export BROOKLYN_LICENSE_SPECIALS=-DonlyExtras=true 
+./make-one-license.sh > LICENSE.autogenerated
+cp LICENSE.autogenerated ../../../LICENSE
+unset BROOKLYN_LICENSE_SPECIALS
+unset BROOKLYN_LICENSE_MODE
+
+# binary build, in dist
+export BROOKLYN_LICENSE_MODE=binary
+echo MAKING LICENSES FOR: ${BROOKLYN_LICENSE_MODE}
+./make-one-license.sh > LICENSE.autogenerated
+cp LICENSE.autogenerated ../src/main/license/files/LICENSE
+unset BROOKLYN_LICENSE_MODE
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/make-one-license.sh
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/make-one-license.sh b/brooklyn-dist/dist/licensing/make-one-license.sh
new file mode 100755
index 0000000..5bcb35b
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/make-one-license.sh
@@ -0,0 +1,79 @@
+#
+# 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.
+#
+
+set -e
+
+# generates a LICENSE file, including notices and other licenses as needed
+# uses various env vars BROOKLYN_LICENSE_* to determine appropriate behaviour;
+# see make-licenses.sh for examples
+
+ls MAIN_LICENSE_ASL2 > /dev/null 2> /dev/null || ( echo "Must run in licensing directory (where this script lives)" > /dev/stderr && false )
+
+if [ -z "${BROOKLYN_LICENSE_MODE}" ] ; then echo BROOKLYN_LICENSE_MODE must be set > /dev/stderr ; false ; fi
+
+
+cat << EOF
+
+This software is distributed under the Apache License, version 2.0. See (1) below.
+This software is copyright (c) The Apache Software Foundation and contributors.
+
+Contents:
+
+  (1) This software license: Apache License, version 2.0
+  (2) Notices for bundled software
+  (3) Licenses for bundled software
+
+
+EOF
+
+echo "---------------------------------------------------"
+echo
+echo "(1) This software license: Apache License, version 2.0"
+echo
+cat MAIN_LICENSE_ASL2
+echo
+echo "---------------------------------------------------"
+echo
+echo "(2) Notices for bundled software"
+echo
+pushd .. > /dev/null
+# add -X on next line to get debug info
+mvn org.heneveld.maven:license-audit-maven-plugin:notices \
+        -DlicensesPreferred=ASL2,ASL,EPL1,BSD-2-Clause,BSD-3-Clause,CDDL1.1,CDDL1,CDDL \
+        -DoverridesFile=licensing/overrides.yaml \
+        -DextrasFiles=${BROOKLYN_LICENSE_EXTRAS_FILES:-`cat licensing/extras-files`} \
+        ${BROOKLYN_LICENSE_SPECIALS} \
+        -DoutputFile=licensing/notices.autogenerated \
+    > tmp_stdout 2> tmp_stderr
+rm tmp_std*
+popd > /dev/null
+cat notices.autogenerated
+
+echo
+echo "---------------------------------------------------"
+echo
+echo "(3) Licenses for bundled software"
+echo
+echo Contents:
+echo
+for x in licenses/${BROOKLYN_LICENSE_MODE}/* ; do head -1 $x | awk '{print "  "$0;}' ; done
+echo
+echo
+for x in licenses/${BROOKLYN_LICENSE_MODE}/* ; do cat $x ; echo ; done
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/overrides.yaml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/overrides.yaml b/brooklyn-dist/dist/licensing/overrides.yaml
new file mode 100644
index 0000000..a2f6107
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/overrides.yaml
@@ -0,0 +1,383 @@
+#
+# 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.
+#
+
+
+# overrides file for org.heneveld.license-audit-maven-plugin
+# expands/corrects detail needed for generating license notices
+
+
+# super-projects to suppress notices for sub-projects
+
+- id: org.apache.brooklyn
+  url: http://brooklyn.incubator.apache.org/
+  license: ASL2
+  internal: true
+
+# poms with missing and incorrect data
+
+- id: org.codehaus.jettison:jettison
+  url: https://github.com/codehaus/jettison
+  license: ASL2 
+- id: org.glassfish.external:opendmk_jmxremote_optional_jar
+  url: https://opendmk.java.net/
+  license: CDDL
+- id: javax.validation:validation-api
+  url: http://beanvalidation.org/
+- id: com.squareup.okhttp:okhttp
+  copyright_by: Square, Inc.
+- id: com.squareup.okio:okio
+  copyright_by: Square, Inc.
+- id: com.wordnik:swagger-core_2.9.1
+  copyright_by: SmartBear Software
+- id: com.wordnik:swagger-jaxrs_2.9.1
+  copyright_by: SmartBear Software
+- id: org.bouncycastle  
+  copyright_by: The Legion of the Bouncy Castle Inc. (http://www.bouncycastle.org)
+- id: org.javassist:javassist
+  copyright_by: Shigeru Chiba
+- id: org.mongodb:mongo-java-driver
+  copyright_by: MongoDB, Inc
+- id: org.apache.httpcomponents:httpclient:*
+  url: http://hc.apache.org/httpcomponents-client-ga
+- id: javax.annotation:jsr250-api:*
+  url: https://jcp.org/en/jsr/detail?id=250
+- id: javax.ws.rs:jsr311-api:*
+  url: https://jsr311.java.net/
+- id: com.thoughtworks.xstream:*:*
+  url: http://x-stream.github.io/
+- id: com.fasterxml.jackson:*:*
+  url: http://wiki.fasterxml.com/JacksonHome
+
+- id: org.hibernate:jtidy:r8-20060801
+  license:
+  - url: "http://sourceforge.net/p/jtidy/code/HEAD/tree/trunk/jtidy/LICENSE.txt?revision=95"
+    name: Java HTML Tidy License
+    comment: Original link http://svn.sourceforge.net/viewvc/*checkout*/jtidy/trunk/jtidy/LICENSE.txt?revision=95 is no longer valid
+
+- id: dom4j:dom4j:1.6.1
+  url: "http://dom4j.sourceforge.net/"
+  license:
+  - name: MetaStuff BSD style license (3-clause)
+    url: http://dom4j.sourceforge.net/dom4j-1.6.1/license.html
+
+- id: org.python:jython-standalone:2.7-b3
+  copyright_by: Jython Developers
+  license:
+  - url: http://www.jython.org/license.html
+    name: Jython Software License
+    comment: Original link http://www.jython.org/Project/license.html is no longer valid
+
+- id: xpp3:xpp3_min:*
+  copyright_by: Extreme! Lab, Indiana University
+  license:
+  - url: https://github.com/apache/openmeetings/blob/a95714ce3f7e587d13d3d0bb3b4f570be15c67a5/LICENSE#L1361
+    name: "Indiana University Extreme! Lab Software License, vesion 1.1.1"
+    comment: |
+      The license applies to the Xpp3 classes (all classes below the org.xmlpull package with exception of classes directly in package org.xmlpull.v1);
+      original link http://www.extreme.indiana.edu/viewcvs/~checkout~/XPP3/java/LICENSE.txt is no longer valid
+  ## as we pull in xmlpull separately we do not use this, and having a single above simplifies the automation:
+  #  - url: http://creativecommons.org/licenses/publicdomain
+  #    name: Public Domain
+  #    comment: "The license applies to the XmlPull API (all classes directly in the org.xmlpull.v1 package)"
+
+
+# info on non-maven projects
+
+- id: jquery-core
+  url: http://jquery.com/
+  description: JS library for manipulating HTML and eventing
+  name: jQuery JavaScript Library
+  files: jquery.js
+  version: 1.7.2
+  organization: { name: "The jQuery Foundation", url: "http://jquery.org/" }
+  license: MIT
+  notices: 
+  - Copyright (c) John Resig (2005-2011)
+  - "Includes code fragments from sizzle.js:"
+  - "  Copyright (c) The Dojo Foundation"
+  - "  Available at http://sizzlejs.com"
+  - "  Used under the MIT license"
+
+- id: jquery-core:1.8.0
+  url: http://jquery.com/
+  description: JS library for manipulating HTML and eventing
+  name: jQuery JavaScript Library
+  files: jquery.js
+  version: 1.8.0
+  organization: { name: "The jQuery Foundation", url: "http://jquery.org/" }
+  license: MIT
+  notices:
+  - Copyright (c) The jQuery Foundation, Inc. and other contributors (2005-2012)
+  - "Includes code fragments from sizzle.js:"
+  # NB: sizzle copyright changed from Dojo Foundation in 1.7.2
+  - "  Copyright (c) The jQuery Foundation, Inc. and other contributors (2012)"
+  - "  Available at http://sizzlejs.com"
+  - "  Used under the MIT license"
+# used in docs (not reported)
+- id: jquery-core:2.1.1
+  url: http://jquery.com/
+  description: JS library for manipulating HTML and eventing
+  name: jQuery JavaScript Library
+  files: jquery.js
+  version: 2.1.1
+  organization: { name: "The jQuery Foundation", url: "http://jquery.org/" }
+  license: MIT
+  notices: 
+  - Copyright (c) The jQuery Foundation, Inc. and other contributors (2005-2014)
+  - "Includes code fragments from sizzle.js:"
+  # NB: sizzle copyright changed from Dojo Foundation in 1.7.2
+  - "  Copyright (c) The jQuery Foundation, Inc. and other contributors (2013)"
+  - "  Available at http://sizzlejs.com"
+  - "  Used under the MIT license"
+
+- id: swagger:2.1.6
+  name: Swagger JS
+  files: swagger-client.js
+  version: 2.1.6
+  url: https://github.com/swagger-api/swagger-js
+  license: ASL2
+  notice: Copyright (c) SmartBear Software (2011-2015)
+
+- id: swagger-ui:2.1.3
+  files: swagger-ui.js
+  name: Swagger UI
+  version: 2.1.3
+  url: https://github.com/swagger-api/swagger-ui
+  license: ASL2
+  notice: Copyright (c) SmartBear Software (2011-2015)
+  
+- id: jquery.wiggle.min.js
+  name: jQuery Wiggle
+  version: swagger-ui:1.0.1
+  notices: 
+  - Copyright (c) WonderGroup and Jordan Thomas (2010)
+  - Previously online at http://labs.wondergroup.com/demos/mini-ui/index.html.
+  # that is link in copyright but it is no longer valid; url below is same person
+  - The version included here is from the Swagger UI distribution.
+  url: https://github.com/jordanthomas/jquery-wiggle
+  license: MIT
+
+- id: require.js
+  name: RequireJS 
+  files: require.js, text.js
+  version: 2.0.6 
+  url: http://requirejs.org/
+  organization: { name: "The Dojo Foundation", url: "http://dojofoundation.org/" }
+  notice: Copyright (c) The Dojo Foundation (2010-2012)
+  license: MIT
+
+- id: require.js/r.js
+  # new ID because this is a different version to the above
+  name: RequireJS (r.js maven plugin)
+  files: r.js
+  version: 2.1.6 
+  url: http://github.com/jrburke/requirejs
+  organization: { name: "The Dojo Foundation", url: "http://dojofoundation.org/" }
+  notices:
+  - Copyright (c) The Dojo Foundation (2009-2013)
+  - "Includes code fragments for source-map and other functionality:" 
+  - "  Copyright (c) The Mozilla Foundation and contributors (2011)"
+  - "  Used under the BSD 2-Clause license."
+  - "Includes code fragments for parse-js and other functionality:" 
+  - "  Copyright (c) Mihai Bazon (2010, 2012)"
+  - "  Used under the BSD 2-Clause license."
+  - "Includes code fragments for uglifyjs/consolidator:" 
+  - "  Copyright (c) Robert Gust-Bardon (2012)"
+  - "  Used under the BSD 2-Clause license."
+  - "Includes code fragments for the esprima parser:" 
+  - "  Copyright (c):"
+  - "    Ariya Hidayat (2011, 2012)"
+  - "    Mathias Bynens (2012)"
+  - "    Joost-Wim Boekesteijn (2012)"
+  - "    Kris Kowal (2012)"
+  - "    Yusuke Suzuki (2012)"
+  - "    Arpad Borsos (2012)"
+  - "  Used under the BSD 2-Clause license."
+  license: MIT
+
+- id: backbone.js
+  version: 1.0.0
+  url: http://backbonejs.org
+  organization: { name: "DocumentCloud Inc.", url: "http://www.documentcloud.org/" }
+  notice: Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2010-2013)
+  license: MIT
+
+- id: backbone.js:1.1.2
+  version: 1.1.2
+  url: http://backbonejs.org
+  organization: { name: "DocumentCloud Inc.", url: "http://www.documentcloud.org/" }
+  notice: Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2010-2014)
+  license: MIT
+
+- id: bootstrap.js
+  version: 2.0.4
+  url: http://twitter.github.com/bootstrap/javascript.html#transitions
+  notice: Copyright (c) Twitter, Inc. (2012)
+  license: ASL2
+ 
+# used in docs (not needed for licensing) 
+- id: bootstrap.js:3.1.1
+  version: 3.1.1
+  url: http://getbootstrap.com/
+  notice: Copyright (c) Twitter, Inc. (2011-2014)
+  license: MIT
+  
+- id: underscore.js
+  version: 1.4.4
+  files: underscore*.{js,map}
+  url: http://underscorejs.org
+  organization: { name: "DocumentCloud Inc.", url: "http://www.documentcloud.org/" }
+  notice: Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2009-2013)
+  license: MIT
+
+# used in CLI (and in docs)
+- id: underscore.js:1.7.0
+  version: 1.7.0
+  files: underscore*.{js,map}
+  url: http://underscorejs.org
+  organization: { name: "DocumentCloud Inc.", url: "http://www.documentcloud.org/" }
+  notice: "Copyright (c) Jeremy Ashkenas, DocumentCloud and Investigative Reporters & Editors (2009-2014)"
+  license: MIT
+
+- id: async.js
+  version: 0.1.1
+  url: https://github.com/p15martin/google-maps-hello-world/blob/master/js/libs/async.js
+  # ORIGINALLY https://github.com/millermedeiros/requirejs-plugins
+  organization: { name: "Miller Medeiros", url: "https://github.com/millermedeiros/" }
+  description: RequireJS plugin for async dependency load like JSONP and Google Maps
+  notice: Copyright (c) Miller Medeiros (2011)
+  license: MIT 
+
+- id: handlebars.js
+  files: handlebars*.js
+  version: 1.0-rc1
+  url: https://github.com/wycats/handlebars.js 
+  organization: { name: "Yehuda Katz", url: "https://github.com/wycats/" }
+  notice: Copyright (c) Yehuda Katz (2012)
+  license: MIT
+
+- id: handlebars.js:2.0.0
+  files: handlebars*.js
+  version: 2.0.0
+  url: https://github.com/wycats/handlebars.js
+  organization: { name: "Yehuda Katz", url: "https://github.com/wycats/" }
+  notice: Copyright (c) Yehuda Katz (2014)
+  license: MIT
+
+- id: jquery.ba-bbq.js
+  name: "jQuery BBQ: Back Button & Query Library"
+  files: jquery.ba-bbq*.js
+  version: 1.2.1
+  url: http://benalman.com/projects/jquery-bbq-plugin/
+  organization: { name: "\"Cowboy\" Ben Alman", url: "http://benalman.com/" }
+  notice: Copyright (c) "Cowboy" Ben Alman (2010)"
+  license: MIT
+
+- id: moment.js
+  version: 2.1.0
+  url: http://momentjs.com
+  organization: { name: "Tim Wood", url: "http://momentjs.com" }
+  notice: Copyright (c) Tim Wood, Iskren Chernev, Moment.js contributors (2011-2014)
+  license: MIT
+
+- id: ZeroClipboard
+  files: ZeroClipboard.*
+  version: 1.3.1
+  url: http://zeroclipboard.org/
+  organization: { name: "ZeroClipboard contributors", url: "https://github.com/zeroclipboard" }
+  notice: Copyright (c) Jon Rohan, James M. Greene (2014)
+  license: MIT
+
+- id: jquery.dataTables
+  files: jquery.dataTables.{js,css}
+  name: DataTables Table plug-in for jQuery
+  version: 1.9.4
+  url: http://www.datatables.net/
+  organization: { name: "SpryMedia Ltd", url: "http://sprymedia.co.uk/" }
+  notice: Copyright (c) Allan Jardine (2008-2012)
+  license: BSD-3-Clause
+
+- id: js-uri
+  files: URI.js
+  version: 0.1
+  url: http://code.google.com/p/js-uri/
+  organization: { name: "js-uri contributors", url: "https://code.google.com/js-uri" }
+  license: BSD-3-Clause
+  # inferred
+  notice: Copyright (c) js-uri contributors (2013)
+
+- id: js-yaml.js
+  version: 3.2.7
+  organization: { name: "Vitaly Puzrin", url: "https://github.com/nodeca/" }
+  url: https://github.com/nodeca/
+  notice: Copyright (c) Vitaly Puzrin (2011-2015)
+  license: MIT
+
+- id: jquery.form.js
+  name: jQuery Form Plugin
+  version: "3.09"
+  url: https://github.com/malsup/form
+  # also http://malsup.com/jquery/form/
+  organization: { name: "Mike Alsup", url: "http://malsup.com/" }
+  notice: Copyright (c) M. Alsup (2006-2013)
+  license: MIT
+
+# used for CLI to build catalog
+- id: typeahead.js
+  version: 0.10.5
+  url: https://github.com/twitter/typeahead.js
+  organization: { name: "Twitter, Inc", url: "http://twitter.com" }
+  notice: Copyright (c) Twitter, Inc. and other contributors (2013-2014)
+  license: MIT
+
+# used for CLI to build catalog
+- id: marked.js
+  version: 0.3.1
+  url: https://github.com/chjj/marked
+  organization: { name: "Christopher Jeffrey", url: "https://github.com/chjj" }
+  notice: Copyright (c) Christopher Jeffrey (2011-2014)
+  license: MIT
+
+# DOCS files
+#
+# we don't do a distributable docs build -- they are just online.
+# (docs are excluded from the source build, and not bundled with the binary build.)
+# so these are not used currently; but for completeness and in case we change our minds,
+# here they are:
+
+# * different versions of jquery, bootstrap, and underscore noted above,
+# * media items github octicons and font-awesome fonts, not listed
+# * plus the below:
+
+- id: jquery.superfish.js
+  files: superfish.js
+  name: Superfish jQuery Menu Widget
+  version: 1.4.8
+  url: http://users.tpg.com.au/j_birch/plugins/superfish/
+  notice: Copyright (c) Joel Birch (2008)
+  license: MIT
+
+- id: jquery.cookie.js
+  name: jQuery Cookie Plugin
+  version: 1.3.1
+  url: https://github.com/carhartl/jquery-cookie
+  notice: Copyright (c) 2013 Klaus Hartl
+  license: MIT
+
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/licensing/projects-with-custom-licenses
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/licensing/projects-with-custom-licenses b/brooklyn-dist/dist/licensing/projects-with-custom-licenses
new file mode 100644
index 0000000..ebf210c
--- /dev/null
+++ b/brooklyn-dist/dist/licensing/projects-with-custom-licenses
@@ -0,0 +1,2 @@
+../jsgui
+../cli

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/pom.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/pom.xml b/brooklyn-dist/dist/pom.xml
new file mode 100644
index 0000000..d9c392a
--- /dev/null
+++ b/brooklyn-dist/dist/pom.xml
@@ -0,0 +1,158 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+    
+     http://www.apache.org/licenses/LICENSE-2.0
+    
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+    <modelVersion>4.0.0</modelVersion>
+    <packaging>jar</packaging>
+
+    <artifactId>brooklyn-dist</artifactId>
+
+    <name>Brooklyn Distribution</name>
+    <description>
+        Brooklyn redistributable package archive, includes all required
+        Jar files and scripts
+    </description>
+
+    <parent>
+        <groupId>org.apache.brooklyn</groupId>
+        <artifactId>brooklyn-parent</artifactId>
+        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
+        <relativePath>../../parent/pom.xml</relativePath>
+    </parent>
+
+    <dependencies>
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-all</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+
+        <!-- TODO include examples -->
+        <!-- TODO include documentation -->
+
+        <dependency>
+            <groupId>org.apache.brooklyn</groupId>
+            <artifactId>brooklyn-test-support</artifactId>
+            <version>${project.version}</version>
+            <scope>test</scope>
+        </dependency>
+        <dependency>
+            <groupId>org.testng</groupId>
+            <artifactId>testng</artifactId>
+            <scope>test</scope>
+        </dependency>
+
+    </dependencies>
+
+    <build>
+        <plugins>
+            <plugin>
+                <artifactId>maven-dependency-plugin</artifactId>
+                <!-- copy the config file from the CLI project (could instead use unpack goal with an includes filter) -->
+                <executions>
+                    <execution>
+                        <id>copy</id>
+                        <phase>process-classes</phase>
+                        <goals>
+                            <goal>copy</goal>
+                        </goals>
+                        <configuration>
+                            <artifactItems>
+                                <artifactItem>
+                                    <!-- this can fail in eclipse trying to copy _from_ target/classes.
+                                         see http://jira.codehaus.org/browse/MDEP-259 -->
+                                    <groupId>${project.groupId}</groupId>
+                                    <artifactId>brooklyn-cli</artifactId>
+                                    <version>${project.version}</version>
+                                    <type>bom</type>
+                                    <classifier>dist</classifier>
+                                    <overWrite>true</overWrite>
+                                    <outputDirectory>target</outputDirectory>
+                                    <destFileName>default.catalog.bom</destFileName>
+                                </artifactItem>
+                            </artifactItems>
+                        </configuration>
+                    </execution>
+                </executions>
+            </plugin>
+            <plugin>
+                <groupId>org.apache.rat</groupId>
+                <artifactId>apache-rat-plugin</artifactId>
+                <configuration>
+                    <excludes combine.children="append">
+                        <!-- Exclude sample config files because they are illustrative, intended for changing -->
+                        <exclude>src/main/dist/conf/**</exclude>
+                        <exclude>licensing/licenses/**</exclude>
+                        <exclude>licensing/README.md</exclude>
+                        <exclude>licensing/*LICENSE*</exclude>
+                        <exclude>licensing/*.autogenerated</exclude>
+                        <exclude>licensing/projects-with-custom-licenses</exclude>
+                        <exclude>licensing/extras-files</exclude>
+                    </excludes>
+                  </configuration>
+            </plugin>
+            <plugin>
+                <artifactId>maven-assembly-plugin</artifactId>
+                <executions>
+                    <execution>
+                        <id>build-distribution-dir</id>
+                        <phase>package</phase>
+                        <goals>
+                            <goal>single</goal>
+                        </goals>
+                        <configuration>
+                            <appendAssemblyId>true</appendAssemblyId>
+                            <descriptors>
+                                <descriptor>src/main/config/build-distribution.xml</descriptor>
+                            </descriptors>
+                            <finalName>brooklyn</finalName>
+                            <includeBaseDirectory>false</includeBaseDirectory>
+                            <formats>
+                                <format>dir</format>
+                            </formats>
+                            <attach>false</attach>
+                        </configuration>
+                    </execution>
+                    <execution>
+                        <id>build-distribution-archive</id>
+                        <phase>package</phase>
+                        <goals>
+                            <goal>single</goal>
+                        </goals>
+                        <configuration>
+                            <appendAssemblyId>true</appendAssemblyId>
+                            <descriptors>
+                                <descriptor>src/main/config/build-distribution.xml</descriptor>
+                            </descriptors>
+                          <!-- finalName affects name in `target/` but we cannot influence name when it is attached/installed,
+                               so `apache-` prefix would be lost there. to keep it consistent this is commented out, 
+                               but would be nice to have if there is a way!
+                            <finalName>apache-brooklyn-${project.version}</finalName>
+                          -->
+                            <formats>
+                                <format>tar.gz</format>
+                                <format>zip</format>
+                            </formats>
+                        </configuration>
+                    </execution>
+                </executions>
+            </plugin>
+        </plugins>
+    </build>
+</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/src/main/config/build-distribution.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/config/build-distribution.xml b/brooklyn-dist/dist/src/main/config/build-distribution.xml
new file mode 100644
index 0000000..fc2264d
--- /dev/null
+++ b/brooklyn-dist/dist/src/main/config/build-distribution.xml
@@ -0,0 +1,96 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+    
+     http://www.apache.org/licenses/LICENSE-2.0
+    
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+-->
+<assembly xmlns="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2"
+        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+        xsi:schemaLocation="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2 http://maven.apache.org/xsd/assembly-1.1.2.xsd">
+    <id>dist</id>
+    <formats><!-- empty, intended for caller to specify --></formats>
+    <fileSets>
+        <fileSet>
+            <directory>${project.basedir}/../..</directory>
+            <outputDirectory></outputDirectory>
+            <fileMode>0644</fileMode>
+            <directoryMode>0755</directoryMode>
+            <includes>
+                <include>README*</include>
+                <include>DISCLAIMER*</include>
+            </includes>
+        </fileSet>
+        <fileSet>
+            <directory>${project.basedir}/src/main/license/files</directory>
+            <outputDirectory></outputDirectory>
+            <fileMode>0644</fileMode>
+            <directoryMode>0755</directoryMode>
+        </fileSet>
+        <fileSet>
+            <directory>${project.basedir}/src/main/dist/bin</directory>
+            <outputDirectory>bin</outputDirectory>
+            <fileMode>0755</fileMode>
+            <directoryMode>0755</directoryMode>
+        </fileSet>
+        <fileSet>
+            <!-- Add an empty dropins folder (so need to reference an existing dir, and exclude everything) -->
+            <directory>${project.basedir}/src/main/dist</directory>
+            <outputDirectory>lib/dropins</outputDirectory>
+            <directoryMode>0755</directoryMode>
+            <excludes>
+                <exclude>**/*</exclude>
+            </excludes>
+        </fileSet>
+        <fileSet>
+            <directory>${project.basedir}/target</directory>
+            <outputDirectory>conf/brooklyn</outputDirectory>
+            <fileMode>0644</fileMode>
+            <directoryMode>0755</directoryMode>
+            <includes>
+                <include>default.catalog.bom</include>
+            </includes>
+        </fileSet>
+        <fileSet>
+            <!-- Add an empty patch folder (so need to reference an existing dir, and exclude everything) -->
+            <directory>${project.basedir}/src/main/dist</directory>
+            <outputDirectory>lib/patch</outputDirectory>
+            <directoryMode>0755</directoryMode>
+            <excludes>
+                <exclude>**/*</exclude>
+            </excludes>
+        </fileSet>
+        <fileSet>
+            <directory>${project.basedir}/src/main/dist</directory>
+            <outputDirectory></outputDirectory>
+            <fileMode>0644</fileMode>
+            <directoryMode>0755</directoryMode>
+            <excludes>
+                <exclude>bin/*</exclude>
+            </excludes>
+        </fileSet>
+    </fileSets>
+    <!-- TODO include documentation -->
+    <!-- TODO include examples -->
+    <dependencySets>
+        <dependencySet>
+            <useProjectArtifact>false</useProjectArtifact>
+            <outputDirectory>lib/brooklyn</outputDirectory>
+            <fileMode>0644</fileMode>
+            <directoryMode>0755</directoryMode>
+            <outputFileNameMapping>${artifact.groupId}-${artifact.artifactId}-${artifact.version}${dashClassifier?}.${artifact.extension}</outputFileNameMapping>
+        </dependencySet>
+    </dependencySets>
+</assembly>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/src/main/dist/bin/.gitattributes
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/dist/bin/.gitattributes b/brooklyn-dist/dist/src/main/dist/bin/.gitattributes
new file mode 100644
index 0000000..4e2b719
--- /dev/null
+++ b/brooklyn-dist/dist/src/main/dist/bin/.gitattributes
@@ -0,0 +1,3 @@
+#Don't auto-convert line endings for shell scripts on Windows (breaks the scripts)
+brooklyn text eol=lf
+cloud-explorer text eol=lf

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/src/main/dist/bin/brooklyn
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/dist/bin/brooklyn b/brooklyn-dist/dist/src/main/dist/bin/brooklyn
new file mode 100755
index 0000000..370bc93
--- /dev/null
+++ b/brooklyn-dist/dist/src/main/dist/bin/brooklyn
@@ -0,0 +1,51 @@
+#!/usr/bin/env bash
+#
+# 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.
+#
+# Brooklyn
+#
+
+#set -x # debug
+
+# discover BROOKLYN_HOME if not set, by attempting to resolve absolute path of this command
+ROOT=$(cd "$(dirname "$0")/.." && pwd -P)
+if [ -z "$BROOKLYN_HOME" ] ; then
+    BROOKLYN_HOME=$(cd "$(dirname "$(readlink -f "$0" 2> /dev/null || readlink "$0" 2> /dev/null || echo "$0")")/.." && pwd)
+fi
+export ROOT BROOKLYN_HOME
+
+# use default memory settings, if not specified
+if [ -z "${JAVA_OPTS}" ] ; then
+    JAVA_OPTS="-Xms256m -Xmx1g -XX:MaxPermSize=256m"
+fi
+
+# set up the classpath
+INITIAL_CLASSPATH=${BROOKLYN_HOME}/conf:${BROOKLYN_HOME}/lib/patch/*:${BROOKLYN_HOME}/lib/brooklyn/*:${BROOKLYN_HOME}/lib/dropins/*
+# specify additional CP args in BROOKLYN_CLASSPATH
+if [ ! -z "${BROOKLYN_CLASSPATH}" ]; then
+    INITIAL_CLASSPATH=${BROOKLYN_CLASSPATH}:${INITIAL_CLASSPATH}
+fi
+export INITIAL_CLASSPATH
+
+# force resolution of localhost to be loopback, otherwise we hit problems
+# TODO should be changed in code
+JAVA_OPTS="-Dbrooklyn.location.localhost.address=127.0.0.1 ${JAVA_OPTS}"
+
+# start Brooklyn
+echo $$ > "$ROOT/pid_java"
+exec java ${JAVA_OPTS} -cp "${INITIAL_CLASSPATH}" org.apache.brooklyn.cli.Main "$@"

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/src/main/dist/bin/brooklyn.bat
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/dist/bin/brooklyn.bat b/brooklyn-dist/dist/src/main/dist/bin/brooklyn.bat
new file mode 100644
index 0000000..90e300e
--- /dev/null
+++ b/brooklyn-dist/dist/src/main/dist/bin/brooklyn.bat
@@ -0,0 +1,111 @@
+@echo off
+REM Licensed to the Apache Software Foundation (ASF) under one
+REM or more contributor license agreements.  See the NOTICE file
+REM distributed with this work for additional information
+REM regarding copyright ownership.  The ASF licenses this file
+REM to you under the Apache License, Version 2.0 (the
+REM "License"); you may not use this file except in compliance
+REM with the License.  You may obtain a copy of the License at
+REM 
+REM   http://www.apache.org/licenses/LICENSE-2.0
+REM 
+REM Unless required by applicable law or agreed to in writing,
+REM software distributed under the License is distributed on an
+REM "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+REM KIND, either express or implied.  See the License for the
+REM specific language governing permissions and limitations
+REM under the License.
+
+SETLOCAL EnableDelayedExpansion
+
+REM discover BROOKLYN_HOME if not set, by attempting to resolve absolute path of this command (brooklyn.bat)
+IF NOT DEFINED BROOKLYN_HOME (
+    SET "WORKING_FOLDER=%~dp0"
+    
+    REM stript trailing slash
+    SET "WORKING_FOLDER=!WORKING_FOLDER:~0,-1!"
+    
+    REM get parent folder (~dp works only for batch file params and loop indexes)
+    FOR %%i in ("!WORKING_FOLDER!") DO SET "BROOKLYN_HOME=%%~dpi"
+)
+
+REM Discover the location of Java.
+REM Use JAVA_HOME environment variable, if available;
+REM else, check the path;
+REM else, search registry for Java installations;
+REM else fail.
+
+IF DEFINED JAVA_HOME (
+    CALL :joinpath "%JAVA_HOME%" bin\java.exe JAVA_BIN
+)
+
+IF NOT DEFINED JAVA_BIN (
+    IF NOT DEFINED JAVA_HOME CALL :registry_home "HKLM\SOFTWARE\JavaSoft\Java Runtime Environment"
+    IF NOT DEFINED JAVA_HOME CALL :registry_home "HKLM\SOFTWARE\Wow6432Node\JavaSoft\Java Runtime Environment"
+    IF NOT DEFINED JAVA_HOME CALL :registry_home "HKLM\SOFTWARE\JavaSoft\Java Development Kit"
+    IF NOT DEFINED JAVA_HOME CALL :registry_home "HKLM\SOFTWARE\Wow6432Node\JavaSoft\Java Development Kit"
+    CALL :joinpath "!JAVA_HOME!" bin\java.exe JAVA_BIN
+)
+
+IF NOT DEFINED JAVA_BIN (
+    java.exe -version > NUL 2> NUL
+    echo !ERRORLEVEL!
+    IF NOT !ERRORLEVEL!==9009 SET JAVA_BIN=java.exe
+)
+
+IF NOT DEFINED JAVA_BIN (
+    echo "Unable to locate a Java installation. Please set JAVA_HOME or PATH environment variables."
+    exit /b 1
+) ELSE (
+    "%JAVA_BIN%" -version > NUL 2> NUL
+    IF !ERRORLEVEL!==9009 (
+        echo "java.exe does not exist where specified. Please check JAVA_HOME or PATH environment variables."
+        exit /b 1
+    )
+)
+
+REM use default memory settings, if not specified
+IF "%JAVA_OPTS%"=="" SET JAVA_OPTS=-Xms256m -Xmx500m -XX:MaxPermSize=256m
+
+REM set up the classpath
+SET INITIAL_CLASSPATH=%BROOKLYN_HOME%conf;%BROOKLYN_HOME%lib\patch\*;%BROOKLYN_HOME%lib\brooklyn\*;%BROOKLYN_HOME%lib\dropins\*
+REM specify additional CP args in BROOKLYN_CLASSPATH
+IF NOT "%BROOKLYN_CLASSPATH%"=="" SET "INITIAL_CLASSPATH=%BROOKLYN_CLASSPATH%;%INITIAL_CLASSPATH%"
+
+REM force resolution of localhost to be loopback, otherwise we hit problems
+REM TODO should be changed in code
+SET JAVA_OPTS=-Dbrooklyn.location.localhost.address=127.0.0.1 %JAVA_OPTS%
+
+REM workaround for http://bugs.sun.com/view_bug.do?bug_id=4787931
+SET JAVA_OPTS=-Duser.home="%USERPROFILE%" %JAVA_OPTS%
+
+REM start Brooklyn
+REM NO easy way to find process PID!!!
+pushd %BROOKLYN_HOME%
+
+"%JAVA_BIN%" %JAVA_OPTS% -cp "%INITIAL_CLASSPATH%" org.apache.brooklyn.cli.Main %*
+
+popd
+
+ENDLOCAL
+GOTO :EOF
+
+:joinpath
+    SET Path1=%~1
+    SET Path2=%~2
+    IF {%Path1:~-1,1%}=={\} (SET "%3=%Path1%%Path2%") ELSE (SET "%3=%Path1%\%Path2%")
+GOTO :EOF
+
+:whereis
+    REM Doesn't handle paths with quotes in the PATH variable
+    SET "%2=%~$PATH:1"
+GOTO :EOF
+
+:registry_value
+    FOR /F "skip=2 tokens=2*" %%A IN ('REG QUERY %1 /v %2 2^>nul') DO SET "%3=%%B"
+GOTO :EOF
+
+:registry_home
+    CALL :registry_value %1 CurrentVersion JAVA_VERSION
+    CALL :registry_value "%~1\%JAVA_VERSION%" JavaHome JAVA_HOME
+GOTO :EOF

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/src/main/dist/bin/brooklyn.ps1
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/dist/bin/brooklyn.ps1 b/brooklyn-dist/dist/src/main/dist/bin/brooklyn.ps1
new file mode 100644
index 0000000..6780ed2
--- /dev/null
+++ b/brooklyn-dist/dist/src/main/dist/bin/brooklyn.ps1
@@ -0,0 +1,135 @@
+#!ps1
+#
+# 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.
+#
+# Brooklyn
+#
+
+$ErrorActionPreference = "Stop";
+
+$ROOT = split-path -parent $MyInvocation.MyCommand.Definition
+
+# discover BROOKLYN_HOME if not set, by attempting to resolve absolute path of this command (brooklyn)
+if ( $env:BROOKLYN_HOME -eq $null ) {
+    $BROOKLYN_HOME = split-path -parent $ROOT
+} else {
+    $BROOKLYN_HOME = $env:BROOKLYN_HOME
+}
+
+# Discover the location of Java.
+# Use JAVA_HOME environment variable, if available;
+# else, search registry for Java installations;
+# else, check the path;
+# else fail.
+$bin = [System.IO.Path]::Combine("bin", "java.exe")
+if ( $env:JAVA_HOME -ne $null ) {
+    $javahome = $env:JAVA_HOME
+    $javabin = [System.IO.Path]::Combine($javahome, $bin)
+}
+if ( $javabin -eq $null ) {
+    $reglocations = ( 'HKLM:\SOFTWARE\JavaSoft\Java Runtime Environment',
+                      'HKLM:\SOFTWARE\Wow6432Node\JavaSoft\Java Runtime Environment' )
+    $jres = @{}
+    foreach ($loc in $reglocations) {
+        $item = Get-Item $loc -ErrorAction SilentlyContinue
+        if ($item -eq $null) { continue }
+        foreach ($key in Get-ChildItem $loc) {
+            $version = $key.PSChildName
+            $jrehome = $key.GetValue("JavaHome")
+            $jres.Add($version, $jrehome)
+        }
+    }
+    # TODO - this does a simple sort on the registry key name (the JRE version). This is not ideal - better would be
+    # to understand semantic versioning, filter out incompatible JREs (1.5 and earlier), prefer known good JREs (1.6
+    # or 1.7) and pick the highest patchlevel.
+    $last = ( $jres.Keys | Sort-Object | Select-Object -Last 1 )
+    if ( $last -ne $null ) {
+        $javahome = $jres.Get_Item($last)
+        $javabin = [System.IO.Path]::Combine($javahome, $bin)
+    }
+}
+if ( $javabin -eq $null ) {
+    $where = Get-Command "java.exe" -ErrorAction SilentlyContinue
+    if ( $where -ne $null ) {
+        $javabin = $where.Definition
+        $bindir = [System.IO.Path]::GetDirectoryName($javabin)
+        $javahome = [System.IO.Path]::GetDirectoryName($bindir)
+    }
+}
+
+if ( $javabin -eq $null ) {
+    throw "Unable to locate a Java installation. Please set JAVA_HOME or PATH environment variables."
+} elseif ( $( Get-Item $javabin -ErrorAction SilentlyContinue ) -eq $null ) {
+    throw "java.exe does not exist where specified. Please check JAVA_HOME or PATH environment variables."
+}
+
+# set up the classpath
+$cp = Get-ChildItem ${BROOKLYN_HOME}\conf | Select-Object -ExpandProperty FullName
+
+if ( Test-Path ${BROOKLYN_HOME}\lib\patch ) {
+    $cp += Get-ChildItem ${BROOKLYN_HOME}\lib\patch | Select-Object -ExpandProperty FullName
+}
+
+$cp += Get-ChildItem ${BROOKLYN_HOME}\lib\brooklyn | Select-Object -ExpandProperty FullName
+
+if ( Test-Path ${BROOKLYN_HOME}\lib\dropins ) {
+    $cp += Get-ChildItem ${BROOKLYN_HOME}\lib\dropins | Select-Object -ExpandProperty FullName
+}
+
+$INITIAL_CLASSPATH = $cp -join ';'
+
+# specify additional CP args in BROOKLYN_CLASSPATH
+if ( ! ( $env:BROOKLYN_CLASSPATH -eq $null )) {
+    $INITIAL_CLASSPATH = "$($INITIAL_CLASSPATH);$($env:BROOKLYN_CLASSPATH)"
+}
+
+# start to build up the arguments to the java invocation
+$javaargs = @()
+
+# add the user's java opts, or use default memory settings, if not specified
+if ( $env:JAVA_OPTS -eq $null ) {
+    $javaargs +="-Xms256m -Xmx1g -XX:MaxPermSize=256m"
+} else {
+    $javaargs +=$env:JAVA_OPTS
+}
+
+# force resolution of localhost to be loopback, otherwise we hit problems
+# TODO should be changed in code
+$javaargs += "-Dbrooklyn.localhost.address=127.0.0.1 $($JAVA_OPTS)"
+
+# workaround for http://bugs.sun.com/view_bug.do?bug_id=4787931
+$javaargs += "-Duser.home=`"$env:USERPROFILE`""
+
+# add the classpath
+$javaargs += "-cp"
+$javaargs += "`"$($INITIAL_CLASSPATH)`""
+
+# main class
+$javaargs += "org.apache.brooklyn.cli.Main"
+
+# copy in the arguments that were given to this script
+$javaargs += $args
+
+# start Brooklyn
+$process = Start-Process -FilePath $javabin -ArgumentList $javaargs -NoNewWindow -PassThru
+
+# save PID
+Set-Content -Path ${BROOKLYN_HOME}\pid_java -Value $($process.Id)
+
+# wait for it to finish
+$process.WaitForExit()

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/src/main/dist/conf/logback.xml
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/dist/conf/logback.xml b/brooklyn-dist/dist/src/main/dist/conf/logback.xml
new file mode 100644
index 0000000..e70862c
--- /dev/null
+++ b/brooklyn-dist/dist/src/main/dist/conf/logback.xml
@@ -0,0 +1,14 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<configuration>
+
+    <!-- to supply custom logging, either change this file, supply your own logback-main.xml 
+         (overriding the default provided on the classpath) or any of the files it references; 
+         see the Logging section of the Brooklyn web site for more information -->
+
+    <property name="logging.basename" scope="context" value="brooklyn" />
+    <property name="logging.dir" scope="context" value="./" />
+
+    <include resource="logback-main.xml"/>
+    
+</configuration>
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/src/main/license/README.md
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/license/README.md b/brooklyn-dist/dist/src/main/license/README.md
new file mode 100644
index 0000000..0d3b52b
--- /dev/null
+++ b/brooklyn-dist/dist/src/main/license/README.md
@@ -0,0 +1,2 @@
+See /usage/dist/licensing/README.md for an explanation of this directory.
+

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/brooklyn-dist/dist/src/main/license/files/DISCLAIMER
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/license/files/DISCLAIMER b/brooklyn-dist/dist/src/main/license/files/DISCLAIMER
new file mode 100644
index 0000000..9e6119b
--- /dev/null
+++ b/brooklyn-dist/dist/src/main/license/files/DISCLAIMER
@@ -0,0 +1,8 @@
+
+Apache Brooklyn is an effort undergoing incubation at The Apache Software Foundation (ASF), 
+sponsored by the Apache Incubator. Incubation is required of all newly accepted projects until 
+a further review indicates that the infrastructure, communications, and decision making process 
+have stabilized in a manner consistent with other successful ASF projects. While incubation 
+status is not necessarily a reflection of the completeness or stability of the code, it does 
+indicate that the project has yet to be fully endorsed by the ASF.
+


[03/51] [abbrv] brooklyn-dist git commit: [SPLITPREP] rearranged to have structure of new repositories

Posted by he...@apache.org.
http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/binary/jtidy
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/binary/jtidy b/usage/dist/licensing/licenses/binary/jtidy
deleted file mode 100644
index 0bcb614..0000000
--- a/usage/dist/licensing/licenses/binary/jtidy
+++ /dev/null
@@ -1,53 +0,0 @@
-JTidy License
-
-  Java HTML Tidy - JTidy
-  HTML parser and pretty printer
-  
-  Copyright (c) 1998-2000 World Wide Web Consortium (Massachusetts
-  Institute of Technology, Institut National de Recherche en
-  Informatique et en Automatique, Keio University). All Rights
-  Reserved.
-  
-  Contributing Author(s):
-  
-     Dave Raggett <ds...@w3.org>
-     Andy Quick <ac...@sympatico.ca> (translation to Java)
-     Gary L Peskin <ga...@firstech.com> (Java development)
-     Sami Lempinen <sa...@lempinen.net> (release management)
-     Fabrizio Giustina <fgiust at users.sourceforge.net>
-  
-  The contributing author(s) would like to thank all those who
-  helped with testing, bug fixes, and patience.  This wouldn't
-  have been possible without all of you.
-  
-  COPYRIGHT NOTICE:
-   
-  This software and documentation is provided "as is," and
-  the copyright holders and contributing author(s) make no
-  representations or warranties, express or implied, including
-  but not limited to, warranties of merchantability or fitness
-  for any particular purpose or that the use of the software or
-  documentation will not infringe any third party patents,
-  copyrights, trademarks or other rights. 
-  
-  The copyright holders and contributing author(s) will not be
-  liable for any direct, indirect, special or consequential damages
-  arising out of any use of the software or documentation, even if
-  advised of the possibility of such damage.
-  
-  Permission is hereby granted to use, copy, modify, and distribute
-  this source code, or portions hereof, documentation and executables,
-  for any purpose, without fee, subject to the following restrictions:
-  
-  1. The origin of this source code must not be misrepresented.
-  2. Altered versions must be plainly marked as such and must
-     not be misrepresented as being the original source.
-  3. This Copyright notice may not be removed or altered from any
-     source or altered source distribution.
-   
-  The copyright holders and contributing author(s) specifically
-  permit, without fee, and encourage the use of this source code
-  as a component for supporting the Hypertext Markup Language in
-  commercial products. If you use this source code in a product,
-  acknowledgment is not required but would be appreciated.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/binary/jython
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/binary/jython b/usage/dist/licensing/licenses/binary/jython
deleted file mode 100644
index b2258d4..0000000
--- a/usage/dist/licensing/licenses/binary/jython
+++ /dev/null
@@ -1,27 +0,0 @@
-Jython License
-
-  Jython 2.0, 2.1 License
-  
-  Copyright (c) 2000, 2001, 2002, 2003, 2004, 2005, 2006, 2007 Jython Developers All rights reserved.
-  
-  Redistribution and use in source and binary forms, with or without modification, are permitted provided 
-  that the following conditions are met:
-  
-  Redistributions of source code must retain the above copyright notice, this list of conditions and the 
-  following disclaimer.
-  
-  Redistributions in binary form must reproduce the above copyright notice, this list of conditions and 
-  the following disclaimer in the documentation and/or other materials provided with the distribution.
-  Neither the name of the Jython Developers nor the names of its contributors may be used to endorse or 
-  promote products derived from this software without specific prior written permission.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS'' AND ANY EXPRESS OR IMPLIED 
-  WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A 
-  PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE REGENTS OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
-  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO, 
-  PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) 
-  HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING 
-  NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
-  POSSIBILITY OF SUCH DAMAGE.
-  
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/binary/metastuff-bsd-style
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/binary/metastuff-bsd-style b/usage/dist/licensing/licenses/binary/metastuff-bsd-style
deleted file mode 100644
index 6bb4ef6..0000000
--- a/usage/dist/licensing/licenses/binary/metastuff-bsd-style
+++ /dev/null
@@ -1,43 +0,0 @@
-MetaStuff BSD Style License
-
-  Copyright 2001-2005 (C) MetaStuff, Ltd. All Rights Reserved.
-  
-  Redistribution and use of this software and associated documentation
-  ("Software"), with or without modification, are permitted provided
-  that the following conditions are met:
-  
-  1. Redistributions of source code must retain copyright
-     statements and notices.  Redistributions must also contain a
-     copy of this document.
-  
-  2. Redistributions in binary form must reproduce the
-     above copyright notice, this list of conditions and the
-     following disclaimer in the documentation and/or other
-     materials provided with the distribution.
-  
-  3. The name "DOM4J" must not be used to endorse or promote
-     products derived from this Software without prior written
-     permission of MetaStuff, Ltd.  For written permission,
-     please contact dom4j-info@metastuff.com.
-  
-  4. Products derived from this Software may not be called "DOM4J"
-     nor may "DOM4J" appear in their names without prior written
-     permission of MetaStuff, Ltd. DOM4J is a registered
-     trademark of MetaStuff, Ltd.
-  
-  5. Due credit should be given to the DOM4J Project -
-     http://www.dom4j.org
-  
-  THIS SOFTWARE IS PROVIDED BY METASTUFF, LTD. AND CONTRIBUTORS
-  ``AS IS'' AND ANY EXPRESSED OR IMPLIED WARRANTIES, INCLUDING, BUT
-  NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND
-  FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED.  IN NO EVENT SHALL
-  METASTUFF, LTD. OR ITS CONTRIBUTORS BE LIABLE FOR ANY DIRECT,
-  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES
-  (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
-  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION)
-  HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT,
-  STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE)
-  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED
-  OF THE POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/binary/xpp3_indiana_university
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/binary/xpp3_indiana_university b/usage/dist/licensing/licenses/binary/xpp3_indiana_university
deleted file mode 100644
index 7d69a29..0000000
--- a/usage/dist/licensing/licenses/binary/xpp3_indiana_university
+++ /dev/null
@@ -1,45 +0,0 @@
-Indiana University Extreme! Lab Software License, Version 1.1.1
-
-  Copyright (c) 2002 Extreme! Lab, Indiana University. All rights reserved.
-  
-  Redistribution and use in source and binary forms, with or without
-  modification, are permitted provided that the following conditions
-  are met:
-  
-  1. Redistributions of source code must retain the above copyright notice,
-     this list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright
-     notice, this list of conditions and the following disclaimer in
-     the documentation and/or other materials provided with the distribution.
-  
-  3. The end-user documentation included with the redistribution, if any,
-     must include the following acknowledgment:
-  
-    "This product includes software developed by the Indiana University
-    Extreme! Lab (http://www.extreme.indiana.edu/)."
-  
-  Alternately, this acknowledgment may appear in the software itself,
-  if and wherever such third-party acknowledgments normally appear.
-  
-  4. The names "Indiana Univeristy" and "Indiana Univeristy Extreme! Lab"
-  must not be used to endorse or promote products derived from this
-  software without prior written permission. For written permission,
-  please contact http://www.extreme.indiana.edu/.
-  
-  5. Products derived from this software may not use "Indiana Univeristy"
-  name nor may "Indiana Univeristy" appear in their name, without prior
-  written permission of the Indiana University.
-  
-  THIS SOFTWARE IS PROVIDED "AS IS" AND ANY EXPRESSED OR IMPLIED
-  WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF
-  MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED.
-  IN NO EVENT SHALL THE AUTHORS, COPYRIGHT HOLDERS OR ITS CONTRIBUTORS
-  BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR
-  CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF
-  SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR PROFITS; OR
-  BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY,
-  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR
-  OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF
-  ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/cli/MIT
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/cli/MIT b/usage/dist/licensing/licenses/cli/MIT
deleted file mode 100644
index 71dfb45..0000000
--- a/usage/dist/licensing/licenses/cli/MIT
+++ /dev/null
@@ -1,20 +0,0 @@
-The MIT License ("MIT")
-
-  Permission is hereby granted, free of charge, to any person obtaining a copy
-  of this software and associated documentation files (the "Software"), to deal
-  in the Software without restriction, including without limitation the rights
-  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
-  copies of the Software, and to permit persons to whom the Software is
-  furnished to do so, subject to the following conditions:
-  
-  The above copyright notice and this permission notice shall be included in
-  all copies or substantial portions of the Software.
-  
-  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
-  THE SOFTWARE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/jsgui/BSD-2-Clause
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/jsgui/BSD-2-Clause b/usage/dist/licensing/licenses/jsgui/BSD-2-Clause
deleted file mode 100644
index 832c10e..0000000
--- a/usage/dist/licensing/licenses/jsgui/BSD-2-Clause
+++ /dev/null
@@ -1,23 +0,0 @@
-The BSD 2-Clause License
-
-  Redistribution and use in source and binary forms, with or without
-  modification, are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, this
-  list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice,
-  this list of conditions and the following disclaimer in the documentation
-  and/or other materials provided with the distribution.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
-  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
-  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
-  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
-  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
-  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
-  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
-  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/jsgui/BSD-3-Clause
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/jsgui/BSD-3-Clause b/usage/dist/licensing/licenses/jsgui/BSD-3-Clause
deleted file mode 100644
index be2692c..0000000
--- a/usage/dist/licensing/licenses/jsgui/BSD-3-Clause
+++ /dev/null
@@ -1,27 +0,0 @@
-The BSD 3-Clause License ("New BSD")
-
-  Redistribution and use in source and binary forms, with or without modification,
-  are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, 
-  this list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice, 
-  this list of conditions and the following disclaimer in the documentation 
-  and/or other materials provided with the distribution.
-  
-  3. Neither the name of the copyright holder nor the names of its contributors 
-  may be used to endorse or promote products derived from this software without 
-  specific prior written permission.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
-  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
-  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
-  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
-  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
-  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
-  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
-  POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/jsgui/MIT
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/jsgui/MIT b/usage/dist/licensing/licenses/jsgui/MIT
deleted file mode 100644
index 71dfb45..0000000
--- a/usage/dist/licensing/licenses/jsgui/MIT
+++ /dev/null
@@ -1,20 +0,0 @@
-The MIT License ("MIT")
-
-  Permission is hereby granted, free of charge, to any person obtaining a copy
-  of this software and associated documentation files (the "Software"), to deal
-  in the Software without restriction, including without limitation the rights
-  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
-  copies of the Software, and to permit persons to whom the Software is
-  furnished to do so, subject to the following conditions:
-  
-  The above copyright notice and this permission notice shall be included in
-  all copies or substantial portions of the Software.
-  
-  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
-  THE SOFTWARE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/source/BSD-2-Clause
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/source/BSD-2-Clause b/usage/dist/licensing/licenses/source/BSD-2-Clause
deleted file mode 100644
index 832c10e..0000000
--- a/usage/dist/licensing/licenses/source/BSD-2-Clause
+++ /dev/null
@@ -1,23 +0,0 @@
-The BSD 2-Clause License
-
-  Redistribution and use in source and binary forms, with or without
-  modification, are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, this
-  list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice,
-  this list of conditions and the following disclaimer in the documentation
-  and/or other materials provided with the distribution.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
-  DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE
-  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
-  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
-  SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
-  CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
-  OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
-  OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/source/BSD-3-Clause
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/source/BSD-3-Clause b/usage/dist/licensing/licenses/source/BSD-3-Clause
deleted file mode 100644
index be2692c..0000000
--- a/usage/dist/licensing/licenses/source/BSD-3-Clause
+++ /dev/null
@@ -1,27 +0,0 @@
-The BSD 3-Clause License ("New BSD")
-
-  Redistribution and use in source and binary forms, with or without modification,
-  are permitted provided that the following conditions are met:
-  
-  1. Redistributions of source code must retain the above copyright notice, 
-  this list of conditions and the following disclaimer.
-  
-  2. Redistributions in binary form must reproduce the above copyright notice, 
-  this list of conditions and the following disclaimer in the documentation 
-  and/or other materials provided with the distribution.
-  
-  3. Neither the name of the copyright holder nor the names of its contributors 
-  may be used to endorse or promote products derived from this software without 
-  specific prior written permission.
-  
-  THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND 
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED 
-  WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. 
-  IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, 
-  INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT 
-  NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR 
-  PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, 
-  WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) 
-  ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE 
-  POSSIBILITY OF SUCH DAMAGE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/licenses/source/MIT
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/licenses/source/MIT b/usage/dist/licensing/licenses/source/MIT
deleted file mode 100644
index 71dfb45..0000000
--- a/usage/dist/licensing/licenses/source/MIT
+++ /dev/null
@@ -1,20 +0,0 @@
-The MIT License ("MIT")
-
-  Permission is hereby granted, free of charge, to any person obtaining a copy
-  of this software and associated documentation files (the "Software"), to deal
-  in the Software without restriction, including without limitation the rights
-  to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
-  copies of the Software, and to permit persons to whom the Software is
-  furnished to do so, subject to the following conditions:
-  
-  The above copyright notice and this permission notice shall be included in
-  all copies or substantial portions of the Software.
-  
-  THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-  IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-  AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-  LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-  OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
-  THE SOFTWARE.
-  

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/make-all-licenses.sh
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/make-all-licenses.sh b/usage/dist/licensing/make-all-licenses.sh
deleted file mode 100755
index 3b62f96..0000000
--- a/usage/dist/licensing/make-all-licenses.sh
+++ /dev/null
@@ -1,61 +0,0 @@
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#  http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-# generates LICENSE files for source and binary,
-# and for each of `projects-with-custom-licenses`
-
-set -e
-
-# update the extras-files file from projects-with-custom-licenses
-cat projects-with-custom-licenses | awk '{ printf("%s/src/main/license/source-inclusions.yaml:", $0); }' | sed 's/:$//' > extras-files
-
-unset BROOKLYN_LICENSE_SPECIALS
-unset BROOKLYN_LICENSE_EXTRAS_FILES
-unset BROOKLYN_LICENSE_MODE
-
-# individual projects
-for x in `cat projects-with-custom-licenses` ; do
-  export BROOKLYN_LICENSE_MODE=`basename $x`
-  echo MAKING LICENSES FOR: ${BROOKLYN_LICENSE_MODE}
-  export BROOKLYN_LICENSE_SPECIALS=-DonlyExtras=true
-  export BROOKLYN_LICENSE_EXTRAS_FILES=$x/src/main/license/source-inclusions.yaml
-  cp licenses/`basename $x`/* licenses/source
-  ./make-one-license.sh > LICENSE.autogenerated || ( echo FAILED. See details in tmp_stdout/err. && false )
-  cp LICENSE.autogenerated ../$x/src/main/license/files/LICENSE
-  unset BROOKLYN_LICENSE_SPECIALS
-  unset BROOKLYN_LICENSE_EXTRAS_FILES
-  unset BROOKLYN_LICENSE_MODE
-done
-
-# source build, at root
-export BROOKLYN_LICENSE_MODE=source
-echo MAKING LICENSES FOR: ${BROOKLYN_LICENSE_MODE}
-export BROOKLYN_LICENSE_SPECIALS=-DonlyExtras=true 
-./make-one-license.sh > LICENSE.autogenerated
-cp LICENSE.autogenerated ../../../LICENSE
-unset BROOKLYN_LICENSE_SPECIALS
-unset BROOKLYN_LICENSE_MODE
-
-# binary build, in dist
-export BROOKLYN_LICENSE_MODE=binary
-echo MAKING LICENSES FOR: ${BROOKLYN_LICENSE_MODE}
-./make-one-license.sh > LICENSE.autogenerated
-cp LICENSE.autogenerated ../src/main/license/files/LICENSE
-unset BROOKLYN_LICENSE_MODE
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/make-one-license.sh
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/make-one-license.sh b/usage/dist/licensing/make-one-license.sh
deleted file mode 100755
index 5bcb35b..0000000
--- a/usage/dist/licensing/make-one-license.sh
+++ /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.
-#
-
-set -e
-
-# generates a LICENSE file, including notices and other licenses as needed
-# uses various env vars BROOKLYN_LICENSE_* to determine appropriate behaviour;
-# see make-licenses.sh for examples
-
-ls MAIN_LICENSE_ASL2 > /dev/null 2> /dev/null || ( echo "Must run in licensing directory (where this script lives)" > /dev/stderr && false )
-
-if [ -z "${BROOKLYN_LICENSE_MODE}" ] ; then echo BROOKLYN_LICENSE_MODE must be set > /dev/stderr ; false ; fi
-
-
-cat << EOF
-
-This software is distributed under the Apache License, version 2.0. See (1) below.
-This software is copyright (c) The Apache Software Foundation and contributors.
-
-Contents:
-
-  (1) This software license: Apache License, version 2.0
-  (2) Notices for bundled software
-  (3) Licenses for bundled software
-
-
-EOF
-
-echo "---------------------------------------------------"
-echo
-echo "(1) This software license: Apache License, version 2.0"
-echo
-cat MAIN_LICENSE_ASL2
-echo
-echo "---------------------------------------------------"
-echo
-echo "(2) Notices for bundled software"
-echo
-pushd .. > /dev/null
-# add -X on next line to get debug info
-mvn org.heneveld.maven:license-audit-maven-plugin:notices \
-        -DlicensesPreferred=ASL2,ASL,EPL1,BSD-2-Clause,BSD-3-Clause,CDDL1.1,CDDL1,CDDL \
-        -DoverridesFile=licensing/overrides.yaml \
-        -DextrasFiles=${BROOKLYN_LICENSE_EXTRAS_FILES:-`cat licensing/extras-files`} \
-        ${BROOKLYN_LICENSE_SPECIALS} \
-        -DoutputFile=licensing/notices.autogenerated \
-    > tmp_stdout 2> tmp_stderr
-rm tmp_std*
-popd > /dev/null
-cat notices.autogenerated
-
-echo
-echo "---------------------------------------------------"
-echo
-echo "(3) Licenses for bundled software"
-echo
-echo Contents:
-echo
-for x in licenses/${BROOKLYN_LICENSE_MODE}/* ; do head -1 $x | awk '{print "  "$0;}' ; done
-echo
-echo
-for x in licenses/${BROOKLYN_LICENSE_MODE}/* ; do cat $x ; echo ; done
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/overrides.yaml
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/overrides.yaml b/usage/dist/licensing/overrides.yaml
deleted file mode 100644
index a2f6107..0000000
--- a/usage/dist/licensing/overrides.yaml
+++ /dev/null
@@ -1,383 +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.
-#
-
-
-# overrides file for org.heneveld.license-audit-maven-plugin
-# expands/corrects detail needed for generating license notices
-
-
-# super-projects to suppress notices for sub-projects
-
-- id: org.apache.brooklyn
-  url: http://brooklyn.incubator.apache.org/
-  license: ASL2
-  internal: true
-
-# poms with missing and incorrect data
-
-- id: org.codehaus.jettison:jettison
-  url: https://github.com/codehaus/jettison
-  license: ASL2 
-- id: org.glassfish.external:opendmk_jmxremote_optional_jar
-  url: https://opendmk.java.net/
-  license: CDDL
-- id: javax.validation:validation-api
-  url: http://beanvalidation.org/
-- id: com.squareup.okhttp:okhttp
-  copyright_by: Square, Inc.
-- id: com.squareup.okio:okio
-  copyright_by: Square, Inc.
-- id: com.wordnik:swagger-core_2.9.1
-  copyright_by: SmartBear Software
-- id: com.wordnik:swagger-jaxrs_2.9.1
-  copyright_by: SmartBear Software
-- id: org.bouncycastle  
-  copyright_by: The Legion of the Bouncy Castle Inc. (http://www.bouncycastle.org)
-- id: org.javassist:javassist
-  copyright_by: Shigeru Chiba
-- id: org.mongodb:mongo-java-driver
-  copyright_by: MongoDB, Inc
-- id: org.apache.httpcomponents:httpclient:*
-  url: http://hc.apache.org/httpcomponents-client-ga
-- id: javax.annotation:jsr250-api:*
-  url: https://jcp.org/en/jsr/detail?id=250
-- id: javax.ws.rs:jsr311-api:*
-  url: https://jsr311.java.net/
-- id: com.thoughtworks.xstream:*:*
-  url: http://x-stream.github.io/
-- id: com.fasterxml.jackson:*:*
-  url: http://wiki.fasterxml.com/JacksonHome
-
-- id: org.hibernate:jtidy:r8-20060801
-  license:
-  - url: "http://sourceforge.net/p/jtidy/code/HEAD/tree/trunk/jtidy/LICENSE.txt?revision=95"
-    name: Java HTML Tidy License
-    comment: Original link http://svn.sourceforge.net/viewvc/*checkout*/jtidy/trunk/jtidy/LICENSE.txt?revision=95 is no longer valid
-
-- id: dom4j:dom4j:1.6.1
-  url: "http://dom4j.sourceforge.net/"
-  license:
-  - name: MetaStuff BSD style license (3-clause)
-    url: http://dom4j.sourceforge.net/dom4j-1.6.1/license.html
-
-- id: org.python:jython-standalone:2.7-b3
-  copyright_by: Jython Developers
-  license:
-  - url: http://www.jython.org/license.html
-    name: Jython Software License
-    comment: Original link http://www.jython.org/Project/license.html is no longer valid
-
-- id: xpp3:xpp3_min:*
-  copyright_by: Extreme! Lab, Indiana University
-  license:
-  - url: https://github.com/apache/openmeetings/blob/a95714ce3f7e587d13d3d0bb3b4f570be15c67a5/LICENSE#L1361
-    name: "Indiana University Extreme! Lab Software License, vesion 1.1.1"
-    comment: |
-      The license applies to the Xpp3 classes (all classes below the org.xmlpull package with exception of classes directly in package org.xmlpull.v1);
-      original link http://www.extreme.indiana.edu/viewcvs/~checkout~/XPP3/java/LICENSE.txt is no longer valid
-  ## as we pull in xmlpull separately we do not use this, and having a single above simplifies the automation:
-  #  - url: http://creativecommons.org/licenses/publicdomain
-  #    name: Public Domain
-  #    comment: "The license applies to the XmlPull API (all classes directly in the org.xmlpull.v1 package)"
-
-
-# info on non-maven projects
-
-- id: jquery-core
-  url: http://jquery.com/
-  description: JS library for manipulating HTML and eventing
-  name: jQuery JavaScript Library
-  files: jquery.js
-  version: 1.7.2
-  organization: { name: "The jQuery Foundation", url: "http://jquery.org/" }
-  license: MIT
-  notices: 
-  - Copyright (c) John Resig (2005-2011)
-  - "Includes code fragments from sizzle.js:"
-  - "  Copyright (c) The Dojo Foundation"
-  - "  Available at http://sizzlejs.com"
-  - "  Used under the MIT license"
-
-- id: jquery-core:1.8.0
-  url: http://jquery.com/
-  description: JS library for manipulating HTML and eventing
-  name: jQuery JavaScript Library
-  files: jquery.js
-  version: 1.8.0
-  organization: { name: "The jQuery Foundation", url: "http://jquery.org/" }
-  license: MIT
-  notices:
-  - Copyright (c) The jQuery Foundation, Inc. and other contributors (2005-2012)
-  - "Includes code fragments from sizzle.js:"
-  # NB: sizzle copyright changed from Dojo Foundation in 1.7.2
-  - "  Copyright (c) The jQuery Foundation, Inc. and other contributors (2012)"
-  - "  Available at http://sizzlejs.com"
-  - "  Used under the MIT license"
-# used in docs (not reported)
-- id: jquery-core:2.1.1
-  url: http://jquery.com/
-  description: JS library for manipulating HTML and eventing
-  name: jQuery JavaScript Library
-  files: jquery.js
-  version: 2.1.1
-  organization: { name: "The jQuery Foundation", url: "http://jquery.org/" }
-  license: MIT
-  notices: 
-  - Copyright (c) The jQuery Foundation, Inc. and other contributors (2005-2014)
-  - "Includes code fragments from sizzle.js:"
-  # NB: sizzle copyright changed from Dojo Foundation in 1.7.2
-  - "  Copyright (c) The jQuery Foundation, Inc. and other contributors (2013)"
-  - "  Available at http://sizzlejs.com"
-  - "  Used under the MIT license"
-
-- id: swagger:2.1.6
-  name: Swagger JS
-  files: swagger-client.js
-  version: 2.1.6
-  url: https://github.com/swagger-api/swagger-js
-  license: ASL2
-  notice: Copyright (c) SmartBear Software (2011-2015)
-
-- id: swagger-ui:2.1.3
-  files: swagger-ui.js
-  name: Swagger UI
-  version: 2.1.3
-  url: https://github.com/swagger-api/swagger-ui
-  license: ASL2
-  notice: Copyright (c) SmartBear Software (2011-2015)
-  
-- id: jquery.wiggle.min.js
-  name: jQuery Wiggle
-  version: swagger-ui:1.0.1
-  notices: 
-  - Copyright (c) WonderGroup and Jordan Thomas (2010)
-  - Previously online at http://labs.wondergroup.com/demos/mini-ui/index.html.
-  # that is link in copyright but it is no longer valid; url below is same person
-  - The version included here is from the Swagger UI distribution.
-  url: https://github.com/jordanthomas/jquery-wiggle
-  license: MIT
-
-- id: require.js
-  name: RequireJS 
-  files: require.js, text.js
-  version: 2.0.6 
-  url: http://requirejs.org/
-  organization: { name: "The Dojo Foundation", url: "http://dojofoundation.org/" }
-  notice: Copyright (c) The Dojo Foundation (2010-2012)
-  license: MIT
-
-- id: require.js/r.js
-  # new ID because this is a different version to the above
-  name: RequireJS (r.js maven plugin)
-  files: r.js
-  version: 2.1.6 
-  url: http://github.com/jrburke/requirejs
-  organization: { name: "The Dojo Foundation", url: "http://dojofoundation.org/" }
-  notices:
-  - Copyright (c) The Dojo Foundation (2009-2013)
-  - "Includes code fragments for source-map and other functionality:" 
-  - "  Copyright (c) The Mozilla Foundation and contributors (2011)"
-  - "  Used under the BSD 2-Clause license."
-  - "Includes code fragments for parse-js and other functionality:" 
-  - "  Copyright (c) Mihai Bazon (2010, 2012)"
-  - "  Used under the BSD 2-Clause license."
-  - "Includes code fragments for uglifyjs/consolidator:" 
-  - "  Copyright (c) Robert Gust-Bardon (2012)"
-  - "  Used under the BSD 2-Clause license."
-  - "Includes code fragments for the esprima parser:" 
-  - "  Copyright (c):"
-  - "    Ariya Hidayat (2011, 2012)"
-  - "    Mathias Bynens (2012)"
-  - "    Joost-Wim Boekesteijn (2012)"
-  - "    Kris Kowal (2012)"
-  - "    Yusuke Suzuki (2012)"
-  - "    Arpad Borsos (2012)"
-  - "  Used under the BSD 2-Clause license."
-  license: MIT
-
-- id: backbone.js
-  version: 1.0.0
-  url: http://backbonejs.org
-  organization: { name: "DocumentCloud Inc.", url: "http://www.documentcloud.org/" }
-  notice: Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2010-2013)
-  license: MIT
-
-- id: backbone.js:1.1.2
-  version: 1.1.2
-  url: http://backbonejs.org
-  organization: { name: "DocumentCloud Inc.", url: "http://www.documentcloud.org/" }
-  notice: Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2010-2014)
-  license: MIT
-
-- id: bootstrap.js
-  version: 2.0.4
-  url: http://twitter.github.com/bootstrap/javascript.html#transitions
-  notice: Copyright (c) Twitter, Inc. (2012)
-  license: ASL2
- 
-# used in docs (not needed for licensing) 
-- id: bootstrap.js:3.1.1
-  version: 3.1.1
-  url: http://getbootstrap.com/
-  notice: Copyright (c) Twitter, Inc. (2011-2014)
-  license: MIT
-  
-- id: underscore.js
-  version: 1.4.4
-  files: underscore*.{js,map}
-  url: http://underscorejs.org
-  organization: { name: "DocumentCloud Inc.", url: "http://www.documentcloud.org/" }
-  notice: Copyright (c) Jeremy Ashkenas, DocumentCloud Inc. (2009-2013)
-  license: MIT
-
-# used in CLI (and in docs)
-- id: underscore.js:1.7.0
-  version: 1.7.0
-  files: underscore*.{js,map}
-  url: http://underscorejs.org
-  organization: { name: "DocumentCloud Inc.", url: "http://www.documentcloud.org/" }
-  notice: "Copyright (c) Jeremy Ashkenas, DocumentCloud and Investigative Reporters & Editors (2009-2014)"
-  license: MIT
-
-- id: async.js
-  version: 0.1.1
-  url: https://github.com/p15martin/google-maps-hello-world/blob/master/js/libs/async.js
-  # ORIGINALLY https://github.com/millermedeiros/requirejs-plugins
-  organization: { name: "Miller Medeiros", url: "https://github.com/millermedeiros/" }
-  description: RequireJS plugin for async dependency load like JSONP and Google Maps
-  notice: Copyright (c) Miller Medeiros (2011)
-  license: MIT 
-
-- id: handlebars.js
-  files: handlebars*.js
-  version: 1.0-rc1
-  url: https://github.com/wycats/handlebars.js 
-  organization: { name: "Yehuda Katz", url: "https://github.com/wycats/" }
-  notice: Copyright (c) Yehuda Katz (2012)
-  license: MIT
-
-- id: handlebars.js:2.0.0
-  files: handlebars*.js
-  version: 2.0.0
-  url: https://github.com/wycats/handlebars.js
-  organization: { name: "Yehuda Katz", url: "https://github.com/wycats/" }
-  notice: Copyright (c) Yehuda Katz (2014)
-  license: MIT
-
-- id: jquery.ba-bbq.js
-  name: "jQuery BBQ: Back Button & Query Library"
-  files: jquery.ba-bbq*.js
-  version: 1.2.1
-  url: http://benalman.com/projects/jquery-bbq-plugin/
-  organization: { name: "\"Cowboy\" Ben Alman", url: "http://benalman.com/" }
-  notice: Copyright (c) "Cowboy" Ben Alman (2010)"
-  license: MIT
-
-- id: moment.js
-  version: 2.1.0
-  url: http://momentjs.com
-  organization: { name: "Tim Wood", url: "http://momentjs.com" }
-  notice: Copyright (c) Tim Wood, Iskren Chernev, Moment.js contributors (2011-2014)
-  license: MIT
-
-- id: ZeroClipboard
-  files: ZeroClipboard.*
-  version: 1.3.1
-  url: http://zeroclipboard.org/
-  organization: { name: "ZeroClipboard contributors", url: "https://github.com/zeroclipboard" }
-  notice: Copyright (c) Jon Rohan, James M. Greene (2014)
-  license: MIT
-
-- id: jquery.dataTables
-  files: jquery.dataTables.{js,css}
-  name: DataTables Table plug-in for jQuery
-  version: 1.9.4
-  url: http://www.datatables.net/
-  organization: { name: "SpryMedia Ltd", url: "http://sprymedia.co.uk/" }
-  notice: Copyright (c) Allan Jardine (2008-2012)
-  license: BSD-3-Clause
-
-- id: js-uri
-  files: URI.js
-  version: 0.1
-  url: http://code.google.com/p/js-uri/
-  organization: { name: "js-uri contributors", url: "https://code.google.com/js-uri" }
-  license: BSD-3-Clause
-  # inferred
-  notice: Copyright (c) js-uri contributors (2013)
-
-- id: js-yaml.js
-  version: 3.2.7
-  organization: { name: "Vitaly Puzrin", url: "https://github.com/nodeca/" }
-  url: https://github.com/nodeca/
-  notice: Copyright (c) Vitaly Puzrin (2011-2015)
-  license: MIT
-
-- id: jquery.form.js
-  name: jQuery Form Plugin
-  version: "3.09"
-  url: https://github.com/malsup/form
-  # also http://malsup.com/jquery/form/
-  organization: { name: "Mike Alsup", url: "http://malsup.com/" }
-  notice: Copyright (c) M. Alsup (2006-2013)
-  license: MIT
-
-# used for CLI to build catalog
-- id: typeahead.js
-  version: 0.10.5
-  url: https://github.com/twitter/typeahead.js
-  organization: { name: "Twitter, Inc", url: "http://twitter.com" }
-  notice: Copyright (c) Twitter, Inc. and other contributors (2013-2014)
-  license: MIT
-
-# used for CLI to build catalog
-- id: marked.js
-  version: 0.3.1
-  url: https://github.com/chjj/marked
-  organization: { name: "Christopher Jeffrey", url: "https://github.com/chjj" }
-  notice: Copyright (c) Christopher Jeffrey (2011-2014)
-  license: MIT
-
-# DOCS files
-#
-# we don't do a distributable docs build -- they are just online.
-# (docs are excluded from the source build, and not bundled with the binary build.)
-# so these are not used currently; but for completeness and in case we change our minds,
-# here they are:
-
-# * different versions of jquery, bootstrap, and underscore noted above,
-# * media items github octicons and font-awesome fonts, not listed
-# * plus the below:
-
-- id: jquery.superfish.js
-  files: superfish.js
-  name: Superfish jQuery Menu Widget
-  version: 1.4.8
-  url: http://users.tpg.com.au/j_birch/plugins/superfish/
-  notice: Copyright (c) Joel Birch (2008)
-  license: MIT
-
-- id: jquery.cookie.js
-  name: jQuery Cookie Plugin
-  version: 1.3.1
-  url: https://github.com/carhartl/jquery-cookie
-  notice: Copyright (c) 2013 Klaus Hartl
-  license: MIT
-
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/licensing/projects-with-custom-licenses
----------------------------------------------------------------------
diff --git a/usage/dist/licensing/projects-with-custom-licenses b/usage/dist/licensing/projects-with-custom-licenses
deleted file mode 100644
index ebf210c..0000000
--- a/usage/dist/licensing/projects-with-custom-licenses
+++ /dev/null
@@ -1,2 +0,0 @@
-../jsgui
-../cli

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/pom.xml
----------------------------------------------------------------------
diff --git a/usage/dist/pom.xml b/usage/dist/pom.xml
deleted file mode 100644
index d9c392a..0000000
--- a/usage/dist/pom.xml
+++ /dev/null
@@ -1,158 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-    
-     http://www.apache.org/licenses/LICENSE-2.0
-    
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-    <modelVersion>4.0.0</modelVersion>
-    <packaging>jar</packaging>
-
-    <artifactId>brooklyn-dist</artifactId>
-
-    <name>Brooklyn Distribution</name>
-    <description>
-        Brooklyn redistributable package archive, includes all required
-        Jar files and scripts
-    </description>
-
-    <parent>
-        <groupId>org.apache.brooklyn</groupId>
-        <artifactId>brooklyn-parent</artifactId>
-        <version>0.9.0-SNAPSHOT</version>  <!-- BROOKLYN_VERSION -->
-        <relativePath>../../parent/pom.xml</relativePath>
-    </parent>
-
-    <dependencies>
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-all</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-
-        <!-- TODO include examples -->
-        <!-- TODO include documentation -->
-
-        <dependency>
-            <groupId>org.apache.brooklyn</groupId>
-            <artifactId>brooklyn-test-support</artifactId>
-            <version>${project.version}</version>
-            <scope>test</scope>
-        </dependency>
-        <dependency>
-            <groupId>org.testng</groupId>
-            <artifactId>testng</artifactId>
-            <scope>test</scope>
-        </dependency>
-
-    </dependencies>
-
-    <build>
-        <plugins>
-            <plugin>
-                <artifactId>maven-dependency-plugin</artifactId>
-                <!-- copy the config file from the CLI project (could instead use unpack goal with an includes filter) -->
-                <executions>
-                    <execution>
-                        <id>copy</id>
-                        <phase>process-classes</phase>
-                        <goals>
-                            <goal>copy</goal>
-                        </goals>
-                        <configuration>
-                            <artifactItems>
-                                <artifactItem>
-                                    <!-- this can fail in eclipse trying to copy _from_ target/classes.
-                                         see http://jira.codehaus.org/browse/MDEP-259 -->
-                                    <groupId>${project.groupId}</groupId>
-                                    <artifactId>brooklyn-cli</artifactId>
-                                    <version>${project.version}</version>
-                                    <type>bom</type>
-                                    <classifier>dist</classifier>
-                                    <overWrite>true</overWrite>
-                                    <outputDirectory>target</outputDirectory>
-                                    <destFileName>default.catalog.bom</destFileName>
-                                </artifactItem>
-                            </artifactItems>
-                        </configuration>
-                    </execution>
-                </executions>
-            </plugin>
-            <plugin>
-                <groupId>org.apache.rat</groupId>
-                <artifactId>apache-rat-plugin</artifactId>
-                <configuration>
-                    <excludes combine.children="append">
-                        <!-- Exclude sample config files because they are illustrative, intended for changing -->
-                        <exclude>src/main/dist/conf/**</exclude>
-                        <exclude>licensing/licenses/**</exclude>
-                        <exclude>licensing/README.md</exclude>
-                        <exclude>licensing/*LICENSE*</exclude>
-                        <exclude>licensing/*.autogenerated</exclude>
-                        <exclude>licensing/projects-with-custom-licenses</exclude>
-                        <exclude>licensing/extras-files</exclude>
-                    </excludes>
-                  </configuration>
-            </plugin>
-            <plugin>
-                <artifactId>maven-assembly-plugin</artifactId>
-                <executions>
-                    <execution>
-                        <id>build-distribution-dir</id>
-                        <phase>package</phase>
-                        <goals>
-                            <goal>single</goal>
-                        </goals>
-                        <configuration>
-                            <appendAssemblyId>true</appendAssemblyId>
-                            <descriptors>
-                                <descriptor>src/main/config/build-distribution.xml</descriptor>
-                            </descriptors>
-                            <finalName>brooklyn</finalName>
-                            <includeBaseDirectory>false</includeBaseDirectory>
-                            <formats>
-                                <format>dir</format>
-                            </formats>
-                            <attach>false</attach>
-                        </configuration>
-                    </execution>
-                    <execution>
-                        <id>build-distribution-archive</id>
-                        <phase>package</phase>
-                        <goals>
-                            <goal>single</goal>
-                        </goals>
-                        <configuration>
-                            <appendAssemblyId>true</appendAssemblyId>
-                            <descriptors>
-                                <descriptor>src/main/config/build-distribution.xml</descriptor>
-                            </descriptors>
-                          <!-- finalName affects name in `target/` but we cannot influence name when it is attached/installed,
-                               so `apache-` prefix would be lost there. to keep it consistent this is commented out, 
-                               but would be nice to have if there is a way!
-                            <finalName>apache-brooklyn-${project.version}</finalName>
-                          -->
-                            <formats>
-                                <format>tar.gz</format>
-                                <format>zip</format>
-                            </formats>
-                        </configuration>
-                    </execution>
-                </executions>
-            </plugin>
-        </plugins>
-    </build>
-</project>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/src/main/config/build-distribution.xml
----------------------------------------------------------------------
diff --git a/usage/dist/src/main/config/build-distribution.xml b/usage/dist/src/main/config/build-distribution.xml
deleted file mode 100644
index fc2264d..0000000
--- a/usage/dist/src/main/config/build-distribution.xml
+++ /dev/null
@@ -1,96 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-    
-     http://www.apache.org/licenses/LICENSE-2.0
-    
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
--->
-<assembly xmlns="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2"
-        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-        xsi:schemaLocation="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2 http://maven.apache.org/xsd/assembly-1.1.2.xsd">
-    <id>dist</id>
-    <formats><!-- empty, intended for caller to specify --></formats>
-    <fileSets>
-        <fileSet>
-            <directory>${project.basedir}/../..</directory>
-            <outputDirectory></outputDirectory>
-            <fileMode>0644</fileMode>
-            <directoryMode>0755</directoryMode>
-            <includes>
-                <include>README*</include>
-                <include>DISCLAIMER*</include>
-            </includes>
-        </fileSet>
-        <fileSet>
-            <directory>${project.basedir}/src/main/license/files</directory>
-            <outputDirectory></outputDirectory>
-            <fileMode>0644</fileMode>
-            <directoryMode>0755</directoryMode>
-        </fileSet>
-        <fileSet>
-            <directory>${project.basedir}/src/main/dist/bin</directory>
-            <outputDirectory>bin</outputDirectory>
-            <fileMode>0755</fileMode>
-            <directoryMode>0755</directoryMode>
-        </fileSet>
-        <fileSet>
-            <!-- Add an empty dropins folder (so need to reference an existing dir, and exclude everything) -->
-            <directory>${project.basedir}/src/main/dist</directory>
-            <outputDirectory>lib/dropins</outputDirectory>
-            <directoryMode>0755</directoryMode>
-            <excludes>
-                <exclude>**/*</exclude>
-            </excludes>
-        </fileSet>
-        <fileSet>
-            <directory>${project.basedir}/target</directory>
-            <outputDirectory>conf/brooklyn</outputDirectory>
-            <fileMode>0644</fileMode>
-            <directoryMode>0755</directoryMode>
-            <includes>
-                <include>default.catalog.bom</include>
-            </includes>
-        </fileSet>
-        <fileSet>
-            <!-- Add an empty patch folder (so need to reference an existing dir, and exclude everything) -->
-            <directory>${project.basedir}/src/main/dist</directory>
-            <outputDirectory>lib/patch</outputDirectory>
-            <directoryMode>0755</directoryMode>
-            <excludes>
-                <exclude>**/*</exclude>
-            </excludes>
-        </fileSet>
-        <fileSet>
-            <directory>${project.basedir}/src/main/dist</directory>
-            <outputDirectory></outputDirectory>
-            <fileMode>0644</fileMode>
-            <directoryMode>0755</directoryMode>
-            <excludes>
-                <exclude>bin/*</exclude>
-            </excludes>
-        </fileSet>
-    </fileSets>
-    <!-- TODO include documentation -->
-    <!-- TODO include examples -->
-    <dependencySets>
-        <dependencySet>
-            <useProjectArtifact>false</useProjectArtifact>
-            <outputDirectory>lib/brooklyn</outputDirectory>
-            <fileMode>0644</fileMode>
-            <directoryMode>0755</directoryMode>
-            <outputFileNameMapping>${artifact.groupId}-${artifact.artifactId}-${artifact.version}${dashClassifier?}.${artifact.extension}</outputFileNameMapping>
-        </dependencySet>
-    </dependencySets>
-</assembly>

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/src/main/dist/bin/.gitattributes
----------------------------------------------------------------------
diff --git a/usage/dist/src/main/dist/bin/.gitattributes b/usage/dist/src/main/dist/bin/.gitattributes
deleted file mode 100644
index 4e2b719..0000000
--- a/usage/dist/src/main/dist/bin/.gitattributes
+++ /dev/null
@@ -1,3 +0,0 @@
-#Don't auto-convert line endings for shell scripts on Windows (breaks the scripts)
-brooklyn text eol=lf
-cloud-explorer text eol=lf

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/src/main/dist/bin/brooklyn
----------------------------------------------------------------------
diff --git a/usage/dist/src/main/dist/bin/brooklyn b/usage/dist/src/main/dist/bin/brooklyn
deleted file mode 100755
index 370bc93..0000000
--- a/usage/dist/src/main/dist/bin/brooklyn
+++ /dev/null
@@ -1,51 +0,0 @@
-#!/usr/bin/env bash
-#
-# 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.
-#
-# Brooklyn
-#
-
-#set -x # debug
-
-# discover BROOKLYN_HOME if not set, by attempting to resolve absolute path of this command
-ROOT=$(cd "$(dirname "$0")/.." && pwd -P)
-if [ -z "$BROOKLYN_HOME" ] ; then
-    BROOKLYN_HOME=$(cd "$(dirname "$(readlink -f "$0" 2> /dev/null || readlink "$0" 2> /dev/null || echo "$0")")/.." && pwd)
-fi
-export ROOT BROOKLYN_HOME
-
-# use default memory settings, if not specified
-if [ -z "${JAVA_OPTS}" ] ; then
-    JAVA_OPTS="-Xms256m -Xmx1g -XX:MaxPermSize=256m"
-fi
-
-# set up the classpath
-INITIAL_CLASSPATH=${BROOKLYN_HOME}/conf:${BROOKLYN_HOME}/lib/patch/*:${BROOKLYN_HOME}/lib/brooklyn/*:${BROOKLYN_HOME}/lib/dropins/*
-# specify additional CP args in BROOKLYN_CLASSPATH
-if [ ! -z "${BROOKLYN_CLASSPATH}" ]; then
-    INITIAL_CLASSPATH=${BROOKLYN_CLASSPATH}:${INITIAL_CLASSPATH}
-fi
-export INITIAL_CLASSPATH
-
-# force resolution of localhost to be loopback, otherwise we hit problems
-# TODO should be changed in code
-JAVA_OPTS="-Dbrooklyn.location.localhost.address=127.0.0.1 ${JAVA_OPTS}"
-
-# start Brooklyn
-echo $$ > "$ROOT/pid_java"
-exec java ${JAVA_OPTS} -cp "${INITIAL_CLASSPATH}" org.apache.brooklyn.cli.Main "$@"

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/src/main/dist/bin/brooklyn.bat
----------------------------------------------------------------------
diff --git a/usage/dist/src/main/dist/bin/brooklyn.bat b/usage/dist/src/main/dist/bin/brooklyn.bat
deleted file mode 100644
index 90e300e..0000000
--- a/usage/dist/src/main/dist/bin/brooklyn.bat
+++ /dev/null
@@ -1,111 +0,0 @@
-@echo off
-REM Licensed to the Apache Software Foundation (ASF) under one
-REM or more contributor license agreements.  See the NOTICE file
-REM distributed with this work for additional information
-REM regarding copyright ownership.  The ASF licenses this file
-REM to you under the Apache License, Version 2.0 (the
-REM "License"); you may not use this file except in compliance
-REM with the License.  You may obtain a copy of the License at
-REM 
-REM   http://www.apache.org/licenses/LICENSE-2.0
-REM 
-REM Unless required by applicable law or agreed to in writing,
-REM software distributed under the License is distributed on an
-REM "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-REM KIND, either express or implied.  See the License for the
-REM specific language governing permissions and limitations
-REM under the License.
-
-SETLOCAL EnableDelayedExpansion
-
-REM discover BROOKLYN_HOME if not set, by attempting to resolve absolute path of this command (brooklyn.bat)
-IF NOT DEFINED BROOKLYN_HOME (
-    SET "WORKING_FOLDER=%~dp0"
-    
-    REM stript trailing slash
-    SET "WORKING_FOLDER=!WORKING_FOLDER:~0,-1!"
-    
-    REM get parent folder (~dp works only for batch file params and loop indexes)
-    FOR %%i in ("!WORKING_FOLDER!") DO SET "BROOKLYN_HOME=%%~dpi"
-)
-
-REM Discover the location of Java.
-REM Use JAVA_HOME environment variable, if available;
-REM else, check the path;
-REM else, search registry for Java installations;
-REM else fail.
-
-IF DEFINED JAVA_HOME (
-    CALL :joinpath "%JAVA_HOME%" bin\java.exe JAVA_BIN
-)
-
-IF NOT DEFINED JAVA_BIN (
-    IF NOT DEFINED JAVA_HOME CALL :registry_home "HKLM\SOFTWARE\JavaSoft\Java Runtime Environment"
-    IF NOT DEFINED JAVA_HOME CALL :registry_home "HKLM\SOFTWARE\Wow6432Node\JavaSoft\Java Runtime Environment"
-    IF NOT DEFINED JAVA_HOME CALL :registry_home "HKLM\SOFTWARE\JavaSoft\Java Development Kit"
-    IF NOT DEFINED JAVA_HOME CALL :registry_home "HKLM\SOFTWARE\Wow6432Node\JavaSoft\Java Development Kit"
-    CALL :joinpath "!JAVA_HOME!" bin\java.exe JAVA_BIN
-)
-
-IF NOT DEFINED JAVA_BIN (
-    java.exe -version > NUL 2> NUL
-    echo !ERRORLEVEL!
-    IF NOT !ERRORLEVEL!==9009 SET JAVA_BIN=java.exe
-)
-
-IF NOT DEFINED JAVA_BIN (
-    echo "Unable to locate a Java installation. Please set JAVA_HOME or PATH environment variables."
-    exit /b 1
-) ELSE (
-    "%JAVA_BIN%" -version > NUL 2> NUL
-    IF !ERRORLEVEL!==9009 (
-        echo "java.exe does not exist where specified. Please check JAVA_HOME or PATH environment variables."
-        exit /b 1
-    )
-)
-
-REM use default memory settings, if not specified
-IF "%JAVA_OPTS%"=="" SET JAVA_OPTS=-Xms256m -Xmx500m -XX:MaxPermSize=256m
-
-REM set up the classpath
-SET INITIAL_CLASSPATH=%BROOKLYN_HOME%conf;%BROOKLYN_HOME%lib\patch\*;%BROOKLYN_HOME%lib\brooklyn\*;%BROOKLYN_HOME%lib\dropins\*
-REM specify additional CP args in BROOKLYN_CLASSPATH
-IF NOT "%BROOKLYN_CLASSPATH%"=="" SET "INITIAL_CLASSPATH=%BROOKLYN_CLASSPATH%;%INITIAL_CLASSPATH%"
-
-REM force resolution of localhost to be loopback, otherwise we hit problems
-REM TODO should be changed in code
-SET JAVA_OPTS=-Dbrooklyn.location.localhost.address=127.0.0.1 %JAVA_OPTS%
-
-REM workaround for http://bugs.sun.com/view_bug.do?bug_id=4787931
-SET JAVA_OPTS=-Duser.home="%USERPROFILE%" %JAVA_OPTS%
-
-REM start Brooklyn
-REM NO easy way to find process PID!!!
-pushd %BROOKLYN_HOME%
-
-"%JAVA_BIN%" %JAVA_OPTS% -cp "%INITIAL_CLASSPATH%" org.apache.brooklyn.cli.Main %*
-
-popd
-
-ENDLOCAL
-GOTO :EOF
-
-:joinpath
-    SET Path1=%~1
-    SET Path2=%~2
-    IF {%Path1:~-1,1%}=={\} (SET "%3=%Path1%%Path2%") ELSE (SET "%3=%Path1%\%Path2%")
-GOTO :EOF
-
-:whereis
-    REM Doesn't handle paths with quotes in the PATH variable
-    SET "%2=%~$PATH:1"
-GOTO :EOF
-
-:registry_value
-    FOR /F "skip=2 tokens=2*" %%A IN ('REG QUERY %1 /v %2 2^>nul') DO SET "%3=%%B"
-GOTO :EOF
-
-:registry_home
-    CALL :registry_value %1 CurrentVersion JAVA_VERSION
-    CALL :registry_value "%~1\%JAVA_VERSION%" JavaHome JAVA_HOME
-GOTO :EOF

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/src/main/dist/bin/brooklyn.ps1
----------------------------------------------------------------------
diff --git a/usage/dist/src/main/dist/bin/brooklyn.ps1 b/usage/dist/src/main/dist/bin/brooklyn.ps1
deleted file mode 100644
index 6780ed2..0000000
--- a/usage/dist/src/main/dist/bin/brooklyn.ps1
+++ /dev/null
@@ -1,135 +0,0 @@
-#!ps1
-#
-# 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.
-#
-# Brooklyn
-#
-
-$ErrorActionPreference = "Stop";
-
-$ROOT = split-path -parent $MyInvocation.MyCommand.Definition
-
-# discover BROOKLYN_HOME if not set, by attempting to resolve absolute path of this command (brooklyn)
-if ( $env:BROOKLYN_HOME -eq $null ) {
-    $BROOKLYN_HOME = split-path -parent $ROOT
-} else {
-    $BROOKLYN_HOME = $env:BROOKLYN_HOME
-}
-
-# Discover the location of Java.
-# Use JAVA_HOME environment variable, if available;
-# else, search registry for Java installations;
-# else, check the path;
-# else fail.
-$bin = [System.IO.Path]::Combine("bin", "java.exe")
-if ( $env:JAVA_HOME -ne $null ) {
-    $javahome = $env:JAVA_HOME
-    $javabin = [System.IO.Path]::Combine($javahome, $bin)
-}
-if ( $javabin -eq $null ) {
-    $reglocations = ( 'HKLM:\SOFTWARE\JavaSoft\Java Runtime Environment',
-                      'HKLM:\SOFTWARE\Wow6432Node\JavaSoft\Java Runtime Environment' )
-    $jres = @{}
-    foreach ($loc in $reglocations) {
-        $item = Get-Item $loc -ErrorAction SilentlyContinue
-        if ($item -eq $null) { continue }
-        foreach ($key in Get-ChildItem $loc) {
-            $version = $key.PSChildName
-            $jrehome = $key.GetValue("JavaHome")
-            $jres.Add($version, $jrehome)
-        }
-    }
-    # TODO - this does a simple sort on the registry key name (the JRE version). This is not ideal - better would be
-    # to understand semantic versioning, filter out incompatible JREs (1.5 and earlier), prefer known good JREs (1.6
-    # or 1.7) and pick the highest patchlevel.
-    $last = ( $jres.Keys | Sort-Object | Select-Object -Last 1 )
-    if ( $last -ne $null ) {
-        $javahome = $jres.Get_Item($last)
-        $javabin = [System.IO.Path]::Combine($javahome, $bin)
-    }
-}
-if ( $javabin -eq $null ) {
-    $where = Get-Command "java.exe" -ErrorAction SilentlyContinue
-    if ( $where -ne $null ) {
-        $javabin = $where.Definition
-        $bindir = [System.IO.Path]::GetDirectoryName($javabin)
-        $javahome = [System.IO.Path]::GetDirectoryName($bindir)
-    }
-}
-
-if ( $javabin -eq $null ) {
-    throw "Unable to locate a Java installation. Please set JAVA_HOME or PATH environment variables."
-} elseif ( $( Get-Item $javabin -ErrorAction SilentlyContinue ) -eq $null ) {
-    throw "java.exe does not exist where specified. Please check JAVA_HOME or PATH environment variables."
-}
-
-# set up the classpath
-$cp = Get-ChildItem ${BROOKLYN_HOME}\conf | Select-Object -ExpandProperty FullName
-
-if ( Test-Path ${BROOKLYN_HOME}\lib\patch ) {
-    $cp += Get-ChildItem ${BROOKLYN_HOME}\lib\patch | Select-Object -ExpandProperty FullName
-}
-
-$cp += Get-ChildItem ${BROOKLYN_HOME}\lib\brooklyn | Select-Object -ExpandProperty FullName
-
-if ( Test-Path ${BROOKLYN_HOME}\lib\dropins ) {
-    $cp += Get-ChildItem ${BROOKLYN_HOME}\lib\dropins | Select-Object -ExpandProperty FullName
-}
-
-$INITIAL_CLASSPATH = $cp -join ';'
-
-# specify additional CP args in BROOKLYN_CLASSPATH
-if ( ! ( $env:BROOKLYN_CLASSPATH -eq $null )) {
-    $INITIAL_CLASSPATH = "$($INITIAL_CLASSPATH);$($env:BROOKLYN_CLASSPATH)"
-}
-
-# start to build up the arguments to the java invocation
-$javaargs = @()
-
-# add the user's java opts, or use default memory settings, if not specified
-if ( $env:JAVA_OPTS -eq $null ) {
-    $javaargs +="-Xms256m -Xmx1g -XX:MaxPermSize=256m"
-} else {
-    $javaargs +=$env:JAVA_OPTS
-}
-
-# force resolution of localhost to be loopback, otherwise we hit problems
-# TODO should be changed in code
-$javaargs += "-Dbrooklyn.localhost.address=127.0.0.1 $($JAVA_OPTS)"
-
-# workaround for http://bugs.sun.com/view_bug.do?bug_id=4787931
-$javaargs += "-Duser.home=`"$env:USERPROFILE`""
-
-# add the classpath
-$javaargs += "-cp"
-$javaargs += "`"$($INITIAL_CLASSPATH)`""
-
-# main class
-$javaargs += "org.apache.brooklyn.cli.Main"
-
-# copy in the arguments that were given to this script
-$javaargs += $args
-
-# start Brooklyn
-$process = Start-Process -FilePath $javabin -ArgumentList $javaargs -NoNewWindow -PassThru
-
-# save PID
-Set-Content -Path ${BROOKLYN_HOME}\pid_java -Value $($process.Id)
-
-# wait for it to finish
-$process.WaitForExit()

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/src/main/dist/conf/logback.xml
----------------------------------------------------------------------
diff --git a/usage/dist/src/main/dist/conf/logback.xml b/usage/dist/src/main/dist/conf/logback.xml
deleted file mode 100644
index e70862c..0000000
--- a/usage/dist/src/main/dist/conf/logback.xml
+++ /dev/null
@@ -1,14 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<configuration>
-
-    <!-- to supply custom logging, either change this file, supply your own logback-main.xml 
-         (overriding the default provided on the classpath) or any of the files it references; 
-         see the Logging section of the Brooklyn web site for more information -->
-
-    <property name="logging.basename" scope="context" value="brooklyn" />
-    <property name="logging.dir" scope="context" value="./" />
-
-    <include resource="logback-main.xml"/>
-    
-</configuration>
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/src/main/license/README.md
----------------------------------------------------------------------
diff --git a/usage/dist/src/main/license/README.md b/usage/dist/src/main/license/README.md
deleted file mode 100644
index 0d3b52b..0000000
--- a/usage/dist/src/main/license/README.md
+++ /dev/null
@@ -1,2 +0,0 @@
-See /usage/dist/licensing/README.md for an explanation of this directory.
-

http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/29757eea/usage/dist/src/main/license/files/DISCLAIMER
----------------------------------------------------------------------
diff --git a/usage/dist/src/main/license/files/DISCLAIMER b/usage/dist/src/main/license/files/DISCLAIMER
deleted file mode 100644
index 9e6119b..0000000
--- a/usage/dist/src/main/license/files/DISCLAIMER
+++ /dev/null
@@ -1,8 +0,0 @@
-
-Apache Brooklyn is an effort undergoing incubation at The Apache Software Foundation (ASF), 
-sponsored by the Apache Incubator. Incubation is required of all newly accepted projects until 
-a further review indicates that the infrastructure, communications, and decision making process 
-have stabilized in a manner consistent with other successful ASF projects. While incubation 
-status is not necessarily a reflection of the completeness or stability of the code, it does 
-indicate that the project has yet to be fully endorsed by the ASF.
-


[22/51] [abbrv] brooklyn-dist git commit: [DIST] fix url in readme

Posted by he...@apache.org.
[DIST] fix url in readme


Project: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/repo
Commit: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/commit/00d8f4c9
Tree: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/tree/00d8f4c9
Diff: http://git-wip-us.apache.org/repos/asf/brooklyn-dist/diff/00d8f4c9

Branch: refs/heads/master
Commit: 00d8f4c95aaa9efb816df8fd5336508c58ff3bb5
Parents: cdd021e
Author: Alex Heneveld <al...@cloudsoftcorp.com>
Authored: Tue Dec 22 18:05:43 2015 +0000
Committer: Alex Heneveld <al...@cloudsoftcorp.com>
Committed: Tue Dec 22 18:05:43 2015 +0000

----------------------------------------------------------------------
 brooklyn-dist/dist/src/main/dist/README.md | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-dist/blob/00d8f4c9/brooklyn-dist/dist/src/main/dist/README.md
----------------------------------------------------------------------
diff --git a/brooklyn-dist/dist/src/main/dist/README.md b/brooklyn-dist/dist/src/main/dist/README.md
index 3c7e46f..406bccd 100644
--- a/brooklyn-dist/dist/src/main/dist/README.md
+++ b/brooklyn-dist/dist/src/main/dist/README.md
@@ -13,5 +13,5 @@ For server CLI info, use:
 
     ./bin/brooklyn help
 
-And to learn more, including the full user's guide, visit [http://github.com/apache/brooklyn/].
+And to learn more, including the full user's guide, visit [brooklyn.apache.org](http://brooklyn.apache.org/).