public class AggregateAnalysisEngineController_impl extends BaseAnalysisEngineController implements AggregateAnalysisEngineController, AggregateAnalysisEngineController_implMBean
BaseAnalysisEngineController.ServiceState
Modifier and Type | Field and Description |
---|---|
protected java.util.List<AnalysisEngineController> |
childControllerList |
protected boolean |
initialized |
java.lang.Object |
parallelStepMux |
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
AEInstanceCount, CasPoolSize
Constructor and Description |
---|
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) |
Modifier and Type | Method and Description |
---|---|
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) |
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
destroy, getCasManager, getLogger, getMetaData, getResourceManager, getUimaContext, getUimaContextAdmin, initialize, setLogger, setMetaData
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
getChildUimaContext, stopCasMultiplier
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
addControllerCallbackListener, removeControllerCallbackListener, terminate
getBrokerURL, getComponentName, getDeploymentDescriptor, getDeploymentMode, getIdleTime, getInputQueue, getServiceName, getTotalNumberOfCASesDropped, getTotalNumberOfCASesProcessed, getTotalNumberOfCASesReceived, getTotalNumberOfErrors, getTotalTimeSpendDeSerializingCAS, getTotalTimeSpentSerializingCAS, getTotalTimeSpentWaitingForFreeCASInstance
protected volatile boolean initialized
protected java.util.List<AnalysisEngineController> childControllerList
public final java.lang.Object parallelStepMux
public AggregateAnalysisEngineController_impl(java.lang.String anEndpointName, java.lang.String aDescriptor, AsynchAECasManager aCasManager, InProcessCache anInProcessCache, java.util.Map aDestinationMap) throws java.lang.Exception
anEndpointName
- aDescriptor
- aCasManager
- anInProcessCache
- aDestinationMap
- java.lang.Exception
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
aParentController
- anEndpointName
- aDescriptor
- aCasManager
- anInProcessCache
- aDestinationMap
- java.lang.Exception
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
java.lang.Exception
public void registerChildController(AnalysisEngineController aChildController, java.lang.String aDelegateKey) throws java.lang.Exception
registerChildController
in interface AggregateAnalysisEngineController
java.lang.Exception
public void saveStatsFromService(java.lang.String aServiceEndpointName, java.util.Map aServiceStats)
saveStatsFromService
in interface AggregateAnalysisEngineController
public void addMessageOrigin(java.lang.String aCasReferenceId, Endpoint anEndpoint)
addMessageOrigin
in interface AggregateAnalysisEngineController
public boolean isDelegateDisabled(java.lang.String aDelegateKey)
isDelegateDisabled
in interface AggregateAnalysisEngineController
public void setServiceEndpointName(java.lang.String anEndpointName)
anEndpointName
- public java.lang.String getServiceEndpointName()
getServiceEndpointName
in interface AnalysisEngineController
public void setControllerBeanName(java.lang.String aBeanName)
aBeanName
- public Endpoint getMessageOrigin(java.lang.String aCasReferenceId)
getMessageOrigin
in interface AggregateAnalysisEngineController
public void removeMessageOrigin(java.lang.String aCasReferenceId)
removeMessageOrigin
in interface AggregateAnalysisEngineController
public void dropCAS(java.lang.String aCasReferenceId, boolean dropCacheEntry)
dropCAS
in interface AnalysisEngineController
dropCAS
in class BaseAnalysisEngineController
public void dropFlow(java.lang.String aCasReferenceId, boolean abortFlow)
dropFlow
in interface AggregateAnalysisEngineController
public void mapEndpointsToKeys(java.util.concurrent.ConcurrentHashMap aDestinationMap)
mapEndpointsToKeys
in interface AggregateAnalysisEngineController
public java.util.Map getDelegateStats()
getDelegateStats
in interface AggregateAnalysisEngineController
public void processCollectionCompleteReplyFromDelegate(java.lang.String aDelegateKey, boolean sendReply) throws AsynchAEException
processCollectionCompleteReplyFromDelegate
in interface AggregateAnalysisEngineController
AsynchAEException
public void setFlowControllerDescriptor(java.lang.String aFlowControllerDescriptor)
aFlowControllerDescriptor
- public void takeAction(java.lang.String anAction, java.lang.String anEndpointName, ErrorContext anErrorContext)
takeAction
in interface AnalysisEngineController
public void collectionProcessComplete(Endpoint anEndpoint) throws AsynchAEException
collectionProcessComplete
in interface AnalysisEngineController
AsynchAEException
public java.lang.String getDescriptor()
public void setDescriptor(java.lang.String descriptor)
public boolean isPrimitive()
isPrimitive
in interface AnalysisEngineController
public java.util.Map getDestinations()
getDestinations
in interface AggregateAnalysisEngineController
public void enableDelegates(java.util.List aDelegateList) throws AsynchAEException
enableDelegates
in interface AggregateAnalysisEngineController
AsynchAEException
public void handleInitializationError(java.lang.Exception ex)
public void disableDelegates(java.util.List aDelegateList) throws AsynchAEException
disableDelegates
in interface AggregateAnalysisEngineController
AsynchAEException
protected void disableDelegates(java.util.List aDelegateList, java.lang.String aCasReferenceId) throws AsynchAEException
AsynchAEException
public boolean continueOnError(java.lang.String aCasReferenceId, java.lang.String aDelegateKey, java.lang.Exception anException) throws AsynchAEException
continueOnError
in interface AggregateAnalysisEngineController
AsynchAEException
public java.lang.String getLastDelegateKeyFromFlow(java.lang.String anInputCasReferenceId)
getLastDelegateKeyFromFlow
in interface AggregateAnalysisEngineController
public void process(org.apache.uima.cas.CAS aCAS, java.lang.String anInputCasReferenceId, java.lang.String aNewCasReferenceId, java.lang.String newCASProducedBy)
process
in interface AnalysisEngineController
process
in class BaseAnalysisEngineController
aCAS
- - CAS to processanInputCasReferenceId
- - reference id of the input CASaNewCasReferenceId
- - reference id of the CAS created by the CAS multipliernewCASProducedBy
- - name of the multiplier that created the CASorg.apache.uima.analysis_engine.AnalysisEngineProcessException
AsynchAEException
public void process(org.apache.uima.cas.CAS aCAS, java.lang.String aCasReferenceId)
process
in interface AnalysisEngineController
process
in class BaseAnalysisEngineController
public void sendRequestForMetadataToRemoteDelegates() throws AsynchAEException
sendRequestForMetadataToRemoteDelegates
in interface AggregateAnalysisEngineController
AsynchAEException
public void finalStep(org.apache.uima.flow.FinalStep aStep, java.lang.String aCasReferenceId)
finalStep
in interface AggregateAnalysisEngineController
public boolean releaseParentCas(boolean casDropped, boolean clientIsCollocated, LocalCache.CasStateEntry parentCasStateEntry)
public boolean delayCasIfDelegateInTimedOutState(java.lang.String aCasReferenceId, java.lang.String aDelegateKey) throws AsynchAEException
delayCasIfDelegateInTimedOutState
in interface AggregateAnalysisEngineController
AsynchAEException
public void retryProcessCASRequest(java.lang.String aCasReferenceId, Endpoint anEndpoint, boolean addEndpointToCache) throws AsynchAEException
retryProcessCASRequest
in interface AggregateAnalysisEngineController
AsynchAEException
public boolean isDelegateKeyValid(java.lang.String aDelegateKey)
isDelegateKeyValid
in interface AggregateAnalysisEngineController
public java.lang.String lookUpDelegateKey(java.lang.String anEndpointName)
lookUpDelegateKey
in interface AggregateAnalysisEngineController
public java.lang.String lookUpDelegateKey(java.lang.String anEndpointName, java.lang.String server)
lookUpDelegateKey
in interface AggregateAnalysisEngineController
public Endpoint lookUpEndpoint(java.lang.String anAnalysisEngineKey, boolean clone) throws AsynchAEException
lookUpEndpoint
in interface AggregateAnalysisEngineController
AsynchAEException
public PrimitiveServiceInfo getDelegateServiceInfo(java.lang.String aDelegateKey)
getDelegateServiceInfo
in interface AggregateAnalysisEngineController
public ServicePerformance getDelegateServicePerformance(java.lang.String aDelegateKey)
getDelegateServicePerformance
in interface AggregateAnalysisEngineController
public ServiceErrors getDelegateServiceErrors(java.lang.String aDelegateKey)
getDelegateServiceErrors
in interface AggregateAnalysisEngineController
public void mergeTypeSystem(java.lang.String aTypeSystem, java.lang.String fromDestination) throws AsynchAEException
mergeTypeSystem
in interface AggregateAnalysisEngineController
AsynchAEException
public void mergeTypeSystem(java.lang.String aTypeSystem, java.lang.String fromDestination, java.lang.String fromServer) throws AsynchAEException
mergeTypeSystem
in interface AggregateAnalysisEngineController
AsynchAEException
public void initialize() throws AsynchAEException
initialize
in interface AnalysisEngineController
AsynchAEException
public void dispatchMetadataRequest(Endpoint anEndpoint) throws AsynchAEException
dispatchMetadataRequest
in interface AggregateAnalysisEngineController
AsynchAEException
public void retryMetadataRequest(Endpoint anEndpoint) throws AsynchAEException
retryMetadataRequest
in interface AggregateAnalysisEngineController
AsynchAEException
public void sendMetadata(Endpoint anEndpoint)
sendMetadata
in interface AnalysisEngineController
public ControllerLatch getControllerLatch()
getControllerLatch
in interface AnalysisEngineController
public Monitor getMonitor()
getMonitor
in interface AnalysisEngineController
public void setMonitor(Monitor monitor)
public void handleDelegateLifeCycleEvent(java.lang.String anEndpoint, int aDelegateCount)
handleDelegateLifeCycleEvent
in interface AnalysisEngineController
public void retryLastCommand(int aCommand, Endpoint anEndpoint, java.lang.String aCasReferenceId)
retryLastCommand
in interface AggregateAnalysisEngineController
public ServiceErrors getServiceErrors(java.lang.String aDelegateKey)
public AggregateServiceInfo getServiceInfo()
getServiceInfo
in interface AggregateAnalysisEngineController
getServiceInfo
in interface AnalysisEngineController
public ServicePerformance getServicePerformance(java.lang.String aDelegateKey)
getServicePerformance
in interface AggregateAnalysisEngineController
public void incrementAnalysisTime(long anAnalysisTime)
anAnalysisTime
- public void stopTimers()
stopTimers
in interface AggregateAnalysisEngineController
public boolean requestForMetaSentToRemotes()
requestForMetaSentToRemotes
in interface AggregateAnalysisEngineController
public void setRequestForMetaSentToRemotes()
setRequestForMetaSentToRemotes
in interface AggregateAnalysisEngineController
public void cleanUp()
cleanUp
in class BaseAnalysisEngineController
public void stop()
BaseAnalysisEngineController
stop
in interface AnalysisEngineController
stop
in class BaseAnalysisEngineController
public java.util.List getChildControllerList()
getChildControllerList
in interface AggregateAnalysisEngineController
public void onInitialize()
onInitialize
in interface AnalysisEngineController
public void changeCollocatedDelegateState(java.lang.String delegateKey, BaseAnalysisEngineController.ServiceState state) throws java.lang.Exception
changeCollocatedDelegateState
in interface AggregateAnalysisEngineController
java.lang.Exception
public void dumpState(java.lang.StringBuffer buffer, java.lang.String lbl1)
dumpState
in interface AnalysisEngineController
dumpState
in class BaseAnalysisEngineController
public LocalCache getLocalCache()
getLocalCache
in interface AnalysisEngineController
getLocalCache
in class BaseAnalysisEngineController
public Delegate lookupDelegate(java.lang.String aDelegateKey)
Delegate
object for a given delegate key.lookupDelegate
in interface AggregateAnalysisEngineController
public void setCasLoggingDirectory(java.lang.String key, java.lang.String directory)
setCasLoggingDirectory
in interface AggregateAnalysisEngineController
Copyright © 2012. All Rights Reserved.