You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@brooklyn.apache.org by dr...@apache.org on 2017/09/15 11:42:20 UTC

[8/9] brooklyn-server git commit: PR #819 config descriptions: incorporate comments (2)

PR #819 config descriptions: incorporate comments (2)

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

Branch: refs/heads/master
Commit: 98297ced8bdc5260320cf8155679bc5d789651ed
Parents: d465091
Author: Aled Sage <al...@gmail.com>
Authored: Fri Sep 15 12:15:11 2017 +0100
Committer: Aled Sage <al...@gmail.com>
Committed: Fri Sep 15 12:15:11 2017 +0100

----------------------------------------------------------------------
 .../core/entity/BrooklynConfigKeys.java         |   2 +-
 .../enricher/stock/AbstractAggregator.java      |   2 +-
 .../enricher/stock/AbstractTransformer.java     |   2 +-
 .../brooklyn/enricher/stock/Aggregator.java     |   2 +-
 .../brooklyn/enricher/stock/Combiner.java       |   2 +-
 .../apache/brooklyn/enricher/stock/Joiner.java  |   2 +-
 .../enricher/stock/PercentageEnricher.java      |   2 +-
 .../brooklyn/enricher/stock/UpdatingMap.java    |   2 +-
 .../enricher/stock/reducer/Reducer.java         |   2 +-
 core/src/main/resources/catalog.bom             |   2 +-
 .../init/src/main/resources/catalog-classes.bom | 105 +++++++++++++++++--
 test-framework/src/main/resources/catalog.bom   |  10 ++
 12 files changed, 115 insertions(+), 20 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/brooklyn-server/blob/98297ced/core/src/main/java/org/apache/brooklyn/core/entity/BrooklynConfigKeys.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/brooklyn/core/entity/BrooklynConfigKeys.java b/core/src/main/java/org/apache/brooklyn/core/entity/BrooklynConfigKeys.java
index 9d92d19..10c5f3e 100644
--- a/core/src/main/java/org/apache/brooklyn/core/entity/BrooklynConfigKeys.java
+++ b/core/src/main/java/org/apache/brooklyn/core/entity/BrooklynConfigKeys.java
@@ -98,7 +98,7 @@ public class BrooklynConfigKeys {
     public static final ConfigKey<Boolean> SKIP_ENTITY_START_IF_RUNNING = ConfigKeys.builder(Boolean.class)
             .name("skip.start.ifRunning") 
             .deprecatedNames("entity.running") 
-            .description("Whether to skip the startup process entirely, but only if it already running")
+            .description("Whether to skip the startup process if the entity is detected as already running")
             .build();
 
     /**

http://git-wip-us.apache.org/repos/asf/brooklyn-server/blob/98297ced/core/src/main/java/org/apache/brooklyn/enricher/stock/AbstractAggregator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/brooklyn/enricher/stock/AbstractAggregator.java b/core/src/main/java/org/apache/brooklyn/enricher/stock/AbstractAggregator.java
index 8e296ab..da9e30b 100644
--- a/core/src/main/java/org/apache/brooklyn/enricher/stock/AbstractAggregator.java
+++ b/core/src/main/java/org/apache/brooklyn/enricher/stock/AbstractAggregator.java
@@ -58,7 +58,7 @@ public abstract class AbstractAggregator<T,U> extends AbstractEnricher implement
     public static final ConfigKey<Sensor<?>> TARGET_SENSOR = ConfigKeys.newConfigKey(
             new TypeToken<Sensor<?>>() {},
             "enricher.targetSensor",
-            "The sensor that will be set on the associated entity, with the target value");
+            "The sensor to be set on the associated entity with the value computed here");
 
     // FIXME this is not just for "members" i think -Alex
     public static final ConfigKey<?> DEFAULT_MEMBER_VALUE = ConfigKeys.newConfigKey(

http://git-wip-us.apache.org/repos/asf/brooklyn-server/blob/98297ced/core/src/main/java/org/apache/brooklyn/enricher/stock/AbstractTransformer.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/brooklyn/enricher/stock/AbstractTransformer.java b/core/src/main/java/org/apache/brooklyn/enricher/stock/AbstractTransformer.java
index a53c297..3069e17 100644
--- a/core/src/main/java/org/apache/brooklyn/enricher/stock/AbstractTransformer.java
+++ b/core/src/main/java/org/apache/brooklyn/enricher/stock/AbstractTransformer.java
@@ -58,7 +58,7 @@ public abstract class AbstractTransformer<T,U> extends AbstractEnricher implemen
     public static final ConfigKey<Sensor<?>> TARGET_SENSOR = ConfigKeys.newConfigKey(
             new TypeToken<Sensor<?>>() {},
             "enricher.targetSensor",
-            "The sensor that will be set on the associated entity, with the target value");
+            "The sensor to be set on the associated entity with the value computed here");
     
     public static final ConfigKey<List<? extends Sensor<?>>> TRIGGER_SENSORS = ConfigKeys.newConfigKey(
             new TypeToken<List<? extends Sensor<?>>>() {}, 

http://git-wip-us.apache.org/repos/asf/brooklyn-server/blob/98297ced/core/src/main/java/org/apache/brooklyn/enricher/stock/Aggregator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/brooklyn/enricher/stock/Aggregator.java b/core/src/main/java/org/apache/brooklyn/enricher/stock/Aggregator.java
index 4f6c481..cf55caa 100644
--- a/core/src/main/java/org/apache/brooklyn/enricher/stock/Aggregator.java
+++ b/core/src/main/java/org/apache/brooklyn/enricher/stock/Aggregator.java
@@ -81,7 +81,7 @@ public class Aggregator<T,U> extends AbstractAggregator<T,U> implements SensorEv
 
     public static final ConfigKey<Integer> QUORUM_TOTAL_SIZE = ConfigKeys.newIntegerConfigKey(
             "quorum.total.size", 
-            "The total size to consider when determining if quorate (used iwth transformation of type 'isQuorate')", 1);
+            "The total size to consider when determining if quorate (used with transformation of type 'isQuorate')", 1);
 
     protected Sensor<T> sourceSensor;
     protected Function<? super Collection<T>, ? extends U> transformation;

http://git-wip-us.apache.org/repos/asf/brooklyn-server/blob/98297ced/core/src/main/java/org/apache/brooklyn/enricher/stock/Combiner.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/brooklyn/enricher/stock/Combiner.java b/core/src/main/java/org/apache/brooklyn/enricher/stock/Combiner.java
index f0ff358..ad1797e 100644
--- a/core/src/main/java/org/apache/brooklyn/enricher/stock/Combiner.java
+++ b/core/src/main/java/org/apache/brooklyn/enricher/stock/Combiner.java
@@ -73,7 +73,7 @@ public class Combiner<T,U> extends AbstractEnricher implements SensorEventListen
     public static ConfigKey<Sensor<?>> TARGET_SENSOR = ConfigKeys.newConfigKey(
             new TypeToken<Sensor<?>>() {}, 
             "enricher.targetSensor",
-            "The sensor that will be set on the associated entity, with the target value");
+            "The sensor to be set on the associated entity with the value computed here");
 
     public static final ConfigKey<Predicate<?>> VALUE_FILTER = ConfigKeys.newConfigKey(
             new TypeToken<Predicate<?>>() {}, 

http://git-wip-us.apache.org/repos/asf/brooklyn-server/blob/98297ced/core/src/main/java/org/apache/brooklyn/enricher/stock/Joiner.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/brooklyn/enricher/stock/Joiner.java b/core/src/main/java/org/apache/brooklyn/enricher/stock/Joiner.java
index a456105..84ea120 100644
--- a/core/src/main/java/org/apache/brooklyn/enricher/stock/Joiner.java
+++ b/core/src/main/java/org/apache/brooklyn/enricher/stock/Joiner.java
@@ -56,7 +56,7 @@ public class Joiner<T> extends AbstractEnricher implements SensorEventListener<T
     
     public static final ConfigKey<Sensor<?>> TARGET_SENSOR = ConfigKeys.newConfigKey(new TypeToken<Sensor<?>>() {},
             "enricher.targetSensor",
-            "The sensor that will be set on the associated entity, with the target value");
+            "The sensor to be set on the associated entity with the value computed here");
 
     @SetFromFlag("separator")
     public static final ConfigKey<String> SEPARATOR = ConfigKeys.newStringConfigKey(

http://git-wip-us.apache.org/repos/asf/brooklyn-server/blob/98297ced/core/src/main/java/org/apache/brooklyn/enricher/stock/PercentageEnricher.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/brooklyn/enricher/stock/PercentageEnricher.java b/core/src/main/java/org/apache/brooklyn/enricher/stock/PercentageEnricher.java
index b031b1c..496dfaf 100644
--- a/core/src/main/java/org/apache/brooklyn/enricher/stock/PercentageEnricher.java
+++ b/core/src/main/java/org/apache/brooklyn/enricher/stock/PercentageEnricher.java
@@ -67,7 +67,7 @@ public class PercentageEnricher extends AbstractEnricher implements SensorEventL
     public static final ConfigKey<AttributeSensor<Double>> TARGET_SENSOR = ConfigKeys.newConfigKey(
             new TypeToken<AttributeSensor<Double>>() {},
             "enricher.targetSensor",
-            "The sensor on which to emit the ratio");
+            "The sensor to be set on the associated entity with the value computed here");
 
     public static final ConfigKey<Entity> PRODUCER = ConfigKeys.newConfigKey(
             Entity.class, 

http://git-wip-us.apache.org/repos/asf/brooklyn-server/blob/98297ced/core/src/main/java/org/apache/brooklyn/enricher/stock/UpdatingMap.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/brooklyn/enricher/stock/UpdatingMap.java b/core/src/main/java/org/apache/brooklyn/enricher/stock/UpdatingMap.java
index 68a1ce6..f759ec3 100644
--- a/core/src/main/java/org/apache/brooklyn/enricher/stock/UpdatingMap.java
+++ b/core/src/main/java/org/apache/brooklyn/enricher/stock/UpdatingMap.java
@@ -79,7 +79,7 @@ public class UpdatingMap<S,TKey,TVal> extends AbstractEnricher implements Sensor
     public static final ConfigKey<Sensor<?>> TARGET_SENSOR = ConfigKeys.newConfigKey(
             new TypeToken<Sensor<?>>() {}, 
             "enricher.targetSensor",
-            "The map-sensor that will be updated on the associated entity");
+            "The map-sensor to be updated on the associated entity with the value computed here");
 
     
     @SetFromFlag("key")

http://git-wip-us.apache.org/repos/asf/brooklyn-server/blob/98297ced/core/src/main/java/org/apache/brooklyn/enricher/stock/reducer/Reducer.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/brooklyn/enricher/stock/reducer/Reducer.java b/core/src/main/java/org/apache/brooklyn/enricher/stock/reducer/Reducer.java
index ff0cd51..f18a722 100644
--- a/core/src/main/java/org/apache/brooklyn/enricher/stock/reducer/Reducer.java
+++ b/core/src/main/java/org/apache/brooklyn/enricher/stock/reducer/Reducer.java
@@ -62,7 +62,7 @@ public class Reducer extends AbstractEnricher implements SensorEventListener<Obj
     public static final ConfigKey<Sensor<?>> TARGET_SENSOR = ConfigKeys.newConfigKey(
             new TypeToken<Sensor<?>>() {},
             "enricher.targetSensor",
-            "The sensor that will be set on the associated entity, with the target value");
+            "The sensor to be set on the associated entity with the value computed here");
 
     public static final ConfigKey<List<? extends AttributeSensor<?>>> SOURCE_SENSORS = ConfigKeys.newConfigKey(
             new TypeToken<List<? extends AttributeSensor<?>>>() {},

http://git-wip-us.apache.org/repos/asf/brooklyn-server/blob/98297ced/core/src/main/resources/catalog.bom
----------------------------------------------------------------------
diff --git a/core/src/main/resources/catalog.bom b/core/src/main/resources/catalog.bom
index 6625afe..2e3c299 100644
--- a/core/src/main/resources/catalog.bom
+++ b/core/src/main/resources/catalog.bom
@@ -38,7 +38,7 @@ brooklyn.catalog:
     - id: org.apache.brooklyn.entity.stock.DataEntity
       item:
         type: org.apache.brooklyn.entity.stock.DataEntity
-        name: Basic Entity
+        name: Data Entity
         description: An entity that supplies data as sensor values (periodically evaluating given suppliers).
     - id: org.apache.brooklyn.entity.group.DynamicGroup
       item:

http://git-wip-us.apache.org/repos/asf/brooklyn-server/blob/98297ced/karaf/init/src/main/resources/catalog-classes.bom
----------------------------------------------------------------------
diff --git a/karaf/init/src/main/resources/catalog-classes.bom b/karaf/init/src/main/resources/catalog-classes.bom
index 3cb90ac..afcf9fe 100644
--- a/karaf/init/src/main/resources/catalog-classes.bom
+++ b/karaf/init/src/main/resources/catalog-classes.bom
@@ -24,42 +24,68 @@ brooklyn.catalog:
      - id: org.apache.brooklyn.entity.group.QuarantineGroup
        item:
          type: org.apache.brooklyn.entity.group.QuarantineGroup
+         name: Quarantine Group
+         description: A grouping for entities that are in quarantine (i.e. removed from the main cluster)
      - id: org.apache.brooklyn.entity.group.BasicGroup
        item:
          type: org.apache.brooklyn.entity.group.BasicGroup
+         name: Basic Group
+         description: A grouping of entities
      - id: org.apache.brooklyn.entity.stock.BasicEntity
        item:
          type: org.apache.brooklyn.entity.stock.BasicEntity
+         name: Basic Entity
+         description: The simplest basic entity (can be useful for testing)
      - id: org.apache.brooklyn.entity.stock.DataEntity
        item:
          type: org.apache.brooklyn.entity.stock.DataEntity
+         name: Data Entity
+         description: An entity that supplies data as sensor values (periodically evaluating given suppliers).
      - id: org.apache.brooklyn.entity.group.DynamicGroup
        item:
          type: org.apache.brooklyn.entity.group.DynamicGroup
+         name: Dynamic Group
+         description: A grouping of entities, where membership of the group is based on a given filter.
      - id: org.apache.brooklyn.entity.stock.DelegateEntity
        item:
          type: org.apache.brooklyn.entity.stock.DelegateEntity
+         name: Delegate Entity
+         description: An entity that mirrors another entity (mirroring its sensors)
      - id: org.apache.brooklyn.entity.group.DynamicRegionsFabric
        item:
          type: org.apache.brooklyn.entity.group.DynamicRegionsFabric
+         name: Dynamic Regions Fabric
+         description: A 'fabric' (see 'Dynamic Fabric') that allows new locations to be added/removed. 
      - id: org.apache.brooklyn.core.server.entity.BrooklynMetrics
        item:
          type: org.apache.brooklyn.core.server.entity.BrooklynMetrics
+         name: Brooklyn Metrics
+         description: An entity that gives information about this Brooklyn server.
      - id: org.apache.brooklyn.entity.stock.BasicApplication
        item:
          type: org.apache.brooklyn.entity.stock.BasicApplication
+         name: Basic Application
+         description: The simplest application.
      - id: org.apache.brooklyn.entity.stock.BasicStartable
        item:
          type: org.apache.brooklyn.entity.stock.BasicStartable
+         name: Basic Startable
+         description: Provides a pass-through Startable entity, which can control the location(s) passed to its children.
      - id: org.apache.brooklyn.entity.group.DynamicCluster
        item:
          type: org.apache.brooklyn.entity.group.DynamicCluster
+         name: Dynamic Cluster
+         description: A cluster of entities that can dynamically increase or decrease the number of members.
      - id: org.apache.brooklyn.entity.group.DynamicMultiGroup
        item:
          type: org.apache.brooklyn.entity.group.DynamicMultiGroup
+         name: Dynamic Multi Group
+         description: Similar to 'Dynamic Group', but with multiple child groups. Entities are added to the child groups based on a supplied filter. 
      - id: org.apache.brooklyn.entity.group.DynamicFabric
        item:
          type: org.apache.brooklyn.entity.group.DynamicFabric
+         name: Dynamic Fabric
+         description: The 'fabric' creates and starts an entity in each of its locations.
 
   # org.apache.brooklyn.policy
   - items:
@@ -81,24 +107,26 @@ brooklyn.catalog:
         type: org.apache.brooklyn.policy.ha.SshMachineFailureDetector
         name: Ssh Connectivity Failure Detector
         description: HA policy for monitoring an SshMachine, 
-#    removed from catalog because it cannot currently be configured via catalog mechanisms
+
+#    Removed from catalog because 'FollowTheSunPool' cannot currently be configured via catalog mechanisms.
+#    Also removing associated 'BalanceableWorkerPool' etc as they are only useful with 'FollowTheSunPool'
 #    - id: org.apache.brooklyn.policy.followthesun.FollowTheSunPool
 #      item:
 #        type: org.apache.brooklyn.policy.followthesun.FollowTheSunPool
-    - id: org.apache.brooklyn.policy.loadbalancing.BalanceableWorkerPool
-      itemType: entity
-      item:
-        type: org.apache.brooklyn.policy.loadbalancing.BalanceableWorkerPool
+#    - id: org.apache.brooklyn.policy.loadbalancing.BalanceableWorkerPool
+#      itemType: entity
+#      item:
+#        type: org.apache.brooklyn.policy.loadbalancing.BalanceableWorkerPool
+#    - id: org.apache.brooklyn.policy.loadbalancing.ItemsInContainersGroup
+#      itemType: entity
+#      item:
+#        type: org.apache.brooklyn.policy.loadbalancing.ItemsInContainersGroup
     - id: org.apache.brooklyn.policy.ha.ServiceReplacer
       itemType: policy
       item:
         type: org.apache.brooklyn.policy.ha.ServiceReplacer
         name: Service Replacer
         description: HA policy for replacing a failed member of a group
-    - id: org.apache.brooklyn.policy.loadbalancing.ItemsInContainersGroup
-      itemType: entity
-      item:
-        type: org.apache.brooklyn.policy.loadbalancing.ItemsInContainersGroup
     - id: org.apache.brooklyn.policy.autoscaling.AutoScalerPolicy
       itemType: policy
       item:
@@ -113,82 +141,126 @@ brooklyn.catalog:
       itemType: enricher
       item:
         type: org.apache.brooklyn.core.network.OnPublicNetworkEnricher
+        name: Public Network Advertiser
+        description: Advertises entity's public mapped ports. This can be used with sensors of type URI, HostAndPort or plain integer port values
     - id: org.apache.brooklyn.core.network.OnSubnetNetworkEnricher
       itemType: enricher
       item:
         type: org.apache.brooklyn.core.network.OnSubnetNetworkEnricher
+        name: Subnet Network Advertiser
+        description: Advertises entity's subnet mapped ports. This can be used with sensors of type URI, HostAndPort or plain integer port values
     - id: org.apache.brooklyn.enricher.stock.Aggregator
       itemType: enricher
       item:
         type: org.apache.brooklyn.enricher.stock.Aggregator
+        name: Aggregator
+        description: Aggregates sensors from multiple entities into a single sensor value
     - id: org.apache.brooklyn.enricher.stock.Combiner
       itemType: enricher
       item:
         type: org.apache.brooklyn.enricher.stock.Combiner
+        name: Combiner
+        description: Combines and apply a transformation to sensors of an entity
     - id: org.apache.brooklyn.enricher.stock.Joiner
       itemType: enricher
       item:
         type: org.apache.brooklyn.enricher.stock.Joiner
+        name: Joiner
+        description: Joins entity's sensors into another one, i.e. creates a comma separated string from a list
     - id: org.apache.brooklyn.enricher.stock.MapAggregator
       itemType: enricher
       item:
         type: org.apache.brooklyn.enricher.stock.MapAggregator
+        name: Map Aggregator
+        description: Aggregates a pair of sensors on multiple children and/or members that are used as key-value pairs in a generated Map
     - id: org.apache.brooklyn.enricher.stock.PercentageEnricher
       itemType: enricher
       item:
         type: org.apache.brooklyn.enricher.stock.PercentageEnricher
+        name: Percentage Transformer
+        description: Computes and advertises the percentage based on a current and total values
     - id: org.apache.brooklyn.enricher.stock.Propagator
       itemType: enricher
       item:
         type: org.apache.brooklyn.enricher.stock.Propagator
+        name: Propagator
+        description: Propagates sensors from one entity to another
     - id: org.apache.brooklyn.enricher.stock.Transformer
       itemType: enricher
       item:
         type: org.apache.brooklyn.enricher.stock.Transformer
+        name: Transformer
+        description: Transforms sensors of an entity
     - id: org.apache.brooklyn.enricher.stock.UpdatingMap
       itemType: enricher
       item:
         type: org.apache.brooklyn.enricher.stock.UpdatingMap
+        name: Map Updater
+        description: Updates an entry in a sensor Map
     - id: org.apache.brooklyn.enricher.stock.YamlRollingTimeWindowMeanEnricher
       itemType: enricher
       item:
         type: org.apache.brooklyn.enricher.stock.YamlRollingTimeWindowMeanEnricher
+        name: YAML Rolling Average
+        description: Transforms sensor data into a rolling average based on a time window.")
     - id: org.apache.brooklyn.enricher.stock.YamlTimeWeightedDeltaEnricher
       itemType: enricher
       item:
         type: org.apache.brooklyn.enricher.stock.YamlTimeWeightedDeltaEnricher
+        name: YAML Time-weighted Delta
+        description: Converts an absolute count sensor into a delta sensor
     - id: org.apache.brooklyn.enricher.stock.reducer.Reducer
       itemType: enricher
       item:
         type: org.apache.brooklyn.enricher.stock.reducer.Reducer
+        name: Reducer
+        description: Applies a transformation to a sensor
     - id: org.apache.brooklyn.policy.enricher.DeltaEnricher
       itemType: enricher
       item:
         type: org.apache.brooklyn.policy.enricher.DeltaEnricher
+        name: Delta
+        description: Converts an absolute sensor into a delta sensor (i.e. the diff between the current and previous value)
     - id: org.apache.brooklyn.policy.enricher.HttpLatencyDetector
       itemType: enricher
       item:
         type: org.apache.brooklyn.policy.enricher.HttpLatencyDetector
+        name: HTTP Latency Detector
+        description: Computes latency in accessing a URL, normally by periodically polling that URL
     - id: org.apache.brooklyn.policy.enricher.RollingMeanEnricher
       itemType: enricher
       item:
         type: org.apache.brooklyn.policy.enricher.RollingMeanEnricher
+        name: Rolling Mean
+        description: |
+          Transforms a sensor into a rolling average based on a fixed window size. 
+          This is useful for smoothing sample type metrics, such as latency or CPU time.
     - id: org.apache.brooklyn.policy.enricher.RollingTimeWindowMeanEnricher
       itemType: enricher
       item:
         type: org.apache.brooklyn.policy.enricher.RollingTimeWindowMeanEnricher
+        name: [DEPRECATED] Rolling Mean in Time Window
+        description: [DEPRECATED] Prefer YamlRollingTimeWindowMeanEnricher
     - id: org.apache.brooklyn.policy.enricher.TimeFractionDeltaEnricher
       itemType: enricher
       item:
         type: org.apache.brooklyn.policy.enricher.TimeFractionDeltaEnricher
+        name: Time-fraction Delta
+        description: |
+          Converts an absolute measure of time into a fraction of time, 
+          based on the delta between consecutive values and the elapsed time between those values.
     - id: org.apache.brooklyn.policy.enricher.TimeWeightedDeltaEnricher
       itemType: enricher
       item:
         type: org.apache.brooklyn.policy.enricher.TimeWeightedDeltaEnricher
+        name: [DEPRECATED] Time Weighted Delta
+        description: [DEPRECATED] prefer 'YamlTimeWeightedDeltaEnricher'
     - id: org.apache.brooklyn.policy.ha.ServiceFailureDetector
       itemType: enricher
       item:
         type: org.apache.brooklyn.policy.ha.ServiceFailureDetector
+        name: Service Failure Detector
+        description: Emits a new sensor if the current entity fails
 
     # org.apache.brooklyn.software-base
   - itemType: entity
@@ -224,6 +296,7 @@ brooklyn.catalog:
     - id: org.apache.brooklyn.entity.java.VanillaJavaApp
       item:
         type: org.apache.brooklyn.entity.java.VanillaJavaApp
+        name: Vanilla Java App
     - id: org.apache.brooklyn.entity.brooklynnode.BrooklynNode
       item:
         type: org.apache.brooklyn.entity.brooklynnode.BrooklynNode
@@ -232,9 +305,12 @@ brooklyn.catalog:
     - id: org.apache.brooklyn.entity.brooklynnode.BrooklynCluster
       item:
         type: org.apache.brooklyn.entity.brooklynnode.BrooklynCluster
+        name: Brooklyn Cluster
     - id: org.apache.brooklyn.entity.brooklynnode.LocalBrooklynNode
       item:
         type: org.apache.brooklyn.entity.brooklynnode.LocalBrooklynNode
+        name: Local Brooklyn Node
+        description: An entity that represents the local Brooklyn server.
     - id: org.apache.brooklyn.entity.software.base.VanillaSoftwareProcess
       item:
         type: org.apache.brooklyn.entity.software.base.VanillaSoftwareProcess
@@ -246,34 +322,43 @@ brooklyn.catalog:
         name: Server Pool
         description: Creates a pre-allocated server pool, which other applications can deploy to
 
-
   # org.apache.brooklyn.test-framework
   - itemType: entity
     items:
     - id: org.apache.brooklyn.test.framework.TestSshCommand
       item:
         type: org.apache.brooklyn.test.framework.TestSshCommand
+        name: Test SSH Command
     - id: org.apache.brooklyn.test.framework.SimpleShellCommandTest
       item:
         type: org.apache.brooklyn.test.framework.SimpleShellCommandTest
+        name: [DEPRECATED] Simple Shell Command Test
+        description:  [DEPRECATED] Instead use TestSshCommand
     - id: org.apache.brooklyn.test.framework.ParallelTestCase
       item:
         type: org.apache.brooklyn.test.framework.ParallelTestCase
+        name: Parallel Test Case
     - id: org.apache.brooklyn.test.framework.TestCase
       item:
         type: org.apache.brooklyn.test.framework.TestCase
+        name: Test Case
     - id: org.apache.brooklyn.test.framework.InfrastructureDeploymentTestCase
       item:
         type: org.apache.brooklyn.test.framework.InfrastructureDeploymentTestCase
+        name: Infrastructure Deployment Test Case
     - id: org.apache.brooklyn.test.framework.TestSensor
       item:
         type: org.apache.brooklyn.test.framework.TestSensor
+        name: Test Sensor
     - id: org.apache.brooklyn.test.framework.TestEffector
       item:
         type: org.apache.brooklyn.test.framework.TestEffector
+        name: Test Effector
     - id: org.apache.brooklyn.test.framework.TestHttpCall
       item:
         type: org.apache.brooklyn.test.framework.TestHttpCall
+        name: Test HTTP Call
     - id: org.apache.brooklyn.test.framework.LoopOverGroupMembersTestCase
       item:
         type: org.apache.brooklyn.test.framework.LoopOverGroupMembersTestCase
+        name: Loop Over Group Members Test Case

http://git-wip-us.apache.org/repos/asf/brooklyn-server/blob/98297ced/test-framework/src/main/resources/catalog.bom
----------------------------------------------------------------------
diff --git a/test-framework/src/main/resources/catalog.bom b/test-framework/src/main/resources/catalog.bom
index bf4d18d..9beeed0 100644
--- a/test-framework/src/main/resources/catalog.bom
+++ b/test-framework/src/main/resources/catalog.bom
@@ -22,27 +22,37 @@ brooklyn.catalog:
     - id: org.apache.brooklyn.test.framework.TestSshCommand
       item:
         type: org.apache.brooklyn.test.framework.TestSshCommand
+        name: Test SSH Command
     - id: org.apache.brooklyn.test.framework.SimpleShellCommandTest
       item:
         type: org.apache.brooklyn.test.framework.SimpleShellCommandTest
+        name: [DEPRECATED] Simple Shell Command Test
+        description:  [DEPRECATED] Instead use TestSshCommand
     - id: org.apache.brooklyn.test.framework.ParallelTestCase
       item:
         type: org.apache.brooklyn.test.framework.ParallelTestCase
+        name: Parallel Test Case
     - id: org.apache.brooklyn.test.framework.TestCase
       item:
         type: org.apache.brooklyn.test.framework.TestCase
+        name: Test Case
     - id: org.apache.brooklyn.test.framework.InfrastructureDeploymentTestCase
       item:
         type: org.apache.brooklyn.test.framework.InfrastructureDeploymentTestCase
+        name: Infrastructure Deployment Test Case
     - id: org.apache.brooklyn.test.framework.TestSensor
       item:
         type: org.apache.brooklyn.test.framework.TestSensor
+        name: Test Sensor
     - id: org.apache.brooklyn.test.framework.TestEffector
       item:
         type: org.apache.brooklyn.test.framework.TestEffector
+        name: Test Effector
     - id: org.apache.brooklyn.test.framework.TestHttpCall
       item:
         type: org.apache.brooklyn.test.framework.TestHttpCall
+        name: Test HTTP Call
     - id: org.apache.brooklyn.test.framework.LoopOverGroupMembersTestCase
       item:
         type: org.apache.brooklyn.test.framework.LoopOverGroupMembersTestCase
+        name: Loop Over Group Members Test Case