You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@uima.apache.org by sc...@apache.org on 2008/10/06 23:01:49 UTC

svn commit: r702261 [4/4] - in /incubator/uima/sandbox/trunk/uima-as/uima-as-distr/src: main/scripts/ test/java/org/apache/uima/as/dd/ test/resources/deploy/ test/resources/deploy/expected/ test/resources/descriptors/analysis_engine/ test/resources/des...

Added: incubator/uima/sandbox/trunk/uima-as/uima-as-distr/src/test/resources/deploy/expected/vmBkrBad.xml
URL: http://svn.apache.org/viewvc/incubator/uima/sandbox/trunk/uima-as/uima-as-distr/src/test/resources/deploy/expected/vmBkrBad.xml?rev=702261&view=auto
==============================================================================
--- incubator/uima/sandbox/trunk/uima-as/uima-as-distr/src/test/resources/deploy/expected/vmBkrBad.xml (added)
+++ incubator/uima/sandbox/trunk/uima-as/uima-as-distr/src/test/resources/deploy/expected/vmBkrBad.xml Mon Oct  6 14:01:48 2008
@@ -0,0 +1,475 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--================================================================================-->
+ <!-- Generated from                                                                 -->
+ <!-- file:/C:/a/Eclipse/apache/uima-as-distr/src/test/resources/deploy/vmBkrBad.xml -->
+ <!-- 6 October, 2008, 3:20:01 P.M.                                                  -->
+ <!--================================================================================-->
+ <!DOCTYPE beans
+  PUBLIC "-//Spring//DTD BEAN//EN" "http://www.springframework.org/dtd/spring-beans.dtd">
+<beans>
+
+   <!-- Factory for specific external queue broker:  -->
+   <!--            tcp://localhost:61616             -->
+   <bean id="qBroker_tcp_c__ss_localhost_c_61616"
+         class="org.apache.activemq.ActiveMQConnectionFactory">
+      <property name="brokerURL" value="tcp://localhost:61616"/>
+      <property name="prefetchPolicy" ref="prefetchPolicy"/>
+   </bean>
+
+   <!-- Creates an instance of the ResourceManager -->
+   <bean id="resourceManager" class="org.apache.uima.aae.UimaClassFactory"
+         factory-method="produceResourceManager"
+         singleton="true"/>
+
+   <!-- Creates an instance of the CasManager  -->
+   <bean id="casManager" class="org.apache.uima.aae.AsynchAECasManager_impl"
+         singleton="true">
+      <constructor-arg index="0" ref="resourceManager"/>
+
+     <!-- Defines how many CASes will be in the CAS pool -->
+     <property name="casPoolSize" value="5"/>
+
+     <!-- Initial heap size for CASes  -->
+     <property name="initialFsHeapSize" value="2000000"/>
+   </bean>
+
+   <!-- Creates a Shared Cache -->
+   <bean id="inProcessCache" class="org.apache.uima.aae.InProcessCache"/>
+
+   <!-- Create prefetch policy -->
+   <bean id="prefetchPolicy" class="org.apache.activemq.ActiveMQPrefetchPolicy">
+      <property name="queuePrefetch" value="0"/>
+   </bean>
+ 
+   <!--=================================-->
+   <!--    E r r o r   D e t a i l s    -->
+   <!--=================================-->
+   <bean id="errorConfig__TCnt_0_TWndw_0_Action_"
+         class="org.apache.uima.aae.error.Threshold"
+         singleton="true">
+      <property name="threshold" value="0"/>
+      <property name="window" value="0"/>
+      <property name="action" value=""/>
+   </bean>
+
+   <bean id="errorConfig__Action_" class="org.apache.uima.aae.error.Threshold"
+         singleton="true">
+      <property name="action" value=""/>
+   </bean>
+
+   <bean id="errorConfig__Rtry_0_Action_terminate"
+         class="org.apache.uima.aae.error.Threshold"
+         singleton="true">
+      <property name="maxRetries" value="0"/>
+      <property name="action" value="terminate"/>
+   </bean>
+
+   <bean id="errorConfig__Rtry_0_Continue_false_TCnt_0_TWndw_0_Action_"
+         class="org.apache.uima.aae.error.Threshold"
+         singleton="true">
+      <property name="maxRetries" value="0"/>
+      <property name="continueOnRetryFailure" value="false"/>
+      <property name="threshold" value="0"/>
+      <property name="window" value="0"/>
+      <property name="action" value=""/>
+   </bean>
+
+ 
+   <!--input queue for service-->
+   <bean id="top_level_input_queue_service_1"
+         class="org.apache.activemq.command.ActiveMQQueue">
+      <constructor-arg index="0" value="RoomNumberAnnotatorQueue"/>
+   </bean>
+   <!--=============================================-->
+   <!-- Async Aggregate: RoomNumberAnnotatorQueue_1 -->
+   <!--=============================================-->
+   <bean id="asAggr_ctlr_RoomNumberAnnotatorQueue_1"
+         class="org.apache.uima.aae.controller.AggregateAnalysisEngineController_impl"
+         init-method="initialize">
+      <constructor-arg index="0">
+         <null/>
+      </constructor-arg>
+      <constructor-arg index="1" value="RoomNumberAnnotatorQueue"/>
+      <constructor-arg index="2"
+                       value="file:/C:/a/Eclipse/apache/uima-as-distr/src/test/resources/descriptors/tutorial/ex4/MeetingDetectorTAE.xml"/>
+      <constructor-arg index="3" ref="casManager"/>
+      <constructor-arg index="4" ref="inProcessCache"/>
+      <constructor-arg index="5" ref="delegate_map_RoomNumberAnnotatorQueue_1"/>
+      <property name="outputChannel" ref="outChnl_RoomNumberAnnotatorQueue_1"/>
+      <property name="serviceEndpointName" value="top_level_input_queue_service_1"/>
+      <property name="controllerBeanName" value="asAggr_ctlr_RoomNumberAnnotatorQueue_1"/>
+      <property name="errorHandlerChain" ref="err_hdlr_chn_RoomNumberAnnotatorQueue_1"/>
+      <property name="flowControllerDescriptor"
+                value="*importByName:org.apache.uima.flow.FixedFlowController"/>
+   </bean>
+ 
+   <!--=========================================================-->
+   <!--   M E S S A G E    H A N D L E R: aggregate_input       -->
+   <!--  for controller: asAggr_ctlr_RoomNumberAnnotatorQueue_1 -->
+   <!--=========================================================-->
+   
+   <bean id="aggregate_input_metaMsgHandler_RoomNumberAnnotatorQueue_1"
+         class="org.apache.uima.aae.handler.input.MetadataRequestHandler_impl">
+      <constructor-arg index="0" value="MetadataRequestHandler"/>
+      <property name="controller" ref="asAggr_ctlr_RoomNumberAnnotatorQueue_1"/>
+      <property name="delegate"
+                ref="aggregate_input_processRequestHandler_RoomNumberAnnotatorQueue_1"/>
+   </bean>
+
+   <bean id="aggregate_input_processRequestHandler_RoomNumberAnnotatorQueue_1"
+         class="org.apache.uima.aae.handler.input.ProcessRequestHandler_impl">
+      <constructor-arg index="0" value="ProcessRequestHandler"/>
+      <property name="controller" ref="asAggr_ctlr_RoomNumberAnnotatorQueue_1"/>
+   </bean>
+ 
+   <!--=========================================================-->
+   <!--   M E S S A G E    H A N D L E R: aggregate_return      -->
+   <!--  for controller: asAggr_ctlr_RoomNumberAnnotatorQueue_1 -->
+   <!--=========================================================-->
+   
+    
+
+<bean id="aggregate_return_processResponseHandler_RoomNumberAnnotatorQueue_1"
+         class="org.apache.uima.aae.handler.input.ProcessResponseHandler">
+      <constructor-arg index="0" value="ProcessResponseHandler"/>
+      <property name="controller" ref="asAggr_ctlr_RoomNumberAnnotatorQueue_1"/>
+      <property name="delegate"
+                ref="aggregate_return_response_metaMsgHandler_RoomNumberAnnotatorQueue_1"/>
+   </bean>
+
+   <bean id="aggregate_return_response_metaMsgHandler_RoomNumberAnnotatorQueue_1"
+         class="org.apache.uima.aae.handler.input.MetadataResponseHandler_impl">
+      <constructor-arg index="0" value="MetadataResponseHandler"/>
+      <property name="controller" ref="asAggr_ctlr_RoomNumberAnnotatorQueue_1"/>
+      <property name="delegate"
+                ref="aggregate_return_processRequestHandler_RoomNumberAnnotatorQueue_1"/>
+   </bean>
+
+   <bean id="aggregate_return_processRequestHandler_RoomNumberAnnotatorQueue_1"
+         class="org.apache.uima.aae.handler.input.ProcessRequestHandler_impl">
+      <constructor-arg index="0" value="ProcessRequestHandler"/>
+      <property name="controller" ref="asAggr_ctlr_RoomNumberAnnotatorQueue_1"/>
+   </bean>
+
+   <!-- Create the endpoints + output channels, one per delegate -->
+   
+
+   <!-- ==================================== -->
+   <!--              RoomNumber              -->
+   <!--        ** Delegate Endpoint **       -->
+   <!-- ==================================== -->
+   <bean id="endpt_RoomNumber_1.1" class="org.apache.uima.aae.controller.Endpoint_impl">
+
+     <!--     Broker URI     -->
+     <property name="serverURI" value="vm://localhost"/>
+
+     <!-- Delegate key name or remote queue name -->
+     <property name="endpoint" value="inQ_RoomNumber_1.1"/>
+
+     <!--      Timeouts      -->
+     <property name="metadataRequestTimeout" value="60000"/>
+      <property name="processRequestTimeout" value="0"/>
+      <property name="collectionProcessCompleteTimeout" value="0"/>
+      <property name="concurrentRequestConsumers" value="1"/>
+      <property name="concurrentReplyConsumers" value="1"/>
+   </bean>
+
+   <!-- ==================================== -->
+   <!--               DateTime               -->
+   <!--        ** Delegate Endpoint **       -->
+   <!-- ==================================== -->
+   <bean id="endpt_DateTime_1.2" class="org.apache.uima.aae.controller.Endpoint_impl">
+
+     <!--     Broker URI     -->
+     <property name="serverURI" value=""/>
+
+     <!-- Delegate key name or remote queue name -->
+     <property name="endpoint" value=""/>
+
+     <!-- Queue name used for replies, on the remote broker  -->
+     <property name="replyToEndpoint"
+                value="rmtRtrnQ_RoomNumberAnnotatorQueue_1_DateTime_9.2.34.805b199f85:11cd396016e:-7ffe"/>
+
+     <!--      Timeouts      -->
+     <property name="metadataRequestTimeout" value="60000"/>
+      <property name="processRequestTimeout" value="0"/>
+      <property name="collectionProcessCompleteTimeout" value="0"/>
+      <property name="serializer" value=""/>
+      <property name="tempReplyDestination" value="true"/>
+   </bean>
+
+   <!-- ==================================== -->
+   <!--               Meeting                -->
+   <!--        ** Delegate Endpoint **       -->
+   <!-- ==================================== -->
+   <bean id="endpt_Meeting_1.3" class="org.apache.uima.aae.controller.Endpoint_impl">
+
+     <!--     Broker URI     -->
+     <property name="serverURI" value="vm://localhost"/>
+
+     <!-- Delegate key name or remote queue name -->
+     <property name="endpoint" value="inQ_Meeting_1.3"/>
+
+     <!--      Timeouts      -->
+     <property name="metadataRequestTimeout" value="60000"/>
+      <property name="processRequestTimeout" value="0"/>
+      <property name="collectionProcessCompleteTimeout" value="0"/>
+      <property name="concurrentRequestConsumers" value="1"/>
+      <property name="concurrentReplyConsumers" value="1"/>
+   </bean>
+
+   <!--~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~ -->
+   <!-- JMS msg listener for input queue for:  -->
+   <!--    top_level_input_queue_service_1     -->
+   <!--~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~ -->
+   <bean id="asAggr_input_q_listenerID_RoomNumberAnnotatorQueue_1"
+         class="org.apache.uima.adapter.jms.activemq.JmsInputChannel">
+      <property name="messageHandler"
+                ref="aggregate_input_metaMsgHandler_RoomNumberAnnotatorQueue_1"/>
+      <property name="endpointName" value="top_level_input_queue_service_1"/>
+      <property name="controller" ref="asAggr_ctlr_RoomNumberAnnotatorQueue_1"/>
+      <property name="listenerContainer"
+                ref="asAggr_input_msgLsnrCntnr_RoomNumberAnnotatorQueue_1"/>
+   </bean>
+
+   <!--~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~ -->
+   <!-- JMS msg listener container for input queue for:  -->
+   <!--         top_level_input_queue_service_1          -->
+   <!--~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~ -->
+   <bean id="asAggr_input_msgLsnrCntnr_RoomNumberAnnotatorQueue_1"
+         class="org.apache.uima.adapter.jms.activemq.UimaDefaultMessageListenerContainer">
+
+     <!-- Define number of JMS Consumers -->
+     <property name="concurrentConsumers" value="1"/>
+
+     <!--    input Queue     -->
+     <property name="destination" ref="top_level_input_queue_service_1"/>
+
+     <!-- POJO to delegate JMS Messages to -->
+     <property name="messageListener"
+                ref="asAggr_input_q_listenerID_RoomNumberAnnotatorQueue_1"/>
+      <property name="connectionFactory" ref="qBroker_tcp_c__ss_localhost_c_61616"/>
+      <property name="messageSelector" value="Command=2000 OR Command=2002"/>
+   </bean>
+
+   <!--~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~ -->
+   <!-- GetMeta JMS msg listener container for input queue for:  -->
+   <!--             top_level_input_queue_service_1              -->
+   <!--~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~ -->
+   <bean id="asAggr_input_msgLsnrCntnr_RoomNumberAnnotatorQueue_1_getMeta"
+         class="org.apache.uima.adapter.jms.activemq.UimaDefaultMessageListenerContainer">
+
+     <!-- Define number of JMS Consumers -->
+     <property name="concurrentConsumers" value="1"/>
+
+     <!--    input Queue     -->
+     <property name="destination" ref="top_level_input_queue_service_1"/>
+
+     <!-- POJO to delegate JMS Messages to -->
+     <property name="messageListener"
+                ref="asAggr_input_q_listenerID_RoomNumberAnnotatorQueue_1"/>
+      <property name="connectionFactory" ref="qBroker_tcp_c__ss_localhost_c_61616"/>
+      <property name="messageSelector" value="Command=2001"/>
+   </bean>
+
+   <!-- return queue for http or tcp remote service  -->
+   <!--               on remote broker               -->
+   <bean id="rmtRtrnQ_RoomNumberAnnotatorQueue_1_DateTime"
+         class="org.apache.activemq.command.ActiveMQQueue">
+      <constructor-arg index="0"
+                       value="rmtRtrnQ_RoomNumberAnnotatorQueue_1_DateTime_9.2.34.805b199f85:11cd396016e:-7ffe"/>
+   </bean>
+
+   <!--~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~-->
+   <!--    JMS msg listener for return queue for:    -->
+   <!-- rmtRtrnQ_RoomNumberAnnotatorQueue_1_DateTime -->
+   <!--~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~-->
+   <bean id="asAggr_return_q_listenerID_RoomNumberAnnotatorQueue_1_DateTime"
+         class="org.apache.uima.adapter.jms.activemq.JmsInputChannel">
+      <property name="messageHandler"
+                ref="aggregate_return_processResponseHandler_RoomNumberAnnotatorQueue_1"/>
+      <property name="endpointName" value=""/>
+      <property name="controller" ref="asAggr_ctlr_RoomNumberAnnotatorQueue_1"/>
+   </bean>
+
+   <!--~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~-->
+   <!-- JMS msg listener container for return queue for: -->
+   <!--   rmtRtrnQ_RoomNumberAnnotatorQueue_1_DateTime   -->
+   <!--~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~-->
+   <bean id="asAggr_return_msgLsnrCntnr_RoomNumberAnnotatorQueue_1_DateTime"
+         class="org.apache.uima.adapter.jms.activemq.UimaDefaultMessageListenerContainer">
+
+     <!-- Define number of JMS Consumers -->
+     <property name="concurrentConsumers" value="31"/>
+
+     <!--    return Queue    -->
+     <property name="destinationResolver"
+                ref="destinationResolver_RoomNumberAnnotatorQueue_1_DateTime"/>
+      <property name="destinationName" value=""/>
+      <property name="targetEndpoint" ref="endpt_DateTime_1.2"/>
+
+     <!-- POJO to delegate JMS Messages to -->
+     <property name="messageListener"
+                ref="asAggr_return_q_listenerID_RoomNumberAnnotatorQueue_1_DateTime"/>
+      <property name="connectionFactory" ref="qBroker_"/>
+   </bean>
+
+   <!--~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~-->
+   <!--      Destination Resolver for DateTime       -->
+   <!-- rmtRtrnQ_RoomNumberAnnotatorQueue_1_DateTime -->
+   <!--~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~-->
+   <bean id="destinationResolver_RoomNumberAnnotatorQueue_1_DateTime"
+         class="org.apache.uima.adapter.jms.activemq.TempDestinationResolver"
+         singleton="false">
+      <property name="connectionFactory" ref="qBroker_"/>
+   </bean>
+
+   <!-- ================================== -->
+   <!-- OutputChannel - for flows out of   -->
+   <!-- this component, both to delegates  -->
+   <!--  (if aggr) and back up to sender   -->
+   <!-- ================================== -->
+   <bean id="outChnl_RoomNumberAnnotatorQueue_1"
+         class="org.apache.uima.adapter.jms.activemq.JmsOutputChannel"
+         init-method="initialize">
+      <property name="serviceInputEndpoint" value="RoomNumberAnnotatorQueue"/>
+      <property name="controller" ref="asAggr_ctlr_RoomNumberAnnotatorQueue_1"/>
+      <property name="controllerInputEndpoint" value="asynAggr_retQ_RoomNumberAnnotatorQueue_1"/>
+   </bean>
+
+   <!-- map for delegate keys  -->
+   <bean id="delegate_map_RoomNumberAnnotatorQueue_1" class="java.util.HashMap"
+         singleton="true">
+      <constructor-arg>
+         <map>
+            <entry key="RoomNumber">
+               <ref bean="endpt_RoomNumber_1.1"/>
+            </entry>
+            <entry key="DateTime">
+               <ref bean="endpt_DateTime_1.2"/>
+            </entry>
+            <entry key="Meeting">
+               <ref bean="endpt_Meeting_1.3"/>
+            </entry>
+         </map>
+      </constructor-arg>
+   </bean>
+
+ 
+   <!--========================-->
+   <!-- Delegate ErrorHandlers -->
+   <!--========================-->
+   <bean id="err_hndlr_getMetadataEr_1"
+         class="org.apache.uima.aae.error.handler.GetMetaErrorHandler">
+      <constructor-arg>
+         <map>
+            <entry key="RoomNumber">
+               <ref bean="errorConfig__Rtry_0_Action_terminate"/>
+            </entry>
+            <entry key="DateTime">
+               <ref bean="errorConfig__Rtry_0_Action_terminate"/>
+            </entry>
+            <entry key="Meeting">
+               <ref bean="errorConfig__Rtry_0_Action_terminate"/>
+            </entry>
+         </map>
+      </constructor-arg>
+   </bean>
+
+   <bean id="err_hndlr_processCasEr_1"
+         class="org.apache.uima.aae.error.handler.ProcessCasErrorHandler">
+      <constructor-arg>
+         <map>
+            <entry key="RoomNumber">
+               <ref bean="errorConfig__Rtry_0_Continue_false_TCnt_0_TWndw_0_Action_"/>
+            </entry>
+            <entry key="DateTime">
+               <ref bean="errorConfig__Rtry_0_Continue_false_TCnt_0_TWndw_0_Action_"/>
+            </entry>
+            <entry key="Meeting">
+               <ref bean="errorConfig__Rtry_0_Continue_false_TCnt_0_TWndw_0_Action_"/>
+            </entry>
+            <entry key="">
+               <ref bean="errorConfig__TCnt_0_TWndw_0_Action_"/>
+            </entry>
+         </map>
+      </constructor-arg>
+   </bean>
+
+   <bean id="err_hndlr_collectionProcessCompleteEr_1"
+         class="org.apache.uima.aae.error.handler.CpcErrorHandler">
+      <constructor-arg>
+         <map>
+            <entry key="RoomNumber">
+               <ref bean="errorConfig__Action_"/>
+            </entry>
+            <entry key="DateTime">
+               <ref bean="errorConfig__Action_"/>
+            </entry>
+            <entry key="Meeting">
+               <ref bean="errorConfig__Action_"/>
+            </entry>
+            <entry key="">
+               <ref bean="errorConfig__Action_"/>
+            </entry>
+         </map>
+      </constructor-arg>
+   </bean>
+
+ 
+   <!--=======================-->
+   <!--  Error Handler Chain  -->
+   <!--=======================-->
+   <bean id="err_hdlr_chn_RoomNumberAnnotatorQueue_1"
+         class="org.apache.uima.aae.error.ErrorHandlerChain">
+      <constructor-arg>
+         <list>
+            <ref local="err_hndlr_getMetadataEr_1"/>
+            <ref local="err_hndlr_processCasEr_1"/>
+            <ref local="err_hndlr_collectionProcessCompleteEr_1"/>
+         </list>
+      </constructor-arg>
+   </bean>
+   <!--=========================================-->
+   <!-- Primitive or non-Async Aggr: RoomNumber -->
+   <!--=========================================-->
+   <bean id="primitive_ctlr_RoomNumber_1.1"
+         class="org.apache.uima.aae.controller.PrimitiveAnalysisEngineController_impl"
+         init-method="initialize">
+      <constructor-arg index="0" ref="asAggr_ctlr_RoomNumberAnnotatorQueue_1"/>
+
+     <!--      Key name      -->
+     <constructor-arg index="1" value="RoomNumber"/>
+      <constructor-arg index="2"
+                       value="file:/C:/a/Eclipse/apache/uima-as-distr/src/test/resources/descriptors/tutorial/ex4/../ex2/RoomNumberAnnotator.xml"/>
+      <constructor-arg index="3" ref="casManager"/>
+      <constructor-arg index="4" ref="inProcessCache"/>
+
+     <!-- this parameter is ignored  -->
+     <constructor-arg index="5" value="10"/>
+
+     <!-- scaleout number of instances -->
+     <constructor-arg index="6" value="1"/>
+   </bean>
+   <!--======================================-->
+   <!-- Primitive or non-Async Aggr: Meeting -->
+   <!--======================================-->
+   <bean id="primitive_ctlr_Meeting_1.3"
+         class="org.apache.uima.aae.controller.PrimitiveAnalysisEngineController_impl"
+         init-method="initialize">
+      <constructor-arg index="0" ref="asAggr_ctlr_RoomNumberAnnotatorQueue_1"/>
+
+     <!--      Key name      -->
+     <constructor-arg index="1" value="Meeting"/>
+      <constructor-arg index="2"
+                       value="file:/C:/a/Eclipse/apache/uima-as-distr/src/test/resources/descriptors/tutorial/ex4/MeetingAnnotator.xml"/>
+      <constructor-arg index="3" ref="casManager"/>
+      <constructor-arg index="4" ref="inProcessCache"/>
+
+     <!-- this parameter is ignored  -->
+     <constructor-arg index="5" value="10"/>
+
+     <!-- scaleout number of instances -->
+     <constructor-arg index="6" value="1"/>
+   </bean>
+</beans>
\ No newline at end of file

Added: incubator/uima/sandbox/trunk/uima-as/uima-as-distr/src/test/resources/deploy/vmBkrBad.xml
URL: http://svn.apache.org/viewvc/incubator/uima/sandbox/trunk/uima-as/uima-as-distr/src/test/resources/deploy/vmBkrBad.xml?rev=702261&view=auto
==============================================================================
--- incubator/uima/sandbox/trunk/uima-as/uima-as-distr/src/test/resources/deploy/vmBkrBad.xml (added)
+++ incubator/uima/sandbox/trunk/uima-as/uima-as-distr/src/test/resources/deploy/vmBkrBad.xml Mon Oct  6 14:01:48 2008
@@ -0,0 +1,45 @@
+<?xml version="1.0" encoding="UTF-8"?>
+   <!--
+    ***************************************************************
+    * Licensed to the Apache Software Foundation (ASF) under one
+    * or more contributor license agreements.  See the NOTICE file
+    * distributed with this work for additional information
+    * regarding copyright ownership.  The ASF licenses this file
+    * to you under the Apache License, Version 2.0 (the
+    * "License"); you may not use this file except in compliance
+    * with the License.  You may obtain a copy of the License at
+    *
+    *   http://www.apache.org/licenses/LICENSE-2.0
+    * 
+    * Unless required by applicable law or agreed to in writing,
+    * software distributed under the License is distributed on an
+    * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    * KIND, either express or implied.  See the License for the
+    * specific language governing permissions and limitations
+    * under the License.
+    ***************************************************************
+   -->
+<analysisEngineDeploymentDescription
+  xmlns="http://uima.apache.org/resourceSpecifier">
+  <name>Meeting Detector TAE</name>
+  <deployment protocol="jms" provider="activemq">
+    <casPool numberOfCASes="5"/>
+    
+      <service>
+        <inputQueue endpoint="RoomNumberAnnotatorQueue"
+          brokerURL="tcp://localhost:61616"/>
+        <topDescriptor>
+          <import
+            location="../descriptors/tutorial/ex4/MeetingDetectorTAE.xml"/>
+        </topDescriptor>
+        <analysisEngine async="true">
+        <delegates>
+          <remoteAnalysisEngine key="DateTime" remoteReplyQueueScaleout="31">
+            <inputQueue endpoint="iq1" brokerURL="vm://some.remote:12345"/>
+          </remoteAnalysisEngine>
+        </delegates>
+          </analysisEngine>
+      </service>
+
+  </deployment>
+</analysisEngineDeploymentDescription>
\ No newline at end of file

Added: incubator/uima/sandbox/trunk/uima-as/uima-as-distr/src/test/resources/descriptors/analysis_engine/SimpleTestAggregate.xml
URL: http://svn.apache.org/viewvc/incubator/uima/sandbox/trunk/uima-as/uima-as-distr/src/test/resources/descriptors/analysis_engine/SimpleTestAggregate.xml?rev=702261&view=auto
==============================================================================
--- incubator/uima/sandbox/trunk/uima-as/uima-as-distr/src/test/resources/descriptors/analysis_engine/SimpleTestAggregate.xml (added)
+++ incubator/uima/sandbox/trunk/uima-as/uima-as-distr/src/test/resources/descriptors/analysis_engine/SimpleTestAggregate.xml Mon Oct  6 14:01:48 2008
@@ -0,0 +1,67 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+	<!--
+	 ***************************************************************
+	 * Licensed to the Apache Software Foundation (ASF) under one
+	 * or more contributor license agreements.  See the NOTICE file
+	 * distributed with this work for additional information
+	 * regarding copyright ownership.  The ASF licenses this file
+	 * to you under the Apache License, Version 2.0 (the
+	 * "License"); you may not use this file except in compliance
+	 * with the License.  You may obtain a copy of the License at
+         *
+	 *   http://www.apache.org/licenses/LICENSE-2.0
+	 * 
+	 * Unless required by applicable law or agreed to in writing,
+	 * software distributed under the License is distributed on an
+	 * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+	 * KIND, either express or implied.  See the License for the
+	 * specific language governing permissions and limitations
+	 * under the License.
+	 ***************************************************************
+   -->
+   
+<analysisEngineDescription xmlns="http://uima.apache.org/resourceSpecifier">
+  <frameworkImplementation>org.apache.uima.java</frameworkImplementation>
+  <primitive>false</primitive>
+  <delegateAnalysisEngineSpecifiers>
+    
+    <delegateAnalysisEngine key="TestMultiplier">
+      <import location="../multiplier/SimpleCasGenerator.xml"/>
+    </delegateAnalysisEngine>
+
+
+      <delegateAnalysisEngine key="NoOp">
+      <import location="NoOpAnnotator.xml"/>
+    </delegateAnalysisEngine>
+  
+  </delegateAnalysisEngineSpecifiers>
+  <analysisEngineMetaData>
+    <name>Test Aggregate TAE</name>
+    <description>Detects Nothing</description>
+    <configurationParameters/>
+    <configurationParameterSettings/>
+    <flowConstraints>
+      <fixedFlow>
+      
+        <node>TestMultiplier</node>
+        <node>NoOp</node> 
+      </fixedFlow>
+    </flowConstraints>
+    <capabilities>
+      <capability>
+        <inputs/>
+        <outputs>
+        </outputs>
+        <languagesSupported>
+          <language>en</language>
+        </languagesSupported>
+      </capability>
+    </capabilities>
+	<operationalProperties>
+		<modifiesCas>true</modifiesCas>
+		<multipleDeploymentAllowed>true</multipleDeploymentAllowed>
+		<outputsNewCASes>false</outputsNewCASes>
+	</operationalProperties>
+  </analysisEngineMetaData>
+</analysisEngineDescription>

Added: incubator/uima/sandbox/trunk/uima-as/uima-as-distr/src/test/resources/descriptors/multiplier/SimpleCasGenerator.xml
URL: http://svn.apache.org/viewvc/incubator/uima/sandbox/trunk/uima-as/uima-as-distr/src/test/resources/descriptors/multiplier/SimpleCasGenerator.xml?rev=702261&view=auto
==============================================================================
--- incubator/uima/sandbox/trunk/uima-as/uima-as-distr/src/test/resources/descriptors/multiplier/SimpleCasGenerator.xml (added)
+++ incubator/uima/sandbox/trunk/uima-as/uima-as-distr/src/test/resources/descriptors/multiplier/SimpleCasGenerator.xml Mon Oct  6 14:01:48 2008
@@ -0,0 +1,112 @@
+<?xml version="1.0" encoding="UTF-8"?>
+  <!--
+   ***************************************************************
+   * Licensed to the Apache Software Foundation (ASF) under one
+   * or more contributor license agreements.  See the NOTICE file
+   * distributed with this work for additional information
+   * regarding copyright ownership.  The ASF licenses this file
+   * to you under the Apache License, Version 2.0 (the
+   * "License"); you may not use this file except in compliance
+   * with the License.  You may obtain a copy of the License at
+         *
+   *   http://www.apache.org/licenses/LICENSE-2.0
+   * 
+   * Unless required by applicable law or agreed to in writing,
+   * software distributed under the License is distributed on an
+   * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+   * KIND, either express or implied.  See the License for the
+   * specific language governing permissions and limitations
+   * under the License.
+   ***************************************************************
+   -->
+<analysisEngineDescription xmlns="http://uima.apache.org/resourceSpecifier">
+  <frameworkImplementation>org.apache.uima.java</frameworkImplementation>
+  <primitive>true</primitive>
+  <annotatorImplementationName>org.apache.uima.ae.multiplier.SimpleCasGenerator</annotatorImplementationName>
+  <analysisEngineMetaData>
+    <name>Simple Text Segmenter</name>
+    <description>Generates specified number of CASes.</description>
+    <version>1.0</version>
+    <vendor>The Apache Software Foundation</vendor>
+    <configurationParameters>
+      <configurationParameter>
+        <name>NumberToGenerate</name>
+        <description>Approximate number of CASes to create.</description>
+        <type>Integer</type>
+        <multiValued>false</multiValued>
+        <mandatory>true</mandatory>
+      </configurationParameter>
+      
+      
+      <configurationParameter>
+        <name>StringOne</name>
+        <description>document text</description>
+        <type>String</type>
+        <multiValued>false</multiValued>
+        <mandatory>true</mandatory>
+      </configurationParameter>
+      <configurationParameter>
+        <name>StringTwo</name>
+        <description>document text</description>
+        <type>String</type>
+        <multiValued>false</multiValued>
+        <mandatory>true</mandatory>
+      </configurationParameter>
+    
+    
+      <configurationParameter>
+        <name>InputFile</name>
+        <description>document text</description>
+        <type>String</type>
+        <multiValued>false</multiValued>
+        <mandatory>true</mandatory>
+      </configurationParameter>
+    
+    
+    
+    
+    </configurationParameters>
+    <configurationParameterSettings>
+      <nameValuePair>
+        <name>NumberToGenerate</name>
+        <value>
+          <integer>1</integer>
+        </value>
+      </nameValuePair>
+      <nameValuePair>
+        <name>StringOne</name>
+        <value>
+          <string>Upcoming UIMA Seminars      April 7, 2004 Distillery Lunch Seminar   UIMA and its Metadata   12:00PM-1:00PM in HAW GN-K35.       Dave Ferrucci will give a UIMA overview and discuss the types of component metadata that UIMA components provide.  Jon Lenchner will give a demo of the Text Analysis Engine configurator tool.         April 16, 2004 KM &amp; I Department Tea    Title: An Eclipse-based TAE Configurator Tool   3:00PM-4:30PM in HAW GN-K35 .      Jon Lenchner will demo an Eclipse plugin for configuring TAE descriptors, which will be available soon for you to use.  No more editing XML descriptors by hand!         May 11, 2004 UIMA Tutorial    9:00AM-5:00PM in HAW GN-K35.      This is a full-day, hands-on tutorial on UIMA, covering the development of Text Analysis Engines and Collection Processing Engines, as well as how to include these components in your own applications.   </string>
+        </value>
+      </nameValuePair>
+      <nameValuePair>
+        <name>StringTwo</name>
+        <value>
+          <string>UIMA Summer School      August 26, 2003   UIMA 101 - The New UIMA Introduction    (Hands-on Tutorial)   9:00AM-5:00PM in HAW GN-K35      August 28, 2003   FROST Tutorial   9:00AM-5:00PM in HAW GN-K35      September 15, 2003   UIMA 201: UIMA Advanced Topics    (Hands-on Tutorial)   9:00AM-5:00PM in HAW 1S-F53      September 17, 2003   The UIMA System Integration Test and Hardening Service   The "SITH"   3:00PM-4:30PM in HAW GN-K35            UIMA Summer School Tutorial and Presentation Details   UIMA 101: The new UIMA tutorial     Tuesday August 26 9:00AM - 4:30PM in GN-K35      UIMA 101 is a hands-on programming tutorial.      UIMA 101 is intended for people who want a first introductory course to UIMA or for people who would like a refresher.      The tutorial covers the same concepts in the first UIMA tutorial given in 3Q 2002 except for some key updates:      1) It uses a new interface to the CAS that makes it more natural to access and update CAS featur
 e structures using ordinary Java objects (i.e., the JCAS) and   2) It uses updated TAE interfaces that give the application developer more control over managing multiple CASs.       Please NOTE expert users of UIMA can skip this one and should consider attending the Advanced Topics tutorial.      Prerequisites for the UIMA 101 Tutorial   1) Java Programming   2) Some experience with Eclipse IDE helpful      FROST Tutorial   August 28  9:00AM - 5:00PM  in GN-K35      Visitors from the FROST team will be here to talk to us about FROST.      UIMA 201: The UIMA Advanced Topics Tutorial   September 15:   9:00AM - 5:30PM in Hawthorne 1S-F53      UIMA 201 will introduce some new UIMA concepts and walk the student through hands-on examples.      The advanced topics tutorial is designed for people who have some experience with UIMA and want    to use new capabilities of UIMA 1.0 to address one or more of the following    Advanced Topics:      1) Collection Processing and Collection P
 rocessing Engines (CPEs)   2) Multi-Threading and CAS Pooling   3) Using the UIMA adapter framework to integrate network TAEs with Java TAEs   4) A Semantic Search Application that brings it all together	      Prerequisites for UIMA 201   1) UIMA 101 Tutorial OR Extensive UIMA Experience      The UIMA Integration Test bed Service (The "SITH")   September 17 3:00PM - 4:30PM in HAW GN-K35      We have developed the first version of the UIMA Integration Test bed service.      This service is being developed to help test, evaluate, certify and publish UIMA compliant components.      In this talk we will explain the service and what it is intended to provide the UIMA community. We will address the following topics:      1. SITH Services   2. How to submit components and what to expect in return   3. Overview of the test bed implementation using Collection Processing UIMA and Juru.    4. Next Steps for the SITH         </string>
+        </value>
+      </nameValuePair>
+    
+      <nameValuePair>
+        <name>InputFile</name>
+        <value>
+        <string>data/IBM_LifeSciences.xml</string>
+          <!-- <string>c:/new-nt.xml</string>  -->
+        </value>
+      </nameValuePair>
+    
+    </configurationParameterSettings>
+    <typeSystemDescription/>
+    <capabilities>
+      <capability>
+        <inputs/>
+        <outputs/>
+        <languagesSupported/>
+      </capability>
+    </capabilities>
+    <operationalProperties>
+      <modifiesCas>false</modifiesCas>
+      <multipleDeploymentAllowed>true</multipleDeploymentAllowed>
+      <outputsNewCASes>true</outputsNewCASes>
+    </operationalProperties>
+  </analysisEngineMetaData>
+</analysisEngineDescription>