You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@brooklyn.apache.org by ha...@apache.org on 2015/08/05 22:56:10 UTC

[06/20] incubator-brooklyn git commit: Package rename to org.apache.brooklyn: usage/camp/

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/catalog/CatalogYamlTemplateTest.java
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/catalog/CatalogYamlTemplateTest.java b/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/catalog/CatalogYamlTemplateTest.java
new file mode 100644
index 0000000..18ce3b3
--- /dev/null
+++ b/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/catalog/CatalogYamlTemplateTest.java
@@ -0,0 +1,95 @@
+/*
+ * 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.camp.brooklyn.catalog;
+
+import static org.testng.Assert.assertEquals;
+
+import org.testng.Assert;
+import org.testng.TestListenerAdapter;
+import org.testng.TestNG;
+import org.testng.annotations.Test;
+import org.apache.brooklyn.camp.brooklyn.AbstractYamlTest;
+import org.apache.brooklyn.catalog.CatalogItem;
+import org.apache.brooklyn.catalog.CatalogItem.CatalogItemType;
+import brooklyn.management.osgi.OsgiStandaloneTest;
+import brooklyn.management.osgi.OsgiTestResources;
+import org.apache.brooklyn.test.TestResourceUnavailableException;
+
+
+public class CatalogYamlTemplateTest extends AbstractYamlTest {
+    
+    private static final String SIMPLE_ENTITY_TYPE = OsgiTestResources.BROOKLYN_TEST_OSGI_ENTITIES_SIMPLE_ENTITY;
+
+    @Test
+    public void testAddCatalogItem() throws Exception {
+        CatalogItem<?, ?> item = makeItem();
+        assertEquals(item.getCatalogItemType(), CatalogItemType.TEMPLATE);
+        Assert.assertTrue(item.getPlanYaml().indexOf("sample comment")>=0,
+            "YAML did not include original comments; it was:\n"+item.getPlanYaml());
+        Assert.assertFalse(item.getPlanYaml().indexOf("description")>=0,
+            "YAML included metadata which should have been excluded; it was:\n"+item.getPlanYaml());
+
+        deleteCatalogEntity("t1");
+    }
+
+    @Test
+    public void testAddCatalogItemAndCheckSource() throws Exception {
+        // this will fail with the Eclipse TestNG plugin -- use the static main instead to run in eclipse!
+        // see Yamls.KnownClassVersionException for details
+        
+        CatalogItem<?, ?> item = makeItem();
+        Assert.assertTrue(item.getPlanYaml().indexOf("sample comment")>=0,
+            "YAML did not include original comments; it was:\n"+item.getPlanYaml());
+        Assert.assertFalse(item.getPlanYaml().indexOf("description")>=0,
+            "YAML included metadata which should have been excluded; it was:\n"+item.getPlanYaml());
+
+        deleteCatalogEntity("t1");
+    }
+
+    private CatalogItem<?, ?> makeItem() {
+        TestResourceUnavailableException.throwIfResourceUnavailable(getClass(), OsgiStandaloneTest.BROOKLYN_TEST_OSGI_ENTITIES_PATH);
+        
+        addCatalogItems(
+            "brooklyn.catalog:",
+            "  id: t1",
+            "  item_type: template",
+            "  name: My Catalog App",
+            "  description: My description",
+            "  icon_url: classpath://path/to/myicon.jpg",
+            "  version: " + TEST_VERSION,
+            "  libraries:",
+            "  - url: " + OsgiStandaloneTest.BROOKLYN_TEST_OSGI_ENTITIES_URL,
+            "  item:",
+            "    services:",
+            "    # this sample comment should be included",
+            "    - type: " + SIMPLE_ENTITY_TYPE);
+
+        CatalogItem<?, ?> item = mgmt().getCatalog().getCatalogItem("t1", TEST_VERSION);
+        return item;
+    }
+
+    // convenience for running in eclipse when the TestNG plugin drags in old version of snake yaml
+    public static void main(String[] args) {
+        TestListenerAdapter tla = new TestListenerAdapter();
+        TestNG testng = new TestNG();
+        testng.setTestClasses(new Class[] { CatalogYamlTemplateTest.class });
+        testng.addListener(tla);
+        testng.run();
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/catalog/CatalogYamlVersioningTest.java
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/catalog/CatalogYamlVersioningTest.java b/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/catalog/CatalogYamlVersioningTest.java
new file mode 100644
index 0000000..6d5e0b7
--- /dev/null
+++ b/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/catalog/CatalogYamlVersioningTest.java
@@ -0,0 +1,257 @@
+/*
+ * 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.camp.brooklyn.catalog;
+
+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 org.testng.Assert;
+import org.testng.annotations.BeforeMethod;
+import org.testng.annotations.Test;
+import org.apache.brooklyn.camp.brooklyn.AbstractYamlTest;
+import org.apache.brooklyn.catalog.BrooklynCatalog;
+import org.apache.brooklyn.catalog.CatalogItem;
+import brooklyn.catalog.CatalogPredicates;
+import brooklyn.catalog.internal.BasicBrooklynCatalog;
+import brooklyn.entity.Entity;
+import brooklyn.entity.basic.BasicApplication;
+import brooklyn.entity.basic.BasicEntity;
+import brooklyn.entity.basic.ConfigKeys;
+
+import com.google.common.base.Predicates;
+import com.google.common.collect.Iterables;
+
+public class CatalogYamlVersioningTest extends AbstractYamlTest {
+    
+    private BrooklynCatalog catalog;
+    
+    @BeforeMethod(alwaysRun = true)
+    public void setUp() {
+        super.setUp();
+        catalog = mgmt().getCatalog();
+    }
+
+    @Test
+    public void testAddItem() {
+        String symbolicName = "sampleId";
+        String version = "0.1.0";
+        addCatalogEntity(symbolicName, version);
+        assertSingleCatalogItem(symbolicName, version);
+    }
+
+    @Test
+    public void testAddUnversionedItem() {
+        String symbolicName = "sampleId";
+        addCatalogEntity(symbolicName, null);
+        assertSingleCatalogItem(symbolicName, BasicBrooklynCatalog.NO_VERSION);
+    }
+
+    @Test
+    public void testAddSameVersionFailsWhenIconIsDifferent() {
+        String symbolicName = "sampleId";
+        String version = "0.1.0";
+        addCatalogEntity(symbolicName, version);
+        addCatalogEntity(symbolicName, version);
+        try {
+            addCatalogEntity(symbolicName, version, BasicEntity.class.getName(), "classpath:/another/icon.png");
+            fail("Expected to fail");
+        } catch (IllegalStateException e) {
+            assertEquals(e.getMessage(), "Updating existing catalog entries is forbidden: " + symbolicName + ":" + version + ". Use forceUpdate argument to override.");
+        }
+    }
+    
+    @Test
+    public void testAddSameVersionForce() {
+        String symbolicName = "sampleId";
+        String version = "0.1.0";
+        addCatalogEntity(symbolicName, version);
+        forceCatalogUpdate();
+        String expectedType = "brooklyn.entity.basic.BasicApplication";
+        addCatalogEntity(symbolicName, version, expectedType);
+        CatalogItem<?, ?> item = catalog.getCatalogItem(symbolicName, version);
+        assertTrue(item.getPlanYaml().contains(expectedType), "Version not updated");
+    }
+    
+    @Test
+    public void testGetLatest() {
+        String symbolicName = "sampleId";
+        String v1 = "0.1.0";
+        String v2 = "0.2.0";
+        addCatalogEntity(symbolicName, v1);
+        addCatalogEntity(symbolicName, v2);
+        CatalogItem<?, ?> item = catalog.getCatalogItem(symbolicName, BasicBrooklynCatalog.DEFAULT_VERSION);
+        assertEquals(item.getVersion(), v2);
+    }
+    
+    @Test
+    public void testGetLatestStable() {
+        String symbolicName = "sampleId";
+        String v1 = "0.1.0";
+        String v2 = "0.2.0-SNAPSHOT";
+        addCatalogEntity(symbolicName, v1);
+        addCatalogEntity(symbolicName, v2);
+        CatalogItem<?, ?> item = catalog.getCatalogItem(symbolicName, BasicBrooklynCatalog.DEFAULT_VERSION);
+        assertEquals(item.getVersion(), v1);
+    }
+
+    @Test
+    public void testDelete() {
+        String symbolicName = "sampleId";
+        String version = "0.1.0";
+        addCatalogEntity(symbolicName, version);
+        assertTrue(catalog.getCatalogItems(CatalogPredicates.symbolicName(Predicates.equalTo(symbolicName))).iterator().hasNext());
+        catalog.deleteCatalogItem(symbolicName, version);
+        assertFalse(catalog.getCatalogItems(CatalogPredicates.symbolicName(Predicates.equalTo(symbolicName))).iterator().hasNext());
+    }
+    
+    @Test
+    public void testDeleteDefault() {
+        String symbolicName = "sampleId";
+        addCatalogEntity(symbolicName, null);
+        assertTrue(catalog.getCatalogItems(CatalogPredicates.symbolicName(Predicates.equalTo(symbolicName))).iterator().hasNext());
+        catalog.deleteCatalogItem(symbolicName, BasicBrooklynCatalog.NO_VERSION);
+        assertFalse(catalog.getCatalogItems(CatalogPredicates.symbolicName(Predicates.equalTo(symbolicName))).iterator().hasNext());
+    }
+    
+    @Test
+    public void testList() {
+        String symbolicName = "sampleId";
+        String v1 = "0.1.0";
+        String v2 = "0.2.0-SNAPSHOT";
+        addCatalogEntity(symbolicName, v1);
+        addCatalogEntity(symbolicName, v2);
+        Iterable<CatalogItem<Object, Object>> items = catalog.getCatalogItems(CatalogPredicates.symbolicName(Predicates.equalTo(symbolicName)));
+        assertEquals(Iterables.size(items), 2);
+    }
+    
+    @Test
+    public void testVersionedReference() throws Exception {
+        String symbolicName = "sampleId";
+        String parentName = "parentId";
+        String v1 = "0.1.0";
+        String v2 = "0.2.0";
+        String expectedType = BasicApplication.class.getName();
+
+        addCatalogEntity(symbolicName, v1, expectedType);
+        addCatalogEntity(symbolicName, v2);
+        addCatalogEntity(parentName, v1, symbolicName + ":" + v1);
+
+        Entity app = createAndStartApplication(
+                "services:",
+                "- type: " + parentName + ":" + v1);
+
+        assertEquals(app.getEntityType().getName(), expectedType);
+    }
+
+    @Test
+    public void testUnversionedReference() throws Exception {
+        String symbolicName = "sampleId";
+        String parentName = "parentId";
+        String v1 = "0.1.0";
+        String v2 = "0.2.0";
+        String expectedType = BasicApplication.class.getName();
+
+        addCatalogEntity(symbolicName, v1);
+        addCatalogEntity(symbolicName, v2, expectedType);
+        addCatalogEntity(parentName, v1, symbolicName);
+
+        Entity app = createAndStartApplication(
+                "services:",
+                "- type: " + parentName + ":" + v1);
+
+        assertEquals(app.getEntityType().getName(), expectedType);
+    }
+
+    private void doTestVersionedReferenceJustAdded(boolean isVersionImplicitSyntax) throws Exception {
+        addCatalogItems(            "brooklyn.catalog:",
+            "  version: 0.9",
+            "  items:",
+            "  - id: referrent",
+            "    item:",
+            "      type: "+BasicEntity.class.getName(),
+            "  - id: referrent",
+            "    version: 1.1",
+            "    item:",
+            "      type: "+BasicEntity.class.getName(),
+            "      brooklyn.config: { foo: bar }",
+            "  - id: referrer",
+            "    version: 1.0",
+            "    item:",
+            (isVersionImplicitSyntax ? 
+                "      type: referrent:1.1" :
+                "      type: referrent\n" +
+                "      version: 1.1"));
+        
+        Iterable<CatalogItem<Object, Object>> items = catalog.getCatalogItems(CatalogPredicates.symbolicName(Predicates.equalTo("referrer")));
+        Assert.assertEquals(Iterables.size(items), 1, "Wrong number of: "+items);
+        CatalogItem<Object, Object> item = Iterables.getOnlyElement(items);
+        Assert.assertEquals(item.getVersion(), "1.0");
+        
+        Entity app = createAndStartApplication(
+            "services:",
+            (isVersionImplicitSyntax ? 
+                "- type: referrer:1.0" :
+                "- type: referrer\n" +
+                "  version: 1.0") );
+        Entity child = Iterables.getOnlyElement(app.getChildren());
+        Assert.assertTrue(child instanceof BasicEntity, "Wrong child: "+child);
+        Assert.assertEquals(child.getConfig(ConfigKeys.newStringConfigKey("foo")), "bar");
+    }
+
+    @Test
+    public void testVersionedReferenceJustAddedExplicitVersion() throws Exception {
+        doTestVersionedReferenceJustAdded(false);
+    }
+    
+    @Test
+    public void testVersionedReferenceJustAddedImplicitVersionSyntax() throws Exception {
+        doTestVersionedReferenceJustAdded(true);
+    }
+    
+    private void assertSingleCatalogItem(String symbolicName, String version) {
+        Iterable<CatalogItem<Object, Object>> items = catalog.getCatalogItems(CatalogPredicates.symbolicName(Predicates.equalTo(symbolicName)));
+        CatalogItem<Object, Object> item = Iterables.getOnlyElement(items);
+        assertEquals(item.getSymbolicName(), symbolicName);
+        assertEquals(item.getVersion(), version);
+    }
+    
+    private void addCatalogEntity(String symbolicName, String version) {
+        addCatalogEntity(symbolicName, version, BasicEntity.class.getName());
+    }
+
+    private void addCatalogEntity(String symbolicName, String version, String type) {
+        addCatalogEntity(symbolicName, version, type, "classpath://path/to/myicon.jpg");
+    }
+    
+    private void addCatalogEntity(String symbolicName, String version, String type, String iconUrl) {
+        addCatalogItems(
+            "brooklyn.catalog:",
+            "  id: " + symbolicName,
+            "  name: My Catalog App",
+            "  description: My description",
+            "  icon_url: "+iconUrl,
+            (version != null ? "  version: " + version : ""),
+            "",
+            "services:",
+            "- type: " + type);
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/catalog/TestBasicApp.java
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/catalog/TestBasicApp.java b/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/catalog/TestBasicApp.java
new file mode 100644
index 0000000..6f6fab5
--- /dev/null
+++ b/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/catalog/TestBasicApp.java
@@ -0,0 +1,27 @@
+/*
+ * 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.camp.brooklyn.catalog;
+
+import brooklyn.entity.basic.BasicApplication;
+import brooklyn.entity.proxying.ImplementedBy;
+
+@ImplementedBy(TestBasicAppImpl.class)
+public interface TestBasicApp extends BasicApplication {
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/catalog/TestBasicAppImpl.java
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/catalog/TestBasicAppImpl.java b/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/catalog/TestBasicAppImpl.java
new file mode 100644
index 0000000..bedbd3b
--- /dev/null
+++ b/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/catalog/TestBasicAppImpl.java
@@ -0,0 +1,24 @@
+/*
+ * 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.camp.brooklyn.catalog;
+
+import brooklyn.entity.basic.BasicApplicationImpl;
+
+public class TestBasicAppImpl extends BasicApplicationImpl implements TestBasicApp {
+}

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/spi/dsl/DslParseTest.java
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/spi/dsl/DslParseTest.java b/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/spi/dsl/DslParseTest.java
new file mode 100644
index 0000000..4457cb3
--- /dev/null
+++ b/usage/camp/src/test/java/org/apache/brooklyn/camp/brooklyn/spi/dsl/DslParseTest.java
@@ -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.
+ */
+package org.apache.brooklyn.camp.brooklyn.spi.dsl;
+
+import static org.testng.Assert.assertEquals;
+import static org.testng.Assert.assertTrue;
+
+import java.util.Arrays;
+import java.util.List;
+
+import org.apache.brooklyn.camp.brooklyn.spi.dsl.parse.DslParser;
+import org.apache.brooklyn.camp.brooklyn.spi.dsl.parse.FunctionWithArgs;
+import org.apache.brooklyn.camp.brooklyn.spi.dsl.parse.QuotedString;
+import org.testng.annotations.Test;
+
+import brooklyn.util.text.StringEscapes.JavaStringEscapes;
+
+import com.google.common.collect.ImmutableList;
+import com.google.common.collect.Iterables;
+
+@Test
+public class DslParseTest {
+
+    public void testParseString() {
+        assertEquals(new DslParser("\"hello world\"").parse(), new QuotedString(JavaStringEscapes.wrapJavaString("hello world")));
+    }
+
+    public void testParseNoArgFunction() {
+        Object fx = new DslParser("f()").parse();
+        fx = Iterables.getOnlyElement( (List<?>)fx );
+        assertEquals( ((FunctionWithArgs)fx).getFunction(), "f" );
+        assertEquals( ((FunctionWithArgs)fx).getArgs(), ImmutableList.of());
+    }
+    
+    public void testParseOneArgFunction() {
+        Object fx = new DslParser("f(\"x\")").parse();
+        fx = Iterables.getOnlyElement( (List<?>)fx );
+        assertEquals( ((FunctionWithArgs)fx).getFunction(), "f" );
+        assertEquals( ((FunctionWithArgs)fx).getArgs(), Arrays.asList(new QuotedString("\"x\"")) );
+    }
+    
+    public void testParseMultiArgMultiTypeFunction() {
+        // TODO Parsing "f(\"x\", 1)" fails, because it interprets 1 as a function rather than a number. Is that expected?
+        Object fx = new DslParser("f(\"x\", \"y\")").parse();
+        fx = Iterables.getOnlyElement( (List<?>)fx );
+        assertEquals( ((FunctionWithArgs)fx).getFunction(), "f" );
+        assertEquals( ((FunctionWithArgs)fx).getArgs(), ImmutableList.of(new QuotedString("\"x\""), new QuotedString("\"y\"")));
+    }
+
+    
+    public void testParseFunctionChain() {
+        Object fx = new DslParser("f(\"x\").g()").parse();
+        assertTrue(((List<?>)fx).size() == 2, ""+fx);
+        Object fx1 = ((List<?>)fx).get(0);
+        Object fx2 = ((List<?>)fx).get(1);
+        assertEquals( ((FunctionWithArgs)fx1).getFunction(), "f" );
+        assertEquals( ((FunctionWithArgs)fx1).getArgs(), ImmutableList.of(new QuotedString("\"x\"")) );
+        assertEquals( ((FunctionWithArgs)fx2).getFunction(), "g" );
+        assertTrue( ((FunctionWithArgs)fx2).getArgs().isEmpty() );
+    }
+    
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entities-osgi-catalog-scan.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entities-osgi-catalog-scan.yaml b/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entities-osgi-catalog-scan.yaml
deleted file mode 100644
index 852d9e1..0000000
--- a/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entities-osgi-catalog-scan.yaml
+++ /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.
-#
-
-# test case which demonstrates osgi bundles can be scanned, *if* expand classpath is true
-
-brooklyn.catalog:
-  items:
-  - scanJavaAnnotations: true
-    version: 2.0.test_java
-    libraries:
-    - classpath:/brooklyn/osgi/brooklyn-test-osgi-more-entities_0.2.0.jar
-    - classpath:/brooklyn/osgi/brooklyn-test-osgi-entities.jar
-  - item:
-      id: more-entity
-      type: brooklyn.osgi.tests.more.MoreEntity
-      version: 2.0.test

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entity-v1-called-v1-osgi-catalog.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entity-v1-called-v1-osgi-catalog.yaml b/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entity-v1-called-v1-osgi-catalog.yaml
deleted file mode 100644
index 0bc4997..0000000
--- a/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entity-v1-called-v1-osgi-catalog.yaml
+++ /dev/null
@@ -1,27 +0,0 @@
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#  http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-services:
-- type: brooklyn.osgi.tests.more.MoreEntity
-
-brooklyn.catalog:
-  id: more-entity-v1
-  version: 1.0
-  # see OsgiTestResources
-  libraries:
-  - classpath:/brooklyn/osgi/brooklyn-test-osgi-more-entities_0.1.0.jar

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entity-v1-osgi-catalog.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entity-v1-osgi-catalog.yaml b/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entity-v1-osgi-catalog.yaml
deleted file mode 100644
index 940053d..0000000
--- a/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entity-v1-osgi-catalog.yaml
+++ /dev/null
@@ -1,27 +0,0 @@
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#  http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-services:
-- type: brooklyn.osgi.tests.more.MoreEntity
-
-brooklyn.catalog:
-  id: more-entity
-  version: 1.0
-  # see OsgiTestResources
-  libraries:
-  - classpath:/brooklyn/osgi/brooklyn-test-osgi-more-entities_0.1.0.jar

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entity-v1-with-policy-osgi-catalog.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entity-v1-with-policy-osgi-catalog.yaml b/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entity-v1-with-policy-osgi-catalog.yaml
deleted file mode 100644
index 3c03bd0..0000000
--- a/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entity-v1-with-policy-osgi-catalog.yaml
+++ /dev/null
@@ -1,29 +0,0 @@
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#  http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-services:
-- type: brooklyn.osgi.tests.more.MoreEntity
-  brooklyn.policies:
-  - type: simple-policy:1.0
-
-brooklyn.catalog:
-  id: more-entity
-  version: 1.0
-  # see OsgiTestResources
-  libraries:
-  - classpath:/brooklyn/osgi/brooklyn-test-osgi-more-entities_0.1.0.jar

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entity-v2-osgi-catalog.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entity-v2-osgi-catalog.yaml b/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entity-v2-osgi-catalog.yaml
deleted file mode 100644
index 74323fa..0000000
--- a/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-entity-v2-osgi-catalog.yaml
+++ /dev/null
@@ -1,28 +0,0 @@
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#  http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-services:
-- type: brooklyn.osgi.tests.more.MoreEntity
-
-brooklyn.catalog:
-  id: more-entity
-  version: 1.0
-  # see OsgiTestResources
-  libraries:
-  - classpath:/brooklyn/osgi/brooklyn-test-osgi-more-entities_0.2.0.jar
-  - classpath:/brooklyn/osgi/brooklyn-test-osgi-entities.jar

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-policies-osgi-catalog-scan.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-policies-osgi-catalog-scan.yaml b/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-policies-osgi-catalog-scan.yaml
deleted file mode 100644
index 47f344d..0000000
--- a/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/more-policies-osgi-catalog-scan.yaml
+++ /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.
-#
-
-# test case which demonstrates osgi bundles can be scanned, *if* expand classpath is true
-
-brooklyn.catalog:
-  items:
-  - scanJavaAnnotations: true
-    version: 2.0.test_java
-    libraries:
-    - classpath:/brooklyn/osgi/brooklyn-test-osgi-more-entities_0.2.0.jar
-    - classpath:/brooklyn/osgi/brooklyn-test-osgi-entities.jar
-  - item:
-      id: more-policy
-      type: brooklyn.osgi.tests.more.MorePolicy
-      version: 2.0.test

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/simple-policy-osgi-catalog.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/simple-policy-osgi-catalog.yaml b/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/simple-policy-osgi-catalog.yaml
deleted file mode 100644
index 0004513..0000000
--- a/usage/camp/src/test/resources/io/brooklyn/camp/brooklyn/catalog/simple-policy-osgi-catalog.yaml
+++ /dev/null
@@ -1,27 +0,0 @@
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#  http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-brooklyn.policies:
-- type: brooklyn.osgi.tests.SimplePolicy
-
-brooklyn.catalog:
-  id: simple-policy
-  version: 1.0
-  # see OsgiTestResources
-  libraries:
-  - classpath:/brooklyn/osgi/brooklyn-test-osgi-entities.jar

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entities-osgi-catalog-scan.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entities-osgi-catalog-scan.yaml b/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entities-osgi-catalog-scan.yaml
new file mode 100644
index 0000000..852d9e1
--- /dev/null
+++ b/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entities-osgi-catalog-scan.yaml
@@ -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.
+#
+
+# test case which demonstrates osgi bundles can be scanned, *if* expand classpath is true
+
+brooklyn.catalog:
+  items:
+  - scanJavaAnnotations: true
+    version: 2.0.test_java
+    libraries:
+    - classpath:/brooklyn/osgi/brooklyn-test-osgi-more-entities_0.2.0.jar
+    - classpath:/brooklyn/osgi/brooklyn-test-osgi-entities.jar
+  - item:
+      id: more-entity
+      type: brooklyn.osgi.tests.more.MoreEntity
+      version: 2.0.test

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entity-v1-called-v1-osgi-catalog.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entity-v1-called-v1-osgi-catalog.yaml b/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entity-v1-called-v1-osgi-catalog.yaml
new file mode 100644
index 0000000..0bc4997
--- /dev/null
+++ b/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entity-v1-called-v1-osgi-catalog.yaml
@@ -0,0 +1,27 @@
+#
+# 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.
+#
+services:
+- type: brooklyn.osgi.tests.more.MoreEntity
+
+brooklyn.catalog:
+  id: more-entity-v1
+  version: 1.0
+  # see OsgiTestResources
+  libraries:
+  - classpath:/brooklyn/osgi/brooklyn-test-osgi-more-entities_0.1.0.jar

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entity-v1-osgi-catalog.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entity-v1-osgi-catalog.yaml b/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entity-v1-osgi-catalog.yaml
new file mode 100644
index 0000000..940053d
--- /dev/null
+++ b/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entity-v1-osgi-catalog.yaml
@@ -0,0 +1,27 @@
+#
+# 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.
+#
+services:
+- type: brooklyn.osgi.tests.more.MoreEntity
+
+brooklyn.catalog:
+  id: more-entity
+  version: 1.0
+  # see OsgiTestResources
+  libraries:
+  - classpath:/brooklyn/osgi/brooklyn-test-osgi-more-entities_0.1.0.jar

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entity-v1-with-policy-osgi-catalog.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entity-v1-with-policy-osgi-catalog.yaml b/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entity-v1-with-policy-osgi-catalog.yaml
new file mode 100644
index 0000000..3c03bd0
--- /dev/null
+++ b/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entity-v1-with-policy-osgi-catalog.yaml
@@ -0,0 +1,29 @@
+#
+# 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.
+#
+services:
+- type: brooklyn.osgi.tests.more.MoreEntity
+  brooklyn.policies:
+  - type: simple-policy:1.0
+
+brooklyn.catalog:
+  id: more-entity
+  version: 1.0
+  # see OsgiTestResources
+  libraries:
+  - classpath:/brooklyn/osgi/brooklyn-test-osgi-more-entities_0.1.0.jar

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entity-v2-osgi-catalog.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entity-v2-osgi-catalog.yaml b/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entity-v2-osgi-catalog.yaml
new file mode 100644
index 0000000..74323fa
--- /dev/null
+++ b/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-entity-v2-osgi-catalog.yaml
@@ -0,0 +1,28 @@
+#
+# 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.
+#
+services:
+- type: brooklyn.osgi.tests.more.MoreEntity
+
+brooklyn.catalog:
+  id: more-entity
+  version: 1.0
+  # see OsgiTestResources
+  libraries:
+  - classpath:/brooklyn/osgi/brooklyn-test-osgi-more-entities_0.2.0.jar
+  - classpath:/brooklyn/osgi/brooklyn-test-osgi-entities.jar

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-policies-osgi-catalog-scan.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-policies-osgi-catalog-scan.yaml b/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-policies-osgi-catalog-scan.yaml
new file mode 100644
index 0000000..47f344d
--- /dev/null
+++ b/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/more-policies-osgi-catalog-scan.yaml
@@ -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.
+#
+
+# test case which demonstrates osgi bundles can be scanned, *if* expand classpath is true
+
+brooklyn.catalog:
+  items:
+  - scanJavaAnnotations: true
+    version: 2.0.test_java
+    libraries:
+    - classpath:/brooklyn/osgi/brooklyn-test-osgi-more-entities_0.2.0.jar
+    - classpath:/brooklyn/osgi/brooklyn-test-osgi-entities.jar
+  - item:
+      id: more-policy
+      type: brooklyn.osgi.tests.more.MorePolicy
+      version: 2.0.test

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/simple-policy-osgi-catalog.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/simple-policy-osgi-catalog.yaml b/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/simple-policy-osgi-catalog.yaml
new file mode 100644
index 0000000..0004513
--- /dev/null
+++ b/usage/camp/src/test/resources/org/apache/brooklyn/camp/brooklyn/catalog/simple-policy-osgi-catalog.yaml
@@ -0,0 +1,27 @@
+#
+# 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.policies:
+- type: brooklyn.osgi.tests.SimplePolicy
+
+brooklyn.catalog:
+  id: simple-policy
+  version: 1.0
+  # see OsgiTestResources
+  libraries:
+  - classpath:/brooklyn/osgi/brooklyn-test-osgi-entities.jar

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/simple-catalog.xml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/simple-catalog.xml b/usage/camp/src/test/resources/simple-catalog.xml
index 242478c..6536bdb 100644
--- a/usage/camp/src/test/resources/simple-catalog.xml
+++ b/usage/camp/src/test/resources/simple-catalog.xml
@@ -29,7 +29,7 @@
         <symbolicName>BasicApp</symbolicName>
     </template>
     <template name="Custom App" type="brooklyn.entity.basic.BasicApplication">
-        <symbolicName>io.brooklyn.camp.brooklyn.catalog.TestBasicApp</symbolicName>
+        <symbolicName>org.apache.brooklyn.camp.brooklyn.catalog.TestBasicApp</symbolicName>
         <!-- Tests that "java:" prefix won't load an old-style catalog item with the same id -->
     </template>
     <template name="Osgi App" type="brooklyn.osgi.tests.SimpleApplication">

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/test-entity-with-init-config.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/test-entity-with-init-config.yaml b/usage/camp/src/test/resources/test-entity-with-init-config.yaml
index 91167b0..f288363 100644
--- a/usage/camp/src/test/resources/test-entity-with-init-config.yaml
+++ b/usage/camp/src/test/resources/test-entity-with-init-config.yaml
@@ -25,7 +25,7 @@ services:
   name: testentity
   brooklyn.config:
     test.name: Name of the test entity
-- serviceType: io.brooklyn.camp.brooklyn.TestEntityWithInitConfig 
+- serviceType: org.apache.brooklyn.camp.brooklyn.TestEntityWithInitConfig 
   name: testentity with init config
   brooklyn.config:
     test.entity: $brooklyn:component("te1") # This entity will be accessed in TestEntityWithInitConfig.init()

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/test-referencing-enrichers.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/test-referencing-enrichers.yaml b/usage/camp/src/test/resources/test-referencing-enrichers.yaml
index 4bfc2da..f1d6a24 100644
--- a/usage/camp/src/test/resources/test-referencing-enrichers.yaml
+++ b/usage/camp/src/test/resources/test-referencing-enrichers.yaml
@@ -41,7 +41,7 @@ description: Test multi-layer application with each entity having an enricher re
 origin: https://github.com/apache/incubator-brooklyn
 id: app1
 brooklyn.enrichers:
-  - enricherType: io.brooklyn.camp.brooklyn.TestReferencingEnricher
+  - enricherType: org.apache.brooklyn.camp.brooklyn.TestReferencingEnricher
     brooklyn.config:
       test.reference.app: $brooklyn:component("app1")
       test.reference.entity1: $brooklyn:component("e1")
@@ -51,11 +51,11 @@ brooklyn.enrichers:
       test.reference.grandchild1: $brooklyn:component("gc1")
       test.reference.grandchild2: $brooklyn:component("gc2")
 services:
-- serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+- serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
   id: e1
   name: entity 1
   brooklyn.enrichers:
-  - enricherType: io.brooklyn.camp.brooklyn.TestReferencingEnricher
+  - enricherType: org.apache.brooklyn.camp.brooklyn.TestReferencingEnricher
     brooklyn.config:
       test.reference.app: $brooklyn:component("app1")
       test.reference.entity1: $brooklyn:component("e1")
@@ -65,11 +65,11 @@ services:
       test.reference.grandchild1: $brooklyn:component("gc1")
       test.reference.grandchild2: $brooklyn:component("gc2")
   brooklyn.children:
-    - serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+    - serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
       id: c1
       name: child 1
       brooklyn.enrichers:
-      - enricherType: io.brooklyn.camp.brooklyn.TestReferencingEnricher
+      - enricherType: org.apache.brooklyn.camp.brooklyn.TestReferencingEnricher
         brooklyn.config:
           test.reference.app: $brooklyn:component("app1")
           test.reference.entity1: $brooklyn:component("e1")
@@ -79,11 +79,11 @@ services:
           test.reference.grandchild1: $brooklyn:component("gc1")
           test.reference.grandchild2: $brooklyn:component("gc2")
       brooklyn.children:
-      - serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+      - serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
         id: gc1
         name: grandchild 1
         brooklyn.enrichers:
-        - enricherType: io.brooklyn.camp.brooklyn.TestReferencingEnricher
+        - enricherType: org.apache.brooklyn.camp.brooklyn.TestReferencingEnricher
           brooklyn.config:
             test.reference.app: $brooklyn:component("app1")
             test.reference.entity1: $brooklyn:component("e1")
@@ -92,11 +92,11 @@ services:
             test.reference.child2: $brooklyn:component("c2")
             test.reference.grandchild1: $brooklyn:component("gc1")
             test.reference.grandchild2: $brooklyn:component("gc2")
-      - serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+      - serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
         id: gc2
         name: grandchild 2
         brooklyn.enrichers:
-        - enricherType: io.brooklyn.camp.brooklyn.TestReferencingEnricher
+        - enricherType: org.apache.brooklyn.camp.brooklyn.TestReferencingEnricher
           brooklyn.config:
             test.reference.app: $brooklyn:component("app1")
             test.reference.entity1: $brooklyn:component("e1")
@@ -105,11 +105,11 @@ services:
             test.reference.child2: $brooklyn:component("c2")
             test.reference.grandchild1: $brooklyn:component("gc1")
             test.reference.grandchild2: $brooklyn:component("gc2") 
-    - serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+    - serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
       id: c2
       name: child 2
       brooklyn.enrichers:
-      - enricherType: io.brooklyn.camp.brooklyn.TestReferencingEnricher
+      - enricherType: org.apache.brooklyn.camp.brooklyn.TestReferencingEnricher
         brooklyn.config:
           test.reference.app: $brooklyn:component("app1")
           test.reference.entity1: $brooklyn:component("e1")
@@ -118,11 +118,11 @@ services:
           test.reference.child2: $brooklyn:component("c2")
           test.reference.grandchild1: $brooklyn:component("gc1")
           test.reference.grandchild2: $brooklyn:component("gc2")
-- serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+- serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
   id: e2
   name: entity 2
   brooklyn.enrichers:
-  - enricherType: io.brooklyn.camp.brooklyn.TestReferencingEnricher
+  - enricherType: org.apache.brooklyn.camp.brooklyn.TestReferencingEnricher
     brooklyn.config:
       test.reference.app: $brooklyn:component("app1")
       test.reference.entity1: $brooklyn:component("e1")

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/test-referencing-entities.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/test-referencing-entities.yaml b/usage/camp/src/test/resources/test-referencing-entities.yaml
index e37d851..19944c3 100644
--- a/usage/camp/src/test/resources/test-referencing-entities.yaml
+++ b/usage/camp/src/test/resources/test-referencing-entities.yaml
@@ -47,7 +47,7 @@ brooklyn.config:
   test.reference.grandchild2: $brooklyn:component("gc2")
   test.reference.bogus: $brooklyn:child("c1")
 services:
-- serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+- serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
   id: e1
   name: entity 1
   brooklyn.config:
@@ -61,7 +61,7 @@ services:
     test.reference.grandchild2: $brooklyn:component("gc2")
     test.reference.bogus: $brooklyn:descendant("app1")
   brooklyn.children:
-    - serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+    - serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
       id: c1
       name: child 1
       brooklyn.config:
@@ -76,7 +76,7 @@ services:
         test.reference.grandchild2: $brooklyn:component("gc2")
         test.reference.bogus: $brooklyn:component("bogus")
       brooklyn.children:
-      - serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+      - serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
         id: gc1
         name: grandchild 1
         brooklyn.config:
@@ -87,7 +87,7 @@ services:
           test.reference.child2: $brooklyn:component("c2")
           test.reference.grandchild1: $brooklyn:component("gc1")
           test.reference.grandchild2: $brooklyn:component("gc2")
-      - serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+      - serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
         id: gc2
         name: grandchild 2
         brooklyn.config:
@@ -98,7 +98,7 @@ services:
           test.reference.child2: $brooklyn:component("c2")
           test.reference.grandchild1: $brooklyn:component("gc1")
           test.reference.grandchild2: $brooklyn:component("gc2") 
-    - serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+    - serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
       id: c2
       name: child 2
       brooklyn.config:
@@ -109,7 +109,7 @@ services:
         test.reference.child2: $brooklyn:component("c2")
         test.reference.grandchild1: $brooklyn:component("gc1")
         test.reference.grandchild2: $brooklyn:component("gc2")
-- serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+- serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
   id: e2
   name: entity 2
   brooklyn.config:

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/camp/src/test/resources/test-referencing-policies.yaml
----------------------------------------------------------------------
diff --git a/usage/camp/src/test/resources/test-referencing-policies.yaml b/usage/camp/src/test/resources/test-referencing-policies.yaml
index 35f0233..ff06f5b 100644
--- a/usage/camp/src/test/resources/test-referencing-policies.yaml
+++ b/usage/camp/src/test/resources/test-referencing-policies.yaml
@@ -41,7 +41,7 @@ description: Test multi-layer application with each entity having a policy refer
 origin: https://github.com/apache/incubator-brooklyn
 id: app1
 brooklyn.policies:
-  - policyType: io.brooklyn.camp.brooklyn.TestReferencingPolicy
+  - policyType: org.apache.brooklyn.camp.brooklyn.TestReferencingPolicy
     brooklyn.config:
       test.reference.app: $brooklyn:component("app1")
       test.reference.entity1: $brooklyn:component("e1")
@@ -51,11 +51,11 @@ brooklyn.policies:
       test.reference.grandchild1: $brooklyn:component("gc1")
       test.reference.grandchild2: $brooklyn:component("gc2")
 services:
-- serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+- serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
   id: e1
   name: entity 1
   brooklyn.policies:
-  - policyType: io.brooklyn.camp.brooklyn.TestReferencingPolicy
+  - policyType: org.apache.brooklyn.camp.brooklyn.TestReferencingPolicy
     brooklyn.config:
       test.reference.app: $brooklyn:component("app1")
       test.reference.entity1: $brooklyn:component("e1")
@@ -65,11 +65,11 @@ services:
       test.reference.grandchild1: $brooklyn:component("gc1")
       test.reference.grandchild2: $brooklyn:component("gc2")
   brooklyn.children:
-    - serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+    - serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
       id: c1
       name: child 1
       brooklyn.policies:
-      - policyType: io.brooklyn.camp.brooklyn.TestReferencingPolicy
+      - policyType: org.apache.brooklyn.camp.brooklyn.TestReferencingPolicy
         brooklyn.config:
           test.reference.app: $brooklyn:component("app1")
           test.reference.entity1: $brooklyn:component("e1")
@@ -79,11 +79,11 @@ services:
           test.reference.grandchild1: $brooklyn:component("gc1")
           test.reference.grandchild2: $brooklyn:component("gc2")
       brooklyn.children:
-      - serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+      - serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
         id: gc1
         name: grandchild 1
         brooklyn.policies:
-        - policyType: io.brooklyn.camp.brooklyn.TestReferencingPolicy
+        - policyType: org.apache.brooklyn.camp.brooklyn.TestReferencingPolicy
           brooklyn.config:
             test.reference.app: $brooklyn:component("app1")
             test.reference.entity1: $brooklyn:component("e1")
@@ -92,11 +92,11 @@ services:
             test.reference.child2: $brooklyn:component("c2")
             test.reference.grandchild1: $brooklyn:component("gc1")
             test.reference.grandchild2: $brooklyn:component("gc2")
-      - serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+      - serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
         id: gc2
         name: grandchild 2
         brooklyn.policies:
-        - policyType: io.brooklyn.camp.brooklyn.TestReferencingPolicy
+        - policyType: org.apache.brooklyn.camp.brooklyn.TestReferencingPolicy
           brooklyn.config:
             test.reference.app: $brooklyn:component("app1")
             test.reference.entity1: $brooklyn:component("e1")
@@ -105,11 +105,11 @@ services:
             test.reference.child2: $brooklyn:component("c2")
             test.reference.grandchild1: $brooklyn:component("gc1")
             test.reference.grandchild2: $brooklyn:component("gc2") 
-    - serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+    - serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
       id: c2
       name: child 2
       brooklyn.policies:
-      - policyType: io.brooklyn.camp.brooklyn.TestReferencingPolicy
+      - policyType: org.apache.brooklyn.camp.brooklyn.TestReferencingPolicy
         brooklyn.config:
           test.reference.app: $brooklyn:component("app1")
           test.reference.entity1: $brooklyn:component("e1")
@@ -118,11 +118,11 @@ services:
           test.reference.child2: $brooklyn:component("c2")
           test.reference.grandchild1: $brooklyn:component("gc1")
           test.reference.grandchild2: $brooklyn:component("gc2")
-- serviceType: io.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
+- serviceType: org.apache.brooklyn.camp.brooklyn.ReferencingYamlTestEntity
   id: e2
   name: entity 2
   brooklyn.policies:
-  - policyType: io.brooklyn.camp.brooklyn.TestReferencingPolicy
+  - policyType: org.apache.brooklyn.camp.brooklyn.TestReferencingPolicy
     brooklyn.config:
       test.reference.app: $brooklyn:component("app1")
       test.reference.entity1: $brooklyn:component("e1")

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/launcher/src/main/java/brooklyn/launcher/BrooklynLauncher.java
----------------------------------------------------------------------
diff --git a/usage/launcher/src/main/java/brooklyn/launcher/BrooklynLauncher.java b/usage/launcher/src/main/java/brooklyn/launcher/BrooklynLauncher.java
index 76ded17..eb4fb82 100644
--- a/usage/launcher/src/main/java/brooklyn/launcher/BrooklynLauncher.java
+++ b/usage/launcher/src/main/java/brooklyn/launcher/BrooklynLauncher.java
@@ -33,6 +33,8 @@ import java.util.concurrent.TimeoutException;
 
 import javax.annotation.Nullable;
 
+import org.apache.brooklyn.camp.brooklyn.BrooklynCampPlatformLauncherNoServer;
+import org.apache.brooklyn.camp.brooklyn.spi.creation.BrooklynAssemblyTemplateInstantiator;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -103,8 +105,6 @@ import brooklyn.util.text.Strings;
 import brooklyn.util.time.Duration;
 import brooklyn.util.time.Time;
 import io.brooklyn.camp.CampPlatform;
-import io.brooklyn.camp.brooklyn.BrooklynCampPlatformLauncherNoServer;
-import io.brooklyn.camp.brooklyn.spi.creation.BrooklynAssemblyTemplateInstantiator;
 import io.brooklyn.camp.spi.AssemblyTemplate;
 import io.brooklyn.camp.spi.instantiate.AssemblyTemplateInstantiator;
 

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/launcher/src/main/java/brooklyn/launcher/camp/BrooklynCampPlatformLauncher.java
----------------------------------------------------------------------
diff --git a/usage/launcher/src/main/java/brooklyn/launcher/camp/BrooklynCampPlatformLauncher.java b/usage/launcher/src/main/java/brooklyn/launcher/camp/BrooklynCampPlatformLauncher.java
index c8e7df4..3bd4823 100644
--- a/usage/launcher/src/main/java/brooklyn/launcher/camp/BrooklynCampPlatformLauncher.java
+++ b/usage/launcher/src/main/java/brooklyn/launcher/camp/BrooklynCampPlatformLauncher.java
@@ -19,14 +19,15 @@
 package brooklyn.launcher.camp;
 
 import io.brooklyn.camp.CampServer;
-import io.brooklyn.camp.brooklyn.BrooklynCampPlatform;
-import io.brooklyn.camp.brooklyn.BrooklynCampPlatformLauncherAbstract;
 import io.brooklyn.camp.spi.PlatformRootSummary;
 import brooklyn.entity.basic.BrooklynShutdownHooks;
 import brooklyn.launcher.BrooklynLauncher;
 import brooklyn.management.ManagementContext;
 import brooklyn.management.internal.LocalManagementContext;
 
+import org.apache.brooklyn.camp.brooklyn.BrooklynCampPlatform;
+import org.apache.brooklyn.camp.brooklyn.BrooklynCampPlatformLauncherAbstract;
+
 import com.google.common.annotations.Beta;
 
 /** variant of super who also starts a CampServer for convenience */

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/launcher/src/main/java/brooklyn/launcher/camp/SimpleYamlLauncher.java
----------------------------------------------------------------------
diff --git a/usage/launcher/src/main/java/brooklyn/launcher/camp/SimpleYamlLauncher.java b/usage/launcher/src/main/java/brooklyn/launcher/camp/SimpleYamlLauncher.java
index ad3e281..0603ded 100644
--- a/usage/launcher/src/main/java/brooklyn/launcher/camp/SimpleYamlLauncher.java
+++ b/usage/launcher/src/main/java/brooklyn/launcher/camp/SimpleYamlLauncher.java
@@ -18,8 +18,8 @@
  */
 package brooklyn.launcher.camp;
 
-import io.brooklyn.camp.brooklyn.BrooklynCampPlatformLauncherAbstract;
-import io.brooklyn.camp.brooklyn.YamlLauncherAbstract;
+import org.apache.brooklyn.camp.brooklyn.BrooklynCampPlatformLauncherAbstract;
+import org.apache.brooklyn.camp.brooklyn.YamlLauncherAbstract;
 
 import com.google.common.annotations.Beta;
 

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/launcher/src/test/java/brooklyn/launcher/blueprints/AbstractBlueprintTest.java
----------------------------------------------------------------------
diff --git a/usage/launcher/src/test/java/brooklyn/launcher/blueprints/AbstractBlueprintTest.java b/usage/launcher/src/test/java/brooklyn/launcher/blueprints/AbstractBlueprintTest.java
index ec084e9..63a8bfb 100644
--- a/usage/launcher/src/test/java/brooklyn/launcher/blueprints/AbstractBlueprintTest.java
+++ b/usage/launcher/src/test/java/brooklyn/launcher/blueprints/AbstractBlueprintTest.java
@@ -19,13 +19,13 @@
 package brooklyn.launcher.blueprints;
 
 import static org.testng.Assert.assertNotEquals;
-import io.brooklyn.camp.brooklyn.BrooklynCampPlatformLauncherAbstract;
 
 import java.io.File;
 import java.io.Reader;
 import java.io.StringReader;
 import java.util.Collection;
 
+import org.apache.brooklyn.camp.brooklyn.BrooklynCampPlatformLauncherAbstract;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 import org.testng.annotations.AfterMethod;

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/rest-server/src/test/java/brooklyn/rest/BrooklynRestApiLauncher.java
----------------------------------------------------------------------
diff --git a/usage/rest-server/src/test/java/brooklyn/rest/BrooklynRestApiLauncher.java b/usage/rest-server/src/test/java/brooklyn/rest/BrooklynRestApiLauncher.java
index 138a4ca..08511b7 100644
--- a/usage/rest-server/src/test/java/brooklyn/rest/BrooklynRestApiLauncher.java
+++ b/usage/rest-server/src/test/java/brooklyn/rest/BrooklynRestApiLauncher.java
@@ -19,8 +19,6 @@
 package brooklyn.rest;
 
 import static com.google.common.base.Preconditions.checkNotNull;
-import io.brooklyn.camp.brooklyn.BrooklynCampPlatformLauncherAbstract;
-import io.brooklyn.camp.brooklyn.BrooklynCampPlatformLauncherNoServer;
 
 import java.io.File;
 import java.io.FilenameFilter;
@@ -32,6 +30,8 @@ import java.util.List;
 import javax.servlet.DispatcherType;
 import javax.servlet.Filter;
 
+import org.apache.brooklyn.camp.brooklyn.BrooklynCampPlatformLauncherAbstract;
+import org.apache.brooklyn.camp.brooklyn.BrooklynCampPlatformLauncherNoServer;
 import org.eclipse.jetty.server.Server;
 import org.eclipse.jetty.server.handler.ContextHandler;
 import org.eclipse.jetty.servlet.FilterHolder;

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/rest-server/src/test/java/brooklyn/rest/HaMasterCheckFilterTest.java
----------------------------------------------------------------------
diff --git a/usage/rest-server/src/test/java/brooklyn/rest/HaMasterCheckFilterTest.java b/usage/rest-server/src/test/java/brooklyn/rest/HaMasterCheckFilterTest.java
index eabeef1..ff16c29 100644
--- a/usage/rest-server/src/test/java/brooklyn/rest/HaMasterCheckFilterTest.java
+++ b/usage/rest-server/src/test/java/brooklyn/rest/HaMasterCheckFilterTest.java
@@ -19,13 +19,13 @@
 package brooklyn.rest;
 
 import static org.testng.Assert.assertEquals;
-import io.brooklyn.camp.brooklyn.BrooklynCampPlatformLauncherNoServer;
 
 import java.io.File;
 import java.net.URI;
 import java.util.concurrent.Callable;
 import java.util.concurrent.TimeoutException;
 
+import org.apache.brooklyn.camp.brooklyn.BrooklynCampPlatformLauncherNoServer;
 import org.apache.http.HttpStatus;
 import org.apache.http.client.HttpClient;
 import org.eclipse.jetty.server.Server;

http://git-wip-us.apache.org/repos/asf/incubator-brooklyn/blob/e406d1ad/usage/rest-server/src/test/java/brooklyn/rest/testing/BrooklynRestApiTest.java
----------------------------------------------------------------------
diff --git a/usage/rest-server/src/test/java/brooklyn/rest/testing/BrooklynRestApiTest.java b/usage/rest-server/src/test/java/brooklyn/rest/testing/BrooklynRestApiTest.java
index af8909a..36a7cd4 100644
--- a/usage/rest-server/src/test/java/brooklyn/rest/testing/BrooklynRestApiTest.java
+++ b/usage/rest-server/src/test/java/brooklyn/rest/testing/BrooklynRestApiTest.java
@@ -18,6 +18,7 @@
  */
 package brooklyn.rest.testing;
 
+import org.apache.brooklyn.camp.brooklyn.BrooklynCampPlatformLauncherNoServer;
 import org.codehaus.jackson.map.ObjectMapper;
 import org.testng.annotations.AfterClass;
 import org.testng.annotations.BeforeMethod;
@@ -45,7 +46,6 @@ import brooklyn.rest.util.TestShutdownHandler;
 import brooklyn.rest.util.json.BrooklynJacksonJsonProvider;
 import brooklyn.test.entity.LocalManagementContextForTests;
 import brooklyn.util.exceptions.Exceptions;
-import io.brooklyn.camp.brooklyn.BrooklynCampPlatformLauncherNoServer;
 
 public abstract class BrooklynRestApiTest {