#include <Worker.h>
Classes | |
class | AcquireTask |
class | AcquireTask< OccurrenceTraits< EventPrincipal, BranchActionStreamBegin >, DUMMY > |
class | HandleExternalWorkExceptionTask |
class | RunModuleTask |
struct | TaskQueueAdaptor |
Public Types | |
enum | ConcurrencyTypes { kGlobal, kLimited, kOne, kStream, kLegacy } |
enum | State { Ready, Pass, Fail, Exception } |
enum | Types { kAnalyzer, kFilter, kProducer, kOutputModule } |
Public Member Functions | |
void | addedToPath () |
void | beginJob () |
void | beginStream (StreamID id, StreamContext &streamContext) |
void | callWhenDoneAsync (WaitingTaskHolder task) |
void | clearCounters () |
void | clearModule () |
virtual std::vector< ConsumesInfo > | consumesInfo () const =0 |
virtual void | convertCurrentProcessAlias (std::string const &processName)=0 |
ModuleDescription const * | description () const |
void | doTransformAsync (WaitingTaskHolder, size_t iTransformIndex, EventPrincipal const &, ServiceToken const &, StreamID, ModuleCallingContext const &, StreamContext const *) |
template<typename T > | |
void | doWorkAsync (WaitingTaskHolder, typename T::TransitionInfoType const &, ServiceToken const &, StreamID, ParentContext const &, typename T::Context const *) |
template<typename T > | |
void | doWorkNoPrefetchingAsync (WaitingTaskHolder, typename T::TransitionInfoType const &, ServiceToken const &, StreamID, ParentContext const &, typename T::Context const *) |
void | endJob () |
void | endStream (StreamID id, StreamContext &streamContext) |
virtual SerialTaskQueue * | globalLuminosityBlocksQueue ()=0 |
virtual SerialTaskQueue * | globalRunsQueue ()=0 |
virtual bool | hasAccumulator () const =0 |
virtual ConcurrencyTypes | moduleConcurrencyType () const =0 |
virtual void | modulesWhoseProductsAreConsumed (std::array< std::vector< ModuleDescription const *> *, NumBranchTypes > &modules, std::vector< ModuleProcessName > &modulesInPreviousProcesses, ProductRegistry const &preg, std::map< std::string, ModuleDescription const *> const &labelsToDesc) const =0 |
virtual Types | moduleType () const =0 |
Worker & | operator= (Worker const &)=delete |
void | postDoEvent (EventPrincipal const &) |
void | prePrefetchSelectionAsync (oneapi::tbb::task_group &, WaitingTask *task, ServiceToken const &, StreamID stream, EventPrincipal const *) |
void | prePrefetchSelectionAsync (oneapi::tbb::task_group &, WaitingTask *task, ServiceToken const &, StreamID stream, void const *) |
void | registerThinnedAssociations (ProductRegistry const ®istry, ThinnedAssociationsHelper &helper) |
void | reset () |
virtual void | resolvePutIndicies (BranchType iBranchType, std::unordered_multimap< std::string, std::tuple< TypeID const *, const char *, edm::ProductResolverIndex >> const &iIndicies)=0 |
void | respondToCloseInputFile (FileBlock const &fb) |
void | respondToCloseOutputFile () |
void | respondToOpenInputFile (FileBlock const &fb) |
template<typename T > | |
std::exception_ptr | runModuleDirectly (typename T::TransitionInfoType const &, StreamID, ParentContext const &, typename T::Context const *) |
virtual void | selectInputProcessBlocks (ProductRegistry const &, ProcessBlockHelperBase const &)=0 |
void | setActivityRegistry (std::shared_ptr< ActivityRegistry > areg) |
void | setEarlyDeleteHelper (EarlyDeleteHelper *iHelper) |
void | skipOnPath (EventPrincipal const &iEvent) |
State | state () const |
int | timesExcept () const |
int | timesFailed () const |
int | timesPass () const |
int | timesPassed () const |
int | timesRun () const |
int | timesVisited () const |
virtual size_t | transformIndex (edm::BranchDescription const &) const =0 |
virtual void | updateLookup (BranchType iBranchType, ProductResolverIndexHelper const &)=0 |
virtual void | updateLookup (eventsetup::ESRecordsToProxyIndices const &)=0 |
edm::WaitingTaskList & | waitingTaskList () |
virtual bool | wantsGlobalLuminosityBlocks () const =0 |
virtual bool | wantsGlobalRuns () const =0 |
virtual bool | wantsInputProcessBlocks () const =0 |
virtual bool | wantsProcessBlocks () const =0 |
virtual bool | wantsStreamLuminosityBlocks () const =0 |
virtual bool | wantsStreamRuns () const =0 |
Worker (ModuleDescription const &iMD, ExceptionToActionTable const *iActions) | |
Worker (Worker const &)=delete | |
virtual | ~Worker () |
Private Member Functions | |
void | edPrefetchAsync (WaitingTaskHolder, ServiceToken const &, Principal const &) const |
void | emitPostModuleEventPrefetchingSignal () |
void | emitPostModuleGlobalPrefetchingSignal () |
void | emitPostModuleStreamPrefetchingSignal () |
virtual std::vector< ESProxyIndex > const & | esItemsToGetFrom (Transition) const =0 |
void | esPrefetchAsync (WaitingTaskHolder, EventSetupImpl const &, Transition, ServiceToken const &) |
virtual std::vector< ESRecordIndex > const & | esRecordsToGetFrom (Transition) const =0 |
std::exception_ptr | handleExternalWorkException (std::exception_ptr iEPtr, ParentContext const &parentContext) |
virtual bool | hasAcquire () const =0 |
virtual void | implRegisterThinnedAssociations (ProductRegistry const &, ThinnedAssociationsHelper &)=0 |
virtual void | implRespondToCloseInputFile (FileBlock const &fb)=0 |
virtual void | implRespondToCloseOutputFile ()=0 |
virtual void | implRespondToOpenInputFile (FileBlock const &fb)=0 |
virtual void | itemsMayGet (BranchType, std::vector< ProductResolverIndexAndSkipBit > &) const =0 |
virtual void | itemsToGet (BranchType, std::vector< ProductResolverIndexAndSkipBit > &) const =0 |
virtual std::vector< ProductResolverIndexAndSkipBit > const & | itemsToGetFrom (BranchType) const =0 |
bool | needsESPrefetching (Transition iTrans) const noexcept |
virtual void | preActionBeforeRunEventAsync (WaitingTaskHolder iTask, ModuleCallingContext const &moduleCallingContext, Principal const &iPrincipal) const =0 |
template<typename T > | |
void | prefetchAsync (WaitingTaskHolder, ServiceToken const &, ParentContext const &, typename T::TransitionInfoType const &, Transition) |
void | runAcquire (EventTransitionInfo const &, ParentContext const &, WaitingTaskWithArenaHolder &) |
void | runAcquireAfterAsyncPrefetch (std::exception_ptr, EventTransitionInfo const &, ParentContext const &, WaitingTaskWithArenaHolder) |
template<typename T > | |
bool | runModule (typename T::TransitionInfoType const &, StreamID, ParentContext const &, typename T::Context const *) |
template<typename T > | |
std::exception_ptr | runModuleAfterAsyncPrefetch (std::exception_ptr, typename T::TransitionInfoType const &, StreamID, ParentContext const &, typename T::Context const *) |
virtual TaskQueueAdaptor | serializeRunModule ()=0 |
template<bool IS_EVENT> | |
std::exception_ptr | setException (std::exception_ptr iException) |
template<bool IS_EVENT> | |
bool | setFailed () |
template<bool IS_EVENT> | |
bool | setPassed () |
bool | shouldRethrowException (std::exception_ptr iPtr, ParentContext const &parentContext, bool isEvent) const |
Private Attributes | |
ExceptionToActionTable const * | actions_ |
std::shared_ptr< ActivityRegistry > | actReg_ |
std::exception_ptr | cached_exception_ |
edm::propagate_const< EarlyDeleteHelper * > | earlyDeleteHelper_ |
ModuleCallingContext | moduleCallingContext_ |
bool | moduleValid_ = true |
std::atomic< int > | numberOfPathsLeftToRun_ |
int | numberOfPathsOn_ |
bool | ranAcquireWithoutException_ |
std::atomic< State > | state_ |
std::atomic< int > | timesExcept_ |
std::atomic< int > | timesFailed_ |
std::atomic< int > | timesPassed_ |
std::atomic< int > | timesRun_ |
std::atomic< int > | timesVisited_ |
edm::WaitingTaskList | waitingTasks_ |
std::atomic< bool > | workStarted_ |
Friends | |
template<typename O > | |
class | workerhelper::CallImpl |
Enumerator | |
---|---|
kGlobal | |
kLimited | |
kOne | |
kStream | |
kLegacy |
Definition at line 96 of file Worker.h.
enum edm::Worker::State |
Enumerator | |
---|---|
Ready | |
Pass | |
Fail | |
Exception |
enum edm::Worker::Types |
Enumerator | |
---|---|
kAnalyzer | |
kFilter | |
kProducer | |
kOutputModule |
edm::Worker::Worker | ( | ModuleDescription const & | iMD, |
ExceptionToActionTable const * | iActions | ||
) |
Definition at line 89 of file Worker.cc.
|
delete |
|
inlineprotected |
|
inline |
void edm::Worker::beginJob | ( | void | ) |
Definition at line 273 of file Worker.cc.
References actReg_, cms::Exception::addContext(), description(), Exception, implBeginJob(), edm::ModuleDescription::moduleLabel(), edm::ModuleDescription::moduleName(), state_, and edm::convertException::wrap().
Referenced by edm::WorkerManager::beginJob().
void edm::Worker::beginStream | ( | StreamID | id, |
StreamContext & | streamContext | ||
) |
Definition at line 306 of file Worker.cc.
References actReg_, cms::Exception::addContext(), description(), Exception, implBeginStream(), edm::LuminosityBlockIndex::invalidLuminosityBlockIndex(), edm::RunIndex::invalidRunIndex(), edm::StreamContext::kBeginStream, edm::ModuleCallingContext::kRunning, moduleCallingContext_, edm::ModuleDescription::moduleLabel(), edm::ModuleDescription::moduleName(), edm::StreamContext::setEventID(), edm::StreamContext::setLuminosityBlockIndex(), edm::StreamContext::setRunIndex(), edm::ModuleCallingContext::setState(), edm::StreamContext::setTimestamp(), edm::StreamContext::setTransition(), state_, and edm::convertException::wrap().
|
inline |
Definition at line 177 of file Worker.h.
References edm::WaitingTaskList::add(), eostools::move(), TrackValidation_cff::task, and waitingTasks_.
Referenced by edm::SwitchProducerProductResolver::prefetchAsync_().
|
inline |
Definition at line 232 of file Worker.h.
References timesExcept_, timesFailed_, timesPassed_, timesRun_, and timesVisited_.
Referenced by edm::StreamSchedule::clearCounters().
|
inline |
Definition at line 123 of file Worker.h.
References doClearModule(), and moduleValid_.
|
pure virtual |
Implemented in edm::WorkerT< T >.
Referenced by edm::PathsAndConsumesOfModules::doConsumesInfo(), and edm::StreamSchedule::tryToPlaceConditionalModules().
|
pure virtual |
Implemented in edm::WorkerT< T >.
|
inline |
Definition at line 198 of file Worker.h.
References moduleCallingContext_, edm::ModuleCallingContext::moduleDescription(), and moduleValid_.
Referenced by beginJob(), beginStream(), endJob(), endStream(), edm::StreamSchedule::fillWorkers(), edm::TransformingProductResolver::prefetchAsync_(), registerThinnedAssociations(), shouldRethrowException(), and edm::StreamSchedule::tryToPlaceConditionalModules().
|
protectedpure virtual |
Implemented in edm::WorkerT< T >.
Referenced by clearModule().
void edm::Worker::doTransformAsync | ( | WaitingTaskHolder | iTask, |
size_t | iTransformIndex, | ||
EventPrincipal const & | iPrincipal, | ||
ServiceToken const & | iToken, | ||
StreamID | , | ||
ModuleCallingContext const & | mcc, | ||
StreamContext const * | |||
) |
Definition at line 240 of file Worker.cc.
References edm::WaitingTaskHolder::doneWaiting(), edm::WaitingTaskHolder::group(), implDoTransformAsync(), itemToGetForTransform(), edm::make_waiting_task(), edm::ModuleCallingContext::parent(), class-composition::parent, edm::Principal::prefetchAsync(), and TrackValidation_cff::task.
Referenced by edm::TransformingProductResolver::prefetchAsync_().
void edm::Worker::doWorkAsync | ( | WaitingTaskHolder | task, |
typename T::TransitionInfoType const & | transitionInfo, | ||
ServiceToken const & | token, | ||
StreamID | streamID, | ||
ParentContext const & | parentContext, | ||
typename T::Context const * | context | ||
) |
Definition at line 968 of file Worker.h.
References edm::WaitingTaskList::add(), visDQMUpload::context, watchdog::group, hasAcquire(), info(), edm::ModuleCallingContext::kPrefetching, edm::make_waiting_task(), moduleCallingContext_, eostools::move(), AlCaHLTBitMon_ParallelJobs::p, prePrefetchSelectionAsync(), fetchall_from_DQM_v2::release, alignCSCRings::s, edm::ModuleCallingContext::setContext(), submitPVValidationJobs::t, TrackValidation_cff::task, timesVisited_, unpackBuffers-CaloStage2::token, waitingTasks_, and workStarted_.
Referenced by edm::UnscheduledProductResolver::prefetchAsync_(), and edm::WorkerInPath::runWorkerAsync().
void edm::Worker::doWorkNoPrefetchingAsync | ( | WaitingTaskHolder | task, |
typename T::TransitionInfoType const & | transitionInfo, | ||
ServiceToken const & | serviceToken, | ||
StreamID | streamID, | ||
ParentContext const & | parentContext, | ||
typename T::Context const * | context | ||
) |
Definition at line 1083 of file Worker.h.
References edm::WaitingTaskList::add(), CMS_SA_ALLOW, visDQMUpload::context, edm::WaitingTaskList::doneWaiting(), esPrefetchAsync(), watchdog::group, info(), edm::ServiceWeakToken::lock(), edm::make_waiting_task(), eostools::move(), needsESPrefetching(), createBeamHaloJobs::queue, serializeRunModule(), TrackValidation_cff::task, waitingTasks_, and workStarted_.
Referenced by edm::WorkerInPath::runWorkerAsync().
|
private |
Definition at line 224 of file Worker.cc.
References edm::Principal::branchType(), B2GTnPMonitor_cfi::item, mps_monitormerge::items, itemsToGetFrom(), moduleCallingContext_, edm::Principal::prefetchAsync(), edm::ProductResolverIndexAmbiguous, and unpackBuffers-CaloStage2::token.
Referenced by prefetchAsync().
|
inlineprivate |
Definition at line 368 of file Worker.h.
References actReg_, edm::ModuleCallingContext::getStreamContext(), and moduleCallingContext_.
Referenced by edm::Worker::RunModuleTask< T >::execute().
|
inlineprivate |
Definition at line 377 of file Worker.h.
References actReg_, edm::ModuleCallingContext::getGlobalContext(), and moduleCallingContext_.
Referenced by edm::Worker::RunModuleTask< T >::execute().
|
inlineprivate |
Definition at line 372 of file Worker.h.
References actReg_, edm::ModuleCallingContext::getStreamContext(), and moduleCallingContext_.
Referenced by edm::Worker::RunModuleTask< T >::execute().
void edm::Worker::endJob | ( | void | ) |
Definition at line 289 of file Worker.cc.
References actReg_, cms::Exception::addContext(), cms::cuda::assert(), submitPVResolutionJobs::desc, description(), Exception, implEndJob(), edm::ModuleDescription::moduleLabel(), edm::ModuleDescription::moduleName(), state_, and edm::convertException::wrap().
void edm::Worker::endStream | ( | StreamID | id, |
StreamContext & | streamContext | ||
) |
Definition at line 330 of file Worker.cc.
References actReg_, cms::Exception::addContext(), description(), Exception, implEndStream(), edm::LuminosityBlockIndex::invalidLuminosityBlockIndex(), edm::RunIndex::invalidRunIndex(), edm::StreamContext::kEndStream, edm::ModuleCallingContext::kRunning, moduleCallingContext_, edm::ModuleDescription::moduleLabel(), edm::ModuleDescription::moduleName(), edm::StreamContext::setEventID(), edm::StreamContext::setLuminosityBlockIndex(), edm::StreamContext::setRunIndex(), edm::ModuleCallingContext::setState(), edm::StreamContext::setTimestamp(), edm::StreamContext::setTransition(), state_, and edm::convertException::wrap().
|
privatepure virtual |
Implemented in edm::WorkerT< T >.
Referenced by esPrefetchAsync(), and needsESPrefetching().
|
private |
Definition at line 199 of file Worker.cc.
References cms::cuda::assert(), esItemsToGetFrom(), esRecordsToGetFrom(), edm::EventSetupImpl::findImpl(), mps_fire::i, mps_monitormerge::items, moduleCallingContext_, edm::NumberOfEventSetupTransitions, and edm::eventsetup::EventSetupRecordImpl::prefetchAsync().
Referenced by doWorkNoPrefetchingAsync(), edm::workerhelper::CallImpl< OccurrenceTraits< EventPrincipal, BranchActionStreamBegin > >::esPrefetchAsync(), edm::workerhelper::CallImpl< OccurrenceTraits< RunPrincipal, BranchActionGlobalBegin > >::esPrefetchAsync(), edm::workerhelper::CallImpl< OccurrenceTraits< RunPrincipal, BranchActionStreamBegin > >::esPrefetchAsync(), edm::workerhelper::CallImpl< OccurrenceTraits< RunPrincipal, BranchActionGlobalEnd > >::esPrefetchAsync(), edm::workerhelper::CallImpl< OccurrenceTraits< RunPrincipal, BranchActionStreamEnd > >::esPrefetchAsync(), edm::workerhelper::CallImpl< OccurrenceTraits< LuminosityBlockPrincipal, BranchActionGlobalBegin > >::esPrefetchAsync(), edm::workerhelper::CallImpl< OccurrenceTraits< LuminosityBlockPrincipal, BranchActionStreamBegin > >::esPrefetchAsync(), edm::workerhelper::CallImpl< OccurrenceTraits< LuminosityBlockPrincipal, BranchActionGlobalEnd > >::esPrefetchAsync(), and edm::workerhelper::CallImpl< OccurrenceTraits< LuminosityBlockPrincipal, BranchActionStreamEnd > >::esPrefetchAsync().
|
privatepure virtual |
Implemented in edm::WorkerT< T >.
Referenced by esPrefetchAsync().
|
pure virtual |
Implemented in edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, and edm::WorkerT< T >.
Referenced by edm::workerhelper::CallImpl< OccurrenceTraits< LuminosityBlockPrincipal, BranchActionGlobalEnd > >::enableGlobalQueue(), and edm::workerhelper::CallImpl< OccurrenceTraits< LuminosityBlockPrincipal, BranchActionGlobalBegin > >::pauseGlobalQueue().
|
pure virtual |
Implemented in edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, and edm::WorkerT< T >.
Referenced by edm::workerhelper::CallImpl< OccurrenceTraits< RunPrincipal, BranchActionGlobalEnd > >::enableGlobalQueue(), and edm::workerhelper::CallImpl< OccurrenceTraits< RunPrincipal, BranchActionGlobalBegin > >::pauseGlobalQueue().
|
private |
Definition at line 417 of file Worker.cc.
References edm::exceptionContext(), moduleCallingContext_, ranAcquireWithoutException_, and edm::convertException::wrap().
|
pure virtual |
Implemented in edm::WorkerT< T >.
Referenced by edm::UnscheduledCallProducer::addWorker().
|
privatepure virtual |
Implemented in edm::WorkerT< T >.
Referenced by doWorkAsync(), and edm::Worker::RunModuleTask< T >::execute().
|
protectedpure virtual |
Implemented in edm::WorkerT< T >.
Referenced by beginJob().
|
protectedpure virtual |
Implemented in edm::WorkerT< T >.
Referenced by beginStream().
|
protectedpure virtual |
Implemented in edm::WorkerT< T >.
Referenced by edm::workerhelper::CallImpl< OccurrenceTraits< EventPrincipal, BranchActionStreamBegin > >::call().
|
protectedpure virtual |
Implemented in edm::WorkerT< T >.
Referenced by edm::workerhelper::CallImpl< OccurrenceTraits< ProcessBlockPrincipal, BranchActionProcessBlockInput > >::call().
|
protectedpure virtual |
Implemented in edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, and edm::WorkerT< T >.
Referenced by runAcquire().
|
protectedpure virtual |
|
protectedpure virtual |
Implemented in edm::WorkerT< T >.
|
protectedpure virtual |
Implemented in edm::WorkerT< T >.
Referenced by edm::workerhelper::CallImpl< OccurrenceTraits< ProcessBlockPrincipal, BranchActionGlobalBegin > >::call().
|
protectedpure virtual |
|
protectedpure virtual |
Implemented in edm::WorkerT< T >.
|
protectedpure virtual |
Implemented in edm::WorkerT< T >.
Referenced by edm::workerhelper::CallImpl< OccurrenceTraits< ProcessBlockPrincipal, BranchActionGlobalEnd > >::call().
|
protectedpure virtual |
Implemented in edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, and edm::WorkerT< T >.
Referenced by prePrefetchSelectionAsync().
|
protectedpure virtual |
|
protectedpure virtual |
Implemented in edm::WorkerT< T >.
|
protectedpure virtual |
|
protectedpure virtual |
Implemented in edm::WorkerT< T >.
|
protectedpure virtual |
Implemented in edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, and edm::WorkerT< T >.
Referenced by doTransformAsync().
|
protectedpure virtual |
Implemented in edm::WorkerT< T >.
Referenced by endJob().
|
protectedpure virtual |
Implemented in edm::WorkerT< T >.
Referenced by endStream().
|
protectedpure virtual |
|
privatepure virtual |
Implemented in edm::WorkerT< T >.
Referenced by registerThinnedAssociations().
|
privatepure virtual |
Implemented in edm::WorkerT< T >.
Referenced by respondToCloseInputFile().
|
privatepure virtual |
Implemented in edm::WorkerT< T >.
Referenced by respondToCloseOutputFile().
|
privatepure virtual |
Implemented in edm::WorkerT< T >.
Referenced by respondToOpenInputFile().
|
privatepure virtual |
Implemented in edm::WorkerT< T >.
|
privatepure virtual |
Implemented in edm::WorkerT< T >.
|
protectedpure virtual |
Implemented in edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, and edm::WorkerT< T >.
Referenced by prePrefetchSelectionAsync().
|
privatepure virtual |
Implemented in edm::WorkerT< T >.
Referenced by edPrefetchAsync().
|
protectedpure virtual |
Implemented in edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, and edm::WorkerT< T >.
Referenced by doTransformAsync().
|
pure virtual |
Implemented in edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, and edm::WorkerT< T >.
|
pure virtual |
Implemented in edm::WorkerT< T >.
|
pure virtual |
Implemented in edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, and edm::WorkerT< T >.
Referenced by edm::WorkerManager::addToUnscheduledWorkers(), and edm::StreamSchedule::fillWorkers().
|
inlineprivatenoexcept |
Definition at line 364 of file Worker.h.
References esItemsToGetFrom(), and edm::NumberOfEventSetupTransitions.
Referenced by doWorkNoPrefetchingAsync().
void edm::Worker::postDoEvent | ( | EventPrincipal const & | iEvent | ) |
Definition at line 372 of file Worker.cc.
References earlyDeleteHelper_, and iEvent.
|
privatepure virtual |
Implemented in edm::WorkerT< T >.
Referenced by prefetchAsync().
|
private |
Definition at line 942 of file Worker.h.
References actReg_, edm::Principal::branchType(), edPrefetchAsync(), edm::ModuleCallingContext::getGlobalContext(), edm::ModuleCallingContext::getStreamContext(), edm::InEvent, edm::ModuleCallingContext::kPrefetching, moduleCallingContext_, preActionBeforeRunEventAsync(), edm::ModuleCallingContext::setContext(), and unpackBuffers-CaloStage2::token.
void edm::Worker::prePrefetchSelectionAsync | ( | oneapi::tbb::task_group & | group, |
WaitingTask * | task, | ||
ServiceToken const & | token, | ||
StreamID | stream, | ||
EventPrincipal const * | iPrincipal | ||
) |
Definition at line 150 of file Worker.cc.
References CMS_SA_ALLOW, edm::TaskBase::decrement_ref_count(), edm::WaitingTaskList::doneWaiting(), edm::TaskBase::execute(), watchdog::group, implDoPrePrefetchSelection(), edm::TaskBase::increment_ref_count(), B2GTnPMonitor_cfi::item, mps_monitormerge::items, itemsToGetForSelection(), edm::ServiceWeakToken::lock(), edm::make_waiting_task(), moduleCallingContext_, edm::Principal::prefetchAsync(), edm::ProductResolverIndexAmbiguous, alignCSCRings::s, timesRun_, unpackBuffers-CaloStage2::token, and waitingTasks_.
Referenced by doWorkAsync().
|
inline |
Definition at line 141 of file Worker.h.
References cms::cuda::assert().
void edm::Worker::registerThinnedAssociations | ( | ProductRegistry const & | registry, |
ThinnedAssociationsHelper & | helper | ||
) |
Definition at line 354 of file Worker.cc.
References cms::Exception::addContext(), description(), implRegisterThinnedAssociations(), and HerwigMaxPtPartonFilter_cfi::moduleLabel.
|
inline |
Definition at line 188 of file Worker.h.
References cached_exception_, numberOfPathsLeftToRun_, numberOfPathsOn_, Ready, edm::WaitingTaskList::reset(), state_, waitingTasks_, and workStarted_.
Referenced by edm::WorkerManager::resetAll().
|
protected |
Definition at line 265 of file Worker.cc.
References moduleCallingContext_, edm::ModuleCallingContext::parent(), edm::ModuleCallingContext::previousModuleOnThread(), edm::ModuleCallingContext::state(), and groupFilesInBlocks::temp.
Referenced by edm::WorkerT< T >::setModule().
|
pure virtual |
Implemented in edm::WorkerT< T >.
|
inline |
Definition at line 184 of file Worker.h.
References implRespondToCloseInputFile().
Referenced by edm::Schedule::respondToCloseInputFile().
|
inline |
Definition at line 185 of file Worker.h.
References implRespondToCloseOutputFile().
|
inline |
Definition at line 183 of file Worker.h.
References implRespondToOpenInputFile().
Referenced by edm::Schedule::respondToOpenInputFile().
|
private |
Definition at line 378 of file Worker.cc.
References edm::exceptionContext(), implDoAcquire(), moduleCallingContext_, shouldRethrowException(), timesRun_, and edm::convertException::wrap().
Referenced by runAcquireAfterAsyncPrefetch().
|
private |
Definition at line 393 of file Worker.cc.
References CMS_SA_ALLOW, edm::WaitingTaskWithArenaHolder::doneWaiting(), edm::ModuleCallingContext::kInvalid, moduleCallingContext_, ranAcquireWithoutException_, runAcquire(), edm::ModuleCallingContext::setContext(), and shouldRethrowException().
|
private |
Definition at line 1142 of file Worker.h.
References actReg_, cms::cuda::assert(), cached_exception_, visDQMUpload::context, edm::exceptionContext(), moduleCallingContext_, shouldRethrowException(), timesRun_, and edm::convertException::wrap().
|
private |
Definition at line 1058 of file Worker.h.
References CMS_SA_ALLOW, visDQMUpload::context, edm::WaitingTaskList::doneWaiting(), edm::ModuleCallingContext::kInvalid, moduleCallingContext_, edm::ModuleCallingContext::setContext(), shouldRethrowException(), and waitingTasks_.
Referenced by edm::Worker::RunModuleTask< T >::execute().
std::exception_ptr edm::Worker::runModuleDirectly | ( | typename T::TransitionInfoType const & | transitionInfo, |
StreamID | streamID, | ||
ParentContext const & | parentContext, | ||
typename T::Context const * | context | ||
) |
Definition at line 1182 of file Worker.h.
References visDQMUpload::context, and timesVisited_.
Referenced by edm::Path::finished().
|
pure virtual |
Implemented in edm::WorkerT< T >.
|
privatepure virtual |
Implemented in edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, and edm::WorkerT< T >.
Referenced by doWorkNoPrefetchingAsync(), and edm::Worker::RunModuleTask< T >::execute().
void edm::Worker::setActivityRegistry | ( | std::shared_ptr< ActivityRegistry > | areg | ) |
void edm::Worker::setEarlyDeleteHelper | ( | EarlyDeleteHelper * | iHelper | ) |
Definition at line 237 of file Worker.cc.
References earlyDeleteHelper_.
|
inlineprivate |
Definition at line 345 of file Worker.h.
References cached_exception_, Exception, state_, and timesExcept_.
|
inlineprivate |
Definition at line 336 of file Worker.h.
References Fail, state_, and timesFailed_.
|
inlineprivate |
Definition at line 327 of file Worker.h.
References Pass, state_, and timesPassed_.
|
private |
Definition at line 110 of file Worker.cc.
References writedatasetfile::action, actions_, cms::Exception::category(), description(), edm::exception_actions::FailPath, edm::ExceptionToActionTable::find(), edm::ModuleCallingContext::getTopModuleCallingContext(), edm::exception_actions::IgnoreCompletely, edm::PathContext::isEndPath(), edm::ModuleCallingContext::kInvalid, edm::ParentContext::kPlaceInPath, edm::PlaceInPathContext::pathContext(), edm::ModuleCallingContext::placeInPathContext(), edm::printCmsExceptionWarning(), edm::exception_actions::Rethrow, edm::exception_actions::SkipEvent, edm::ModuleCallingContext::type(), and edm::convertException::wrap().
Referenced by runAcquire(), runAcquireAfterAsyncPrefetch(), runModule(), and runModuleAfterAsyncPrefetch().
void edm::Worker::skipOnPath | ( | EventPrincipal const & | iEvent | ) |
Definition at line 363 of file Worker.cc.
References cached_exception_, edm::WaitingTaskList::doneWaiting(), earlyDeleteHelper_, iEvent, numberOfPathsLeftToRun_, and waitingTasks_.
Referenced by edm::WorkerInPath::skipWorker().
|
inline |
Definition at line 247 of file Worker.h.
References state_.
Referenced by edm::WorkerInPath::checkResultsOfRunWorker().
|
inline |
|
inline |
|
inline |
|
inline |
|
inline |
|
inline |
|
pure virtual |
Implemented in edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, edm::WorkerT< T >, and edm::WorkerT< T >.
Definition at line 239 of file Worker.cc.
Referenced by edm::TransformingProductResolver::setupUnscheduled().
|
pure virtual |
Implemented in edm::WorkerT< T >.
|
pure virtual |
Implemented in edm::WorkerT< T >.
|
inline |
|
pure virtual |
|
pure virtual |
|
pure virtual |
|
pure virtual |
|
pure virtual |
|
pure virtual |
|
protectedpure virtual |
Implemented in edm::WorkerT< T >.
|
friend |
|
private |
Definition at line 611 of file Worker.h.
Referenced by shouldRethrowException().
|
private |
Definition at line 614 of file Worker.h.
Referenced by activityRegistry(), beginJob(), beginStream(), emitPostModuleEventPrefetchingSignal(), emitPostModuleGlobalPrefetchingSignal(), emitPostModuleStreamPrefetchingSignal(), endJob(), endStream(), prefetchAsync(), runModule(), and setActivityRegistry().
|
private |
Definition at line 612 of file Worker.h.
Referenced by reset(), runModule(), setException(), and skipOnPath().
|
private |
Definition at line 616 of file Worker.h.
Referenced by postDoEvent(), setEarlyDeleteHelper(), and skipOnPath().
|
private |
Definition at line 609 of file Worker.h.
Referenced by beginStream(), description(), doWorkAsync(), edPrefetchAsync(), emitPostModuleEventPrefetchingSignal(), emitPostModuleGlobalPrefetchingSignal(), emitPostModuleStreamPrefetchingSignal(), endStream(), esPrefetchAsync(), handleExternalWorkException(), prefetchAsync(), prePrefetchSelectionAsync(), resetModuleDescription(), runAcquire(), runAcquireAfterAsyncPrefetch(), runModule(), and runModuleAfterAsyncPrefetch().
|
private |
Definition at line 621 of file Worker.h.
Referenced by clearModule(), and description().
|
private |
Definition at line 607 of file Worker.h.
Referenced by reset(), and skipOnPath().
|
private |
Definition at line 606 of file Worker.h.
Referenced by addedToPath(), and reset().
|
private |
Definition at line 620 of file Worker.h.
Referenced by handleExternalWorkException(), and runAcquireAfterAsyncPrefetch().
|
private |
Definition at line 605 of file Worker.h.
Referenced by beginJob(), beginStream(), endJob(), endStream(), reset(), setException(), setFailed(), setPassed(), and state().
|
private |
Definition at line 604 of file Worker.h.
Referenced by clearCounters(), setException(), and timesExcept().
|
private |
Definition at line 603 of file Worker.h.
Referenced by clearCounters(), setFailed(), and timesFailed().
|
private |
Definition at line 602 of file Worker.h.
Referenced by clearCounters(), setPassed(), and timesPassed().
|
private |
Definition at line 600 of file Worker.h.
Referenced by clearCounters(), prePrefetchSelectionAsync(), runAcquire(), runModule(), and timesRun().
|
private |
Definition at line 601 of file Worker.h.
Referenced by clearCounters(), doWorkAsync(), runModuleDirectly(), and timesVisited().
|
private |
Definition at line 618 of file Worker.h.
Referenced by callWhenDoneAsync(), doWorkAsync(), doWorkNoPrefetchingAsync(), prePrefetchSelectionAsync(), reset(), runModuleAfterAsyncPrefetch(), skipOnPath(), and waitingTaskList().
|
private |
Definition at line 619 of file Worker.h.
Referenced by doWorkAsync(), doWorkNoPrefetchingAsync(), and reset().