org.apache.uima.aae.controller
Class AggregateAnalysisEngineController_impl

java.lang.Object
  extended by org.apache.uima.resource.Resource_ImplBase
      extended by org.apache.uima.aae.controller.BaseAnalysisEngineController
          extended by org.apache.uima.aae.controller.AggregateAnalysisEngineController_impl
All Implemented Interfaces:
java.io.Serializable, AggregateAnalysisEngineController, AggregateAnalysisEngineController_implMBean, AnalysisEngineController, BaseAnalysisEngineControllerMBean, ControllerLifecycle, EventSubscriber, org.apache.uima.resource.Resource

public class AggregateAnalysisEngineController_impl
extends BaseAnalysisEngineController
implements AggregateAnalysisEngineController, AggregateAnalysisEngineController_implMBean

See Also:
Serialized Form

Nested Class Summary
 
Nested classes/interfaces inherited from class org.apache.uima.aae.controller.BaseAnalysisEngineController
BaseAnalysisEngineController.ServiceState
 
Field Summary
protected  java.util.List<AnalysisEngineController> childControllerList
           
protected  boolean initialized
           
 java.lang.Object parallelStepMux
           
 
Fields inherited from class org.apache.uima.aae.controller.BaseAnalysisEngineController
abortedCasesMap, aeDescriptor, allDelegatesAreRemote, awaitingCacheCallbackNotification, callbackMonitor, callbackReceived, clientEndpoint, cmOutstandingCASes, componentCasPoolSize, controllerListeners, currentState, deadClientDestinationMap, delegateKey, delegates, errorCount, errorHandlerChain, finalStepMux, idleTime, inputChannel, inputChannelList, inputChannelMap, jmxContext, latch, localCache, messageListeners, monitor, NO_RECOVERY, paramsMap, parentController, perCasStatistics, processPid, replyTime, resourceSpecifier, serviceErrorMap, serviceErrors, serviceInitialized, servicePerformance, statsMap, stopped, syncObject, transports, unregisteredDelegateList
 
Fields inherited from interface org.apache.uima.aae.controller.AnalysisEngineController
AEInstanceCount, CasPoolSize
 
Fields inherited from interface org.apache.uima.resource.Resource
PARAM_AGGREGATE_SOFA_MAPPINGS, PARAM_CONFIG_PARAM_SETTINGS, PARAM_PERFORMANCE_TUNING_SETTINGS, PARAM_RESOURCE_MANAGER, PARAM_UIMA_CONTEXT
 
Constructor Summary
AggregateAnalysisEngineController_impl(AnalysisEngineController aParentController, java.lang.String anEndpointName, java.lang.String aDescriptor, AsynchAECasManager aCasManager, InProcessCache anInProcessCache, java.util.Map aDestinationMap)
           
AggregateAnalysisEngineController_impl(AnalysisEngineController aParentController, java.lang.String anEndpointName, java.lang.String aDescriptor, AsynchAECasManager aCasManager, InProcessCache anInProcessCache, java.util.Map aDestinationMap, JmxManagement aJmxManagement)
           
AggregateAnalysisEngineController_impl(java.lang.String anEndpointName, java.lang.String aDescriptor, AsynchAECasManager aCasManager, InProcessCache anInProcessCache, java.util.Map aDestinationMap)
           
 
Method Summary
 void addMessageOrigin(java.lang.String aCasReferenceId, Endpoint anEndpoint)
           
 void changeCollocatedDelegateState(java.lang.String delegateKey, BaseAnalysisEngineController.ServiceState state)
           
 void cleanUp()
           
 void collectionProcessComplete(Endpoint anEndpoint)
           
 boolean continueOnError(java.lang.String aCasReferenceId, java.lang.String aDelegateKey, java.lang.Exception anException)
           
 boolean delayCasIfDelegateInTimedOutState(java.lang.String aCasReferenceId, java.lang.String aDelegateKey)
          Checks the state of a delegate to see if it is in TIMEOUT State.
 void disableDelegates(java.util.List aDelegateList)
           
protected  void disableDelegates(java.util.List aDelegateList, java.lang.String aCasReferenceId)
           
 void dispatchMetadataRequest(Endpoint anEndpoint)
           
 void dropCAS(java.lang.String aCasReferenceId, boolean dropCacheEntry)
           
 void dropFlow(java.lang.String aCasReferenceId, boolean abortFlow)
           
 void dumpState(java.lang.StringBuffer buffer, java.lang.String lbl1)
           
 void enableDelegates(java.util.List aDelegateList)
           
 void finalStep(org.apache.uima.flow.FinalStep aStep, java.lang.String aCasReferenceId)
           
 java.util.List getChildControllerList()
           
 ControllerLatch getControllerLatch()
           
 ServiceErrors getDelegateServiceErrors(java.lang.String aDelegateKey)
           
 PrimitiveServiceInfo getDelegateServiceInfo(java.lang.String aDelegateKey)
           
 ServicePerformance getDelegateServicePerformance(java.lang.String aDelegateKey)
           
 java.util.Map getDelegateStats()
           
 java.lang.String getDescriptor()
           
 java.util.Map getDestinations()
           
 java.lang.String getLastDelegateKeyFromFlow(java.lang.String anInputCasReferenceId)
           
 LocalCache getLocalCache()
           
 Endpoint getMessageOrigin(java.lang.String aCasReferenceId)
           
 Monitor getMonitor()
           
 java.lang.String getServiceEndpointName()
           
 ServiceErrors getServiceErrors(java.lang.String aDelegateKey)
           
 AggregateServiceInfo getServiceInfo()
           
 ServicePerformance getServicePerformance(java.lang.String aDelegateKey)
           
 void handleDelegateLifeCycleEvent(java.lang.String anEndpoint, int aDelegateCount)
           
 void handleInitializationError(java.lang.Exception ex)
           
 void incrementAnalysisTime(long anAnalysisTime)
          Accumulate analysis time for the aggregate
 void initialize()
           
 boolean isDelegateDisabled(java.lang.String aDelegateKey)
           
 boolean isDelegateKeyValid(java.lang.String aDelegateKey)
           
 boolean isPrimitive()
           
 Delegate lookupDelegate(java.lang.String aDelegateKey)
          Return Delegate object for a given delegate key.
 java.lang.String lookUpDelegateKey(java.lang.String anEndpointName)
           
 java.lang.String lookUpDelegateKey(java.lang.String anEndpointName, java.lang.String server)
          Returns a delegate key given an endpoint (queue) name and a server uri.
 Endpoint lookUpEndpoint(java.lang.String anAnalysisEngineKey, boolean clone)
           
 void mapEndpointsToKeys(java.util.concurrent.ConcurrentHashMap aDestinationMap)
           
 void mergeTypeSystem(java.lang.String aTypeSystem, java.lang.String fromDestination)
           
 void mergeTypeSystem(java.lang.String aTypeSystem, java.lang.String fromDestination, java.lang.String fromServer)
           
 void onInitialize()
          Force all collocated delegates to perform any post-initialization steps.
 void process(org.apache.uima.cas.CAS aCAS, java.lang.String aCasReferenceId)
          This is a process method that is executed for CASes not created by a Multiplier in this aggregate.
 void process(org.apache.uima.cas.CAS aCAS, java.lang.String anInputCasReferenceId, java.lang.String aNewCasReferenceId, java.lang.String newCASProducedBy)
          This routine is called to handle CASes produced by a CAS Multiplier.
 void processCollectionCompleteReplyFromDelegate(java.lang.String aDelegateKey, boolean sendReply)
           
 void registerChildController(AnalysisEngineController aChildController, java.lang.String aDelegateKey)
           
 boolean releaseParentCas(boolean casDropped, boolean clientIsCollocated, LocalCache.CasStateEntry parentCasStateEntry)
           
 void removeMessageOrigin(java.lang.String aCasReferenceId)
           
 boolean requestForMetaSentToRemotes()
           
 void retryLastCommand(int aCommand, Endpoint anEndpoint, java.lang.String aCasReferenceId)
           
 void retryMetadataRequest(Endpoint anEndpoint)
           
 void retryProcessCASRequest(java.lang.String aCasReferenceId, Endpoint anEndpoint, boolean addEndpointToCache)
           
 void saveStatsFromService(java.lang.String aServiceEndpointName, java.util.Map aServiceStats)
           
 void sendMetadata(Endpoint anEndpoint)
           
 void sendRequestForMetadataToRemoteDelegates()
           
 void setCasLoggingDirectory(java.lang.String key, java.lang.String directory)
           
 void setControllerBeanName(java.lang.String aBeanName)
           
 void setDescriptor(java.lang.String descriptor)
           
 void setFlowControllerDescriptor(java.lang.String aFlowControllerDescriptor)
           
 void setMonitor(Monitor monitor)
           
 void setRequestForMetaSentToRemotes()
           
 void setServiceEndpointName(java.lang.String anEndpointName)
           
 void stop()
          Stops input channel(s) and initiates a shutdown of all delegates ( if this is an aggregate ).
 void stopTimers()
           
 void takeAction(java.lang.String anAction, java.lang.String anEndpointName, ErrorContext anErrorContext)
           
 
Methods inherited from class org.apache.uima.aae.controller.BaseAnalysisEngineController
abortGeneratingCASes, addAbortedCasReferenceId, addControllerCallbackListener, addInputChannel, addServiceInfo, beginProcess, cacheClientEndpoint, changeState, clearStats, dropCAS, dropCasStatistics, dropStats, endProcess, exceedsThresholdWithinWindow, forceTimeoutOnPendingCases, getAnalysisTime, getBrokerURL, getCasManagerWrapper, getCasMultiplierController, getCasStatistics, getChildUimaContext, getClientEndpoint, getComponentName, getCpuTime, getDeadClientMap, getDeploymentDescriptor, getDeploymentMode, getErrorHandlerChain, getEventListener, getIdleTime, getIdleTimeBetweenProcessCalls, getIndex, getInProcessCache, getInputChannel, getInputChannel, getInputQueue, getJmxContext, getJMXDomain, getKey, getManagementInterface, getName, getOutputChannel, getParentController, getReplyInputChannel, getReplyTime, getResourceSpecifier, getServiceErrors, getServiceName, getServicePerformance, getState, getStats, getTime, getTotalNumberOfCASesDropped, getTotalNumberOfCASesProcessed, getTotalNumberOfCASesReceived, getTotalNumberOfErrors, getTotalTimeSpendDeSerializingCAS, getTotalTimeSpentSerializingCAS, getTotalTimeSpentWaitingForFreeCASInstance, getTransport, getTransport, getTransport, getUimaEEAdminContext, getUimaMessageListener, handleAction, handleError, incrementDeserializationTime, incrementErrorCounter, incrementSerializationTime, initializeVMTransport, isAwaitingCacheCallbackNotification, isCasMultiplier, isStopped, isTopLevelComponent, logStats, logStats, notifyListenersWithInitializationStatus, onCacheEmpty, plugInDefaultErrorHandlerChain, process, quiesceAndStop, registerServiceWithJMX, registerVmQueueWithJMX, registerWithAgent, releaseNextCas, removeControllerCallbackListener, resetErrorCounter, saveReplyTime, saveTime, sendMetadata, setCasManager, setDeployDescriptor, setErrorHandlerChain, setInputChannel, setJmxManagement, setOutputChannel, setStopped, setUimaEEAdminContext, stop, stopCasMultiplier, stopCasMultipliers, stopDelegateTimers, stopInputChannel, stopInputChannels, stopTransportLayer, terminate, terminate, toString
 
Methods inherited from class org.apache.uima.resource.Resource_ImplBase
destroy, getCasManager, getLogger, getMetaData, getResourceManager, getUimaContext, getUimaContextAdmin, initialize, setLogger, setMetaData
 
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
 
Methods inherited from interface org.apache.uima.aae.controller.AggregateAnalysisEngineController
getChildUimaContext, stopCasMultiplier
 
Methods inherited from interface org.apache.uima.aae.controller.AnalysisEngineController
addAbortedCasReferenceId, addInputChannel, addServiceInfo, beginProcess, cacheClientEndpoint, changeState, dropCAS, dropStats, endProcess, forceTimeoutOnPendingCases, getAnalysisTime, getCasManagerWrapper, getCasStatistics, getClientEndpoint, getComponentName, getCpuTime, getDeadClientMap, getErrorHandlerChain, getEventListener, getIdleTime, getIdleTimeBetweenProcessCalls, getIndex, getInProcessCache, getInputChannel, getInputChannel, getJmxContext, getJMXDomain, getKey, getManagementInterface, getName, getOutputChannel, getParentController, getReplyInputChannel, getReplyTime, getServiceErrors, getServicePerformance, getState, getStats, getTime, getTransport, getTransport, getUimaEEAdminContext, getUimaMessageListener, incrementDeserializationTime, incrementSerializationTime, initializeVMTransport, isAwaitingCacheCallbackNotification, isCasMultiplier, isStopped, isTopLevelComponent, notifyListenersWithInitializationStatus, process, quiesceAndStop, registerVmQueueWithJMX, releaseNextCas, saveReplyTime, saveTime, setCasManager, setDeployDescriptor, setInputChannel, setOutputChannel, setStopped, setUimaEEAdminContext
 
Methods inherited from interface org.apache.uima.aae.controller.ControllerLifecycle
addControllerCallbackListener, removeControllerCallbackListener, terminate
 
Methods inherited from interface org.apache.uima.aae.controller.BaseAnalysisEngineControllerMBean
getBrokerURL, getComponentName, getDeploymentDescriptor, getDeploymentMode, getIdleTime, getInputQueue, getServiceName, getTotalNumberOfCASesDropped, getTotalNumberOfCASesProcessed, getTotalNumberOfCASesReceived, getTotalNumberOfErrors, getTotalTimeSpendDeSerializingCAS, getTotalTimeSpentSerializingCAS, getTotalTimeSpentWaitingForFreeCASInstance
 

Field Detail

initialized

protected volatile boolean initialized

childControllerList

protected java.util.List<AnalysisEngineController> childControllerList

parallelStepMux

public final java.lang.Object parallelStepMux
Constructor Detail

AggregateAnalysisEngineController_impl

public AggregateAnalysisEngineController_impl(java.lang.String anEndpointName,
                                              java.lang.String aDescriptor,
                                              AsynchAECasManager aCasManager,
                                              InProcessCache anInProcessCache,
                                              java.util.Map aDestinationMap)
                                       throws java.lang.Exception
Parameters:
anEndpointName -
aDescriptor -
aCasManager -
anInProcessCache -
aDestinationMap -
Throws:
java.lang.Exception

AggregateAnalysisEngineController_impl

public AggregateAnalysisEngineController_impl(AnalysisEngineController aParentController,
                                              java.lang.String anEndpointName,
                                              java.lang.String aDescriptor,
                                              AsynchAECasManager aCasManager,
                                              InProcessCache anInProcessCache,
                                              java.util.Map aDestinationMap)
                                       throws java.lang.Exception
Parameters:
aParentController -
anEndpointName -
aDescriptor -
aCasManager -
anInProcessCache -
aDestinationMap -
Throws:
java.lang.Exception

AggregateAnalysisEngineController_impl

public AggregateAnalysisEngineController_impl(AnalysisEngineController aParentController,
                                              java.lang.String anEndpointName,
                                              java.lang.String aDescriptor,
                                              AsynchAECasManager aCasManager,
                                              InProcessCache anInProcessCache,
                                              java.util.Map aDestinationMap,
                                              JmxManagement aJmxManagement)
                                       throws java.lang.Exception
Throws:
java.lang.Exception
Method Detail

registerChildController

public void registerChildController(AnalysisEngineController aChildController,
                                    java.lang.String aDelegateKey)
                             throws java.lang.Exception
Specified by:
registerChildController in interface AggregateAnalysisEngineController
Throws:
java.lang.Exception

saveStatsFromService

public void saveStatsFromService(java.lang.String aServiceEndpointName,
                                 java.util.Map aServiceStats)
Specified by:
saveStatsFromService in interface AggregateAnalysisEngineController

addMessageOrigin

public void addMessageOrigin(java.lang.String aCasReferenceId,
                             Endpoint anEndpoint)
Specified by:
addMessageOrigin in interface AggregateAnalysisEngineController

isDelegateDisabled

public boolean isDelegateDisabled(java.lang.String aDelegateKey)
Specified by:
isDelegateDisabled in interface AggregateAnalysisEngineController

setServiceEndpointName

public void setServiceEndpointName(java.lang.String anEndpointName)
Parameters:
anEndpointName -

getServiceEndpointName

public java.lang.String getServiceEndpointName()
Specified by:
getServiceEndpointName in interface AnalysisEngineController

setControllerBeanName

public void setControllerBeanName(java.lang.String aBeanName)
Parameters:
aBeanName -

getMessageOrigin

public Endpoint getMessageOrigin(java.lang.String aCasReferenceId)
Specified by:
getMessageOrigin in interface AggregateAnalysisEngineController

removeMessageOrigin

public void removeMessageOrigin(java.lang.String aCasReferenceId)
Specified by:
removeMessageOrigin in interface AggregateAnalysisEngineController

dropCAS

public void dropCAS(java.lang.String aCasReferenceId,
                    boolean dropCacheEntry)
Specified by:
dropCAS in interface AnalysisEngineController
Overrides:
dropCAS in class BaseAnalysisEngineController

dropFlow

public void dropFlow(java.lang.String aCasReferenceId,
                     boolean abortFlow)
Specified by:
dropFlow in interface AggregateAnalysisEngineController

mapEndpointsToKeys

public void mapEndpointsToKeys(java.util.concurrent.ConcurrentHashMap aDestinationMap)
Specified by:
mapEndpointsToKeys in interface AggregateAnalysisEngineController

getDelegateStats

public java.util.Map getDelegateStats()
Specified by:
getDelegateStats in interface AggregateAnalysisEngineController

processCollectionCompleteReplyFromDelegate

public void processCollectionCompleteReplyFromDelegate(java.lang.String aDelegateKey,
                                                       boolean sendReply)
                                                throws AsynchAEException
Specified by:
processCollectionCompleteReplyFromDelegate in interface AggregateAnalysisEngineController
Throws:
AsynchAEException

setFlowControllerDescriptor

public void setFlowControllerDescriptor(java.lang.String aFlowControllerDescriptor)
Parameters:
aFlowControllerDescriptor -

takeAction

public void takeAction(java.lang.String anAction,
                       java.lang.String anEndpointName,
                       ErrorContext anErrorContext)
Specified by:
takeAction in interface AnalysisEngineController

collectionProcessComplete

public void collectionProcessComplete(Endpoint anEndpoint)
                               throws AsynchAEException
Specified by:
collectionProcessComplete in interface AnalysisEngineController
Throws:
AsynchAEException

getDescriptor

public java.lang.String getDescriptor()

setDescriptor

public void setDescriptor(java.lang.String descriptor)

isPrimitive

public boolean isPrimitive()
Specified by:
isPrimitive in interface AnalysisEngineController

getDestinations

public java.util.Map getDestinations()
Specified by:
getDestinations in interface AggregateAnalysisEngineController

enableDelegates

public void enableDelegates(java.util.List aDelegateList)
                     throws AsynchAEException
Specified by:
enableDelegates in interface AggregateAnalysisEngineController
Throws:
AsynchAEException

handleInitializationError

public void handleInitializationError(java.lang.Exception ex)

disableDelegates

public void disableDelegates(java.util.List aDelegateList)
                      throws AsynchAEException
Specified by:
disableDelegates in interface AggregateAnalysisEngineController
Throws:
AsynchAEException

disableDelegates

protected void disableDelegates(java.util.List aDelegateList,
                                java.lang.String aCasReferenceId)
                         throws AsynchAEException
Throws:
AsynchAEException

continueOnError

public boolean continueOnError(java.lang.String aCasReferenceId,
                               java.lang.String aDelegateKey,
                               java.lang.Exception anException)
                        throws AsynchAEException
Specified by:
continueOnError in interface AggregateAnalysisEngineController
Throws:
AsynchAEException

getLastDelegateKeyFromFlow

public java.lang.String getLastDelegateKeyFromFlow(java.lang.String anInputCasReferenceId)
Specified by:
getLastDelegateKeyFromFlow in interface AggregateAnalysisEngineController

process

public void process(org.apache.uima.cas.CAS aCAS,
                    java.lang.String anInputCasReferenceId,
                    java.lang.String aNewCasReferenceId,
                    java.lang.String newCASProducedBy)
This routine is called to handle CASes produced by a CAS Multiplier. A new CAS needs a flow object which is produced here from the Flow associated with the input CAS. Once the subflow is computed, it is cached for future use.

Specified by:
process in interface AnalysisEngineController
Overrides:
process in class BaseAnalysisEngineController
Parameters:
aCAS - - CAS to process
anInputCasReferenceId - - reference id of the input CAS
aNewCasReferenceId - - reference id of the CAS created by the CAS multiplier
newCASProducedBy - - name of the multiplier that created the CAS
Throws:
org.apache.uima.analysis_engine.AnalysisEngineProcessException
AsynchAEException

process

public void process(org.apache.uima.cas.CAS aCAS,
                    java.lang.String aCasReferenceId)
This is a process method that is executed for CASes not created by a Multiplier in this aggregate.

Specified by:
process in interface AnalysisEngineController
Overrides:
process in class BaseAnalysisEngineController

sendRequestForMetadataToRemoteDelegates

public void sendRequestForMetadataToRemoteDelegates()
                                             throws AsynchAEException
Specified by:
sendRequestForMetadataToRemoteDelegates in interface AggregateAnalysisEngineController
Throws:
AsynchAEException

finalStep

public void finalStep(org.apache.uima.flow.FinalStep aStep,
                      java.lang.String aCasReferenceId)
Specified by:
finalStep in interface AggregateAnalysisEngineController

releaseParentCas

public boolean releaseParentCas(boolean casDropped,
                                boolean clientIsCollocated,
                                LocalCache.CasStateEntry parentCasStateEntry)

delayCasIfDelegateInTimedOutState

public boolean delayCasIfDelegateInTimedOutState(java.lang.String aCasReferenceId,
                                                 java.lang.String aDelegateKey)
                                          throws AsynchAEException
Checks the state of a delegate to see if it is in TIMEOUT State. If it is, push the CAS id onto a list of CASes pending dispatch. The delegate is in a questionable state and the aggregate sends a ping message to check delegate's availability. If the delegate responds to the ping, all CASes in the pending dispatch list will be immediately dispatched.

Specified by:
delayCasIfDelegateInTimedOutState in interface AggregateAnalysisEngineController
Throws:
AsynchAEException

retryProcessCASRequest

public void retryProcessCASRequest(java.lang.String aCasReferenceId,
                                   Endpoint anEndpoint,
                                   boolean addEndpointToCache)
                            throws AsynchAEException
Specified by:
retryProcessCASRequest in interface AggregateAnalysisEngineController
Throws:
AsynchAEException

isDelegateKeyValid

public boolean isDelegateKeyValid(java.lang.String aDelegateKey)
Specified by:
isDelegateKeyValid in interface AggregateAnalysisEngineController

lookUpDelegateKey

public java.lang.String lookUpDelegateKey(java.lang.String anEndpointName)
Specified by:
lookUpDelegateKey in interface AggregateAnalysisEngineController

lookUpDelegateKey

public java.lang.String lookUpDelegateKey(java.lang.String anEndpointName,
                                          java.lang.String server)
Returns a delegate key given an endpoint (queue) name and a server uri. If a server is null, only the endpoint name will be used for matching.

Specified by:
lookUpDelegateKey in interface AggregateAnalysisEngineController

lookUpEndpoint

public Endpoint lookUpEndpoint(java.lang.String anAnalysisEngineKey,
                               boolean clone)
                        throws AsynchAEException
Specified by:
lookUpEndpoint in interface AggregateAnalysisEngineController
Throws:
AsynchAEException

getDelegateServiceInfo

public PrimitiveServiceInfo getDelegateServiceInfo(java.lang.String aDelegateKey)
Specified by:
getDelegateServiceInfo in interface AggregateAnalysisEngineController

getDelegateServicePerformance

public ServicePerformance getDelegateServicePerformance(java.lang.String aDelegateKey)
Specified by:
getDelegateServicePerformance in interface AggregateAnalysisEngineController

getDelegateServiceErrors

public ServiceErrors getDelegateServiceErrors(java.lang.String aDelegateKey)
Specified by:
getDelegateServiceErrors in interface AggregateAnalysisEngineController

mergeTypeSystem

public void mergeTypeSystem(java.lang.String aTypeSystem,
                            java.lang.String fromDestination)
                     throws AsynchAEException
Specified by:
mergeTypeSystem in interface AggregateAnalysisEngineController
Throws:
AsynchAEException

mergeTypeSystem

public void mergeTypeSystem(java.lang.String aTypeSystem,
                            java.lang.String fromDestination,
                            java.lang.String fromServer)
                     throws AsynchAEException
Specified by:
mergeTypeSystem in interface AggregateAnalysisEngineController
Throws:
AsynchAEException

initialize

public void initialize()
                throws AsynchAEException
Specified by:
initialize in interface AnalysisEngineController
Throws:
AsynchAEException

dispatchMetadataRequest

public void dispatchMetadataRequest(Endpoint anEndpoint)
                             throws AsynchAEException
Specified by:
dispatchMetadataRequest in interface AggregateAnalysisEngineController
Throws:
AsynchAEException

retryMetadataRequest

public void retryMetadataRequest(Endpoint anEndpoint)
                          throws AsynchAEException
Specified by:
retryMetadataRequest in interface AggregateAnalysisEngineController
Throws:
AsynchAEException

sendMetadata

public void sendMetadata(Endpoint anEndpoint)
Specified by:
sendMetadata in interface AnalysisEngineController

getControllerLatch

public ControllerLatch getControllerLatch()
Specified by:
getControllerLatch in interface AnalysisEngineController

getMonitor

public Monitor getMonitor()
Specified by:
getMonitor in interface AnalysisEngineController

setMonitor

public void setMonitor(Monitor monitor)

handleDelegateLifeCycleEvent

public void handleDelegateLifeCycleEvent(java.lang.String anEndpoint,
                                         int aDelegateCount)
Specified by:
handleDelegateLifeCycleEvent in interface AnalysisEngineController

retryLastCommand

public void retryLastCommand(int aCommand,
                             Endpoint anEndpoint,
                             java.lang.String aCasReferenceId)
Specified by:
retryLastCommand in interface AggregateAnalysisEngineController

getServiceErrors

public ServiceErrors getServiceErrors(java.lang.String aDelegateKey)

getServiceInfo

public AggregateServiceInfo getServiceInfo()
Specified by:
getServiceInfo in interface AggregateAnalysisEngineController
Specified by:
getServiceInfo in interface AnalysisEngineController

getServicePerformance

public ServicePerformance getServicePerformance(java.lang.String aDelegateKey)
Specified by:
getServicePerformance in interface AggregateAnalysisEngineController

incrementAnalysisTime

public void incrementAnalysisTime(long anAnalysisTime)
Accumulate analysis time for the aggregate

Parameters:
anAnalysisTime -

stopTimers

public void stopTimers()
Specified by:
stopTimers in interface AggregateAnalysisEngineController

requestForMetaSentToRemotes

public boolean requestForMetaSentToRemotes()
Specified by:
requestForMetaSentToRemotes in interface AggregateAnalysisEngineController

setRequestForMetaSentToRemotes

public void setRequestForMetaSentToRemotes()
Specified by:
setRequestForMetaSentToRemotes in interface AggregateAnalysisEngineController

cleanUp

public void cleanUp()
Overrides:
cleanUp in class BaseAnalysisEngineController

stop

public void stop()
Description copied from class: BaseAnalysisEngineController
Stops input channel(s) and initiates a shutdown of all delegates ( if this is an aggregate ). At the end sends an Exception to the client and closes an output channel.

Specified by:
stop in interface AnalysisEngineController
Overrides:
stop in class BaseAnalysisEngineController

getChildControllerList

public java.util.List getChildControllerList()
Specified by:
getChildControllerList in interface AggregateAnalysisEngineController

onInitialize

public void onInitialize()
Force all collocated delegates to perform any post-initialization steps.

Specified by:
onInitialize in interface AnalysisEngineController

changeCollocatedDelegateState

public void changeCollocatedDelegateState(java.lang.String delegateKey,
                                          BaseAnalysisEngineController.ServiceState state)
                                   throws java.lang.Exception
Specified by:
changeCollocatedDelegateState in interface AggregateAnalysisEngineController
Throws:
java.lang.Exception

dumpState

public void dumpState(java.lang.StringBuffer buffer,
                      java.lang.String lbl1)
Specified by:
dumpState in interface AnalysisEngineController
Specified by:
dumpState in class BaseAnalysisEngineController

getLocalCache

public LocalCache getLocalCache()
Specified by:
getLocalCache in interface AnalysisEngineController
Overrides:
getLocalCache in class BaseAnalysisEngineController

lookupDelegate

public Delegate lookupDelegate(java.lang.String aDelegateKey)
Return Delegate object for a given delegate key.

Specified by:
lookupDelegate in interface AggregateAnalysisEngineController

setCasLoggingDirectory

public void setCasLoggingDirectory(java.lang.String key,
                                   java.lang.String directory)
Specified by:
setCasLoggingDirectory in interface AggregateAnalysisEngineController


Copyright © 2011. All Rights Reserved.