Hi,
I tried deploying the services with the other example which uses the
flowcontrollerand the services starts but with these errors:
Deployment xml:
<deployment protocol="jms" provider="activemq">
<casPool numberOfCASes="20"/>
<service>
<inputQueue endpoint="CorefDetectorTaeFixedQueue"
brokerURL="tcp://localhost:61616" prefetch="0"/>
<topDescriptor>
<import
location="../../desc//flow_controller/CorefDetectorTAE_AdvancedFixedFlow1.xml"/>
</topDescriptor>
<analysisEngine async="true">
<scaleout numberOfInstances="1"/>
<delegates>
<remoteAnalysisEngine key="StemmerDescriptor">
<inputQueue endpoint="StemmerDescriptorQueue"
brokerURL="tcp://localhost:61616"/>
<serializer method="xmi"/>
<asyncAggregateErrorConfiguration>
<getMetadataErrors
maxRetries="0"
timeout="100000"
errorAction="disable"/>
<processCasErrors maxRetries="0" timeout="100000"
continueOnRetryFailure="false" thresholdCount="100"
thresholdWindow="1000" thresholdAction="disable"/>
</asyncAggregateErrorConfiguration>
</remoteAnalysisEngine>
<remoteAnalysisEngine key="StopwordsDescriptor" >
<inputQueue endpoint="StopwordsDescriptorQueue"
brokerURL="tcp://1localhost:61616"/>
<serializer method="xmi"/>
<asyncAggregateErrorConfiguration>
<getMetadataErrors
maxRetries="0"
timeout="100000"
errorAction="disable"/>
<processCasErrors maxRetries="0" timeout="100000"
continueOnRetryFailure="false" thresholdCount="100"
thresholdWindow="1000" thresholdAction="disable"/>
</asyncAggregateErrorConfiguration>
</remoteAnalysisEngine>
</delegates>
</analysisEngine>
</service>
</deployment>
Flow Controller contains flow:
<string>OpenNLPSentenceDetector</string>
<string>OpenNLPTokenizer</string>
<string>OpenNLPPOSTagger</string>
<string>StemmerDescriptor,StopwordsDescriptor</string>
<string>TreeBankChunkerDescriptor</string>
deployment output: /bin/deployAsyncService.sh
UIMA_AS/deploy/as/Deploy_CorefDetectorTAE_Fixed1.xml
Service:TreeBankChunkerDescriptor Initialized. Ready To Process Messages
>From Queue:inQ_TreeBankChunkerDescriptor_1.1
Service:OpenNLPSentenceDetector Initialized. Ready To Process Messages
From Queue:inQ_OpenNLPSentenceDetector_1.2
Service:OpenNLPTokenizer Initialized. Ready To Process Messages From
Queue:inQ_OpenNLPTokenizer_1.3
Service:OpenNLPPOSTagger Initialized. Ready To Process Messages From
Queue:inQ_OpenNLPPOSTagger_1.5
Could not refresh JMS Connection for destination
'temp-queue://ID:.....-56497-1373965746367-0:1:1' - silently retrying in
5 ms. Cause: java.io.InterruptedIOException
Could not refresh JMS Connection for destination
'temp-queue://ID:.....-56497-1373965746367-0:0:1' - silently retrying in
5 ms. Cause: java.io.InterruptedIOException
Could not stop service: tcp:///localhost:61616. Reason:
java.lang.InterruptedException
java.lang.InterruptedException
at
java.util.concurrent.locks.AbstractQueuedSynchronizer.tryAcquireSharedNanos(AbstractQueuedSynchronizer.java:1325)
at java.util.concurrent.CountDownLatch.await(CountDownLatch.java:282)
at
org.apache.activemq.transport.tcp.TcpTransport.doStop(TcpTransport.java:531)
at org.apache.activemq.util.ServiceSupport.stop(ServiceSupport.java:69)
at
org.apache.activemq.transport.tcp.TcpTransport.stop(TcpTransport.java:548)
at
org.apache.activemq.transport.InactivityMonitor.stop(InactivityMonitor.java:133)
at
org.apache.activemq.transport.TransportFilter.stop(TransportFilter.java:65)
at
org.apache.activemq.transport.WireFormatNegotiator.stop(WireFormatNegotiator.java:91)
at
org.apache.activemq.transport.TransportFilter.stop(TransportFilter.java:65)
at
org.apache.activemq.transport.TransportFilter.stop(TransportFilter.java:65)
at
org.apache.activemq.transport.ResponseCorrelator.stop(ResponseCorrelator.java:132)
at
org.apache.activemq.util.ServiceSupport.dispose(ServiceSupport.java:43)
at
org.apache.activemq.ActiveMQConnection.close(ActiveMQConnection.java:656)
at
org.springframework.jms.connection.ConnectionFactoryUtils.releaseConnection(ConnectionFactoryUtils.java:80)
at
org.springframework.jms.listener.AbstractJmsListeningContainer.refreshSharedConnection(AbstractJmsListeningContainer.java:385)
at
org.apache.uima.adapter.jms.activemq.UimaDefaultMessageListenerContainer.refreshConnectionUntilSuccessful(UimaDefaultMessageListenerContainer.java:149)
at
org.springframework.jms.listener.DefaultMessageListenerContainer.recoverAfterListenerSetupFailure(DefaultMessageListenerContainer.java:838)
at
org.apache.uima.adapter.jms.activemq.UimaDefaultMessageListenerContainer.recoverAfterListenerSetupFailure(UimaDefaultMessageListenerContainer.java:174)
at
org.springframework.jms.listener.DefaultMessageListenerContainer$AsyncMessageListenerInvoker.run(DefaultMessageListenerContainer.java:969)
at
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1145)
at
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:615)
at
org.apache.uima.aae.UimaAsThreadFactory$1.run(UimaAsThreadFactory.java:118)
at java.lang.Thread.run(Thread.java:722)
Could not stop service: tcp:///localhost:61616. Reason:
java.lang.InterruptedException
java.lang.InterruptedException
at
java.util.concurrent.locks.AbstractQueuedSynchronizer.tryAcquireSharedNanos(AbstractQueuedSynchronizer.java:1325)
at java.util.concurrent.CountDownLatch.await(CountDownLatch.java:282)
at
org.apache.activemq.transport.tcp.TcpTransport.doStop(TcpTransport.java:531)
at org.apache.activemq.util.ServiceSupport.stop(ServiceSupport.java:69)
at
org.apache.activemq.transport.tcp.TcpTransport.stop(TcpTransport.java:548)
at
org.apache.activemq.transport.InactivityMonitor.stop(InactivityMonitor.java:133)
at
org.apache.activemq.transport.TransportFilter.stop(TransportFilter.java:65)
at
org.apache.activemq.transport.WireFormatNegotiator.stop(WireFormatNegotiator.java:91)
at
org.apache.activemq.transport.TransportFilter.stop(TransportFilter.java:65)
at
org.apache.activemq.transport.TransportFilter.stop(TransportFilter.java:65)
at
org.apache.activemq.transport.ResponseCorrelator.stop(ResponseCorrelator.java:132)
at
org.apache.activemq.util.ServiceSupport.dispose(ServiceSupport.java:43)
at
org.apache.activemq.ActiveMQConnection.close(ActiveMQConnection.java:656)
at
org.springframework.jms.connection.ConnectionFactoryUtils.releaseConnection(ConnectionFactoryUtils.java:80)
at
org.springframework.jms.listener.AbstractJmsListeningContainer.refreshSharedConnection(AbstractJmsListeningContainer.java:385)
at
org.apache.uima.adapter.jms.activemq.UimaDefaultMessageListenerContainer.refreshConnectionUntilSuccessful(UimaDefaultMessageListenerContainer.java:149)
at
org.springframework.jms.listener.DefaultMessageListenerContainer.recoverAfterListenerSetupFailure(DefaultMessageListenerContainer.java:838)
at
org.apache.uima.adapter.jms.activemq.UimaDefaultMessageListenerContainer.recoverAfterListenerSetupFailure(UimaDefaultMessageListenerContainer.java:174)
at
org.springframework.jms.listener.DefaultMessageListenerContainer$AsyncMessageListenerInvoker.run(DefaultMessageListenerContainer.java:969)
at
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1145)
at
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:615)
at
org.apache.uima.aae.UimaAsThreadFactory$1.run(UimaAsThreadFactory.java:118)
at java.lang.Thread.run(Thread.java:722)
All scheduled consumers have been paused, probably due to tasks having
been rejected. Check your thread pool configuration! Manual recovery
necessary through a start() call.
All scheduled consumers have been paused, probably due to tasks having
been rejected. Check your thread pool configuration! Manual recovery
necessary through a start() call.
Service:Coref Detector TAE with Advanced Fixed Flow Controller
Initialized. Ready To Process Messages From Queue:CorefDetectorTaeFixedQueue
--
Thanks and Regards,
Reshu Agarwal
|