Go to the source code of this file.
enum MACHINE_SMP_MODE |
INVALID_MODE | |
COMM_THREAD_SEND_RECV | |
COMM_THREAD_SEND_RECV | |
COMM_THREAD_ONLY_RECV | |
COMM_WORK_THREADS_SEND_RECV | |
COMM_THREAD_NOT_EXIST |
Definition at line 176 of file machine-common-core.C.
CsvDeclare | ( | CMIQueue | , | |
procBcastQ | ||||
) |
CsvDeclare | ( | CMIQueue | , | |
nodeBcastQ | ||||
) |
Definition at line 65 of file machine-common-core.C.
Referenced by CmiAsyncNodeSendFn(), CmiAsyncSendFn(), CmiInterFreeNodeSendFn(), and CmiInterSendNetworkFunc().
static void handleOneBcastMsg | ( | int | size, | |
char * | msg | |||
) | [static] |
static void processBcastQs | ( | void | ) | [static] |
static INLINE_KEYWORD void processProcBcastMsg | ( | int | size, | |
char * | msg | |||
) | [static] |
static INLINE_KEYWORD void processNodeBcastMsg | ( | int | size, | |
char * | msg | |||
) | [static] |
static void SendSpanningChildrenProc | ( | int | size, | |
char * | msg | |||
) | [static] |
static void SendHyperCubeProc | ( | int | size, | |
char * | msg | |||
) | [static] |
static void SendSpanningChildrenNode | ( | int | size, | |
char * | msg | |||
) | [static] |
static void SendHyperCubeNode | ( | int | size, | |
char * | msg | |||
) | [static] |
void CmiSyncBroadcastFn | ( | int | size, | |
char * | msg | |||
) |
Definition at line 320 of file machine-broadcast.C.
References CmiFree(), CmiSyncBroadcastFn1(), and CopyMsg().
CmiCommHandle CmiAsyncBroadcastFn | ( | int | size, | |
char * | msg | |||
) |
Definition at line 343 of file machine-broadcast.C.
References CmiAbort().
void CmiFreeBroadcastFn | ( | int | size, | |
char * | msg | |||
) |
Definition at line 333 of file machine-broadcast.C.
References CmiFree(), and CmiSyncBroadcastFn1().
void CmiSyncBroadcastAllFn | ( | int | size, | |
char * | msg | |||
) |
Definition at line 351 of file machine-broadcast.C.
References CmiFree(), CmiMyPe(), CmiSyncBroadcastFn1(), CmiSyncSendFn(), and CopyMsg().
CmiCommHandle CmiAsyncBroadcastAllFn | ( | int | size, | |
char * | msg | |||
) |
Definition at line 379 of file machine-broadcast.C.
References CmiAsyncBroadcastFn(), CmiSendSelf(), and CopyMsg().
void CmiFreeBroadcastAllFn | ( | int | size, | |
char * | msg | |||
) |
Definition at line 365 of file machine-broadcast.C.
References CmiFree(), CmiGetReference(), CmiSendSelf(), CmiSyncBroadcastFn1(), and CopyMsg().
void CmiSyncNodeBroadcastFn | ( | int | size, | |
char * | msg | |||
) |
Definition at line 386 of file machine-broadcast.C.
References CmiSyncNodeSendFn(), CQdCreate(), SendHyperCubeNode(), and SendSpanningChildrenNode().
CmiCommHandle CmiAsyncNodeeroadcastFn | ( | int | size, | |
char * | msg | |||
) |
void CmiFreeNodeBroadcastFn | ( | int | size, | |
char * | msg | |||
) |
Definition at line 406 of file machine-broadcast.C.
References CmiFree(), and CmiSyncNodeBroadcastFn().
void CmiSyncNodeBroadcastAllFn | ( | int | size, | |
char * | msg | |||
) |
Definition at line 419 of file machine-broadcast.C.
References CmiSyncNodeBroadcastFn(), and CmiSyncNodeSendFn().
CmiCommHandle CmiAsyncNodeBroadcastAllFn | ( | int | size, | |
char * | msg | |||
) |
Definition at line 424 of file machine-broadcast.C.
References CmiAsyncNodeBroadcastFn(), CmiSendNodeSelf(), and CopyMsg().
void CmiFreeNodeBroadcastAllFn | ( | int | size, | |
char * | msg | |||
) |
Definition at line 429 of file machine-broadcast.C.
References CmiSendNodeSelf(), and CmiSyncNodeBroadcastFn().
CpvDeclare | ( | void * | , | |
CmiLocalQueue | ||||
) |
void CmiSuspendedTaskEnqueue | ( | int | targetRank, | |
void * | data | |||
) |
void* CmiSuspendedTaskPop | ( | void | ) |
CpvDeclare | ( | unsigned | , | |
networkProgressCount | ||||
) |
CMK_NORETURN void CmiAbort | ( | const char * | why | ) |
Serial version of common Charm++ routines:.
Serial version of common Charm++ routines:.
Currently only used for FEM_ALONE mode.
Orion Sky Lawlor, olawlor@acm.org, 2003/8/15
Definition at line 8 of file charm_standalone.C.
References abort().
static void PerrorExit | ( | const char * | msg | ) | [static] |
Definition at line 447 of file machine-common-core.C.
Referenced by call_startfn(), and CmiStartThreads().
static INLINE_KEYWORD void handleOneRecvedMsg | ( | int | size, | |
char * | msg | |||
) | [static] |
Definition at line 528 of file machine-common-core.C.
References cma_reg_msg, CmiPushNode(), CmiPushPE(), CMK_CMA_ACK_MSG, CMK_CMA_MD_MSG, handleOneBcastMsg(), handleOneCmaAckMsg(), handleOneCmaMdMsg(), and TraceTimerCommon().
Referenced by CmiSendMessagePxshm(), CmiSendMessageXpmem(), PumpMsgs(), PumpMsgsBlocking(), and SendMsgBuf().
static void SendToPeers | ( | int | size, | |
char * | msg | |||
) | [static] |
Definition at line 565 of file machine-common-core.C.
References CmiPushPE(), and CopyMsg().
Referenced by CmiForwardMsgToPeers(), SendHyperCubeProc(), and SendSpanningChildrenProc().
void CmiPushPE | ( | int | rank, | |
void * | msg | |||
) |
void CmiPushNode | ( | void * | msg | ) |
static void CmiSendSelf | ( | char * | msg | ) | [static] |
Definition at line 581 of file machine-common-core.C.
References CdsFifo_Enqueue(), CmiHandleImmediate(), and CmiPushImmediateMsg().
Referenced by CmiAsyncBroadcastAllFn(), CmiFreeBroadcastAllFn(), and CmiInterFreeSendFn().
CmiCommHandle CmiAsyncSendFn | ( | int | destPE, | |
int | size, | |||
char * | msg | |||
) |
static void CmiSendNodeSelf | ( | char * | msg | ) | [static] |
Definition at line 745 of file machine-common-core.C.
References _immRunning, CmiHandleImmediate(), CmiLock(), CmiPushImmediateMsg(), CmiUnlock(), and MPMCQueuePush().
Referenced by CmiAsyncNodeBroadcastAllFn(), CmiFreeNodeBroadcastAllFn(), and CmiInterFreeNodeSendFn().
CmiCommHandle CmiAsyncNodeSendFn | ( | int | destNode, | |
int | size, | |||
char * | msg | |||
) |
void ConverseInit | ( | int | argc, | |
char ** | argv, | |||
CmiStartFn | fn, | |||
int | usched, | |||
int | initret | |||
) |
static void ConverseRunPE | ( | int | everReturn | ) | [static] |
The reason to initialize this variable here: cmiArgDebugFlag is possibly accessed in CmiPrintf/CmiError etc., therefore, we have to initialize this variable before any calls to those functions (such as CmiPrintf). Otherwise, we may encounter a memory segmentation fault (bad memory access). Note, even testing CpvInitialized(cmiArgDebugFlag) doesn't help to solve this problem because the variable indicating whether cmiArgDebugFlag is initialized or not is not initialized, thus possibly causing another bad memory access. --Chao Mei
Definition at line 1496 of file machine-common-core.C.
References _immediateReady, CcdCallOnConditionKeep(), CharmLibInterOperate, Cmi_argv, Cmi_argvcopy, Cmi_startfn, Cmi_usrsched, CmiCopyArgs(), CmiGetArgc(), CmiGetState(), CmiInitNotifyCommThdScheme(), CmiMyRank(), CmiNodeAllBarrier(), CmiNotifyBeginIdle(), CmiNotifyGetState(), CmiNotifyStillIdle(), CommunicationServerThread(), ConverseCommonInit(), ConverseExit(), CsdScheduler(), CthInit(), CmiStateStruct::localqueue, LrtsPostCommonInit(), and LrtsPreCommonInit().
Referenced by call_startfn(), and ConverseInit().
static INLINE_KEYWORD void AdvanceCommunication | ( | int | whenidle | ) | [static] |
Definition at line 1606 of file machine-common-core.C.
References CmiHandleImmediate(), CmiMyRank(), CommunicationServerPxshm(), LrtsAdvanceCommunication(), and processBcastQs().
Referenced by CmiGetNonLocal(), CmiGetNonLocalNodeQ(), and CommunicationServer().
static void CommunicationServer | ( | int | sleepTime | ) | [static] |
Definition at line 1638 of file machine-common-core.C.
References _exitcode, AdvanceCommunication(), CharmLibInterOperate, ckExitComplete, CmiExitXpmem(), CmiNodeAllBarrier(), ConverseCommonExit(), LrtsDrainResources(), LrtsExit(), and memory_order_acquire.
Referenced by call_startfn().
void CommunicationServerThread | ( | int | sleepTime | ) |
void* CmiGetNonLocal | ( | void | ) |
In SMP mode with comm thread, it's possible a normal msg is sent from an immediate msg which is executed on comm thread. In this case, the msg is sent to the network queue of the work thread. Therefore, even there's only one worker thread, the polling of network queue is still required.
void* CmiGetNonLocalNodeQ | ( | void | ) |
static char* CopyMsg | ( | char * | msg, | |
int | len | |||
) | [static] |
Referenced by CmiAsyncBroadcastAllFn(), CmiAsyncNodeBroadcastAllFn(), CmiFreeBroadcastAllFn(), CmiGetNonLocalNodeQ(), CmiInterSyncNodeSendFn(), CmiInterSyncSendFn(), CmiSyncBroadcastAllFn(), CmiSyncBroadcastFn(), CmiSyncNodeSendFn(), CmiSyncSendFn(), forwardProcBcastMsg(), SendHyperCube(), SendSpanningChildren(), and SendToPeers().
static CmiIdleState* CmiNotifyGetState | ( | void | ) | [static] |
Referenced by CmiGetNonLocalNodeQ(), and ConverseRunPE().
static void CmiNotifyBeginIdle | ( | CmiIdleState * | s | ) | [static] |
Generally,.
CmiNotifyIdle is used in non-SMP mode when the proc is idle. When the proc is idle, AdvanceCommunication needs to be called.
CmiNotifyStillIdle and CmiNotifyBeginIdle are used in SMP mode.
Different layers have choices of registering different callbacks for idle state.
Referenced by CmiGetNonLocalNodeQ(), and ConverseRunPE().
static void CmiNotifyStillIdle | ( | CmiIdleState * | s | ) | [static] |
Referenced by CmiGetNonLocalNodeQ(), CmiSendMessagePxshm(), CmiSendMessageXpmem(), and ConverseRunPE().
void CmiNotifyIdle | ( | void | ) |
CsvDeclare | ( | CmiNodeState | , | |
NodeState | ||||
) |
void CmiMemLock | ( | void | ) |
Definition at line 358 of file machine-common-core.C.
Referenced by CmiMemoryMark(), CmiMemoryMarkBlock(), CmiMemorySweep(), free_nomigrate(), and malloc_nomigrate().
void CmiMemUnlock | ( | void | ) |
Definition at line 359 of file machine-common-core.C.
Referenced by CmiMemoryMark(), CmiMemoryMarkBlock(), CmiMemorySweep(), free_nomigrate(), and malloc_nomigrate().
void CmiYield | ( | void | ) |
Definition at line 364 of file machine-common-core.C.
References sleep().
Referenced by CmiGetNonLocalNodeQ(), and ConverseExit().
static void CmiStartThreads | ( | char ** | argv | ) | [static] |
Definition at line 368 of file machine-common-core.C.
References _Cmi_mynode_global, _Cmi_mype, _Cmi_mype_global, _Cmi_myrank, Cmi_nodestart, Cmi_state, and CmiStateInit().
Referenced by ConverseInit().
INLINE_KEYWORD int CmiNodeSpan | ( | void | ) |
Definition at line 375 of file machine-common-core.C.
INLINE_KEYWORD CMIQueue CmiMyRecvQueue | ( | void | ) |
Definition at line 380 of file machine-common-core.C.
References CmiGetState(), and CmiStateStruct::recv.
INLINE_KEYWORD MPMCQueue CMIQueue CmiMyNodeQueue | ( | void | ) |
Definition at line 391 of file machine-common-core.C.
int CmiMyPe | ( | void | ) |
Definition at line 396 of file machine-common-core.C.
References CmiGetState(), and CmiStateStruct::pe.
Referenced by __cmi_assert(), _bcastQD1(), _bcastQD2(), _callWhenIdle(), _checkpointBarrierAckHandler(), _createTracecounter(), _dummyMigrationHandler(), _getCheckpointHandler(), _getGlobalStepHandler(), _getRestartCheckpointHandler(), _handlePhase0(), _handlePhase1(), _handlePhase2(), _initCharm(), _initHandler(), _libExitHandler(), _messageLoggingExit(), _parseCommandLineOpts(), _qdCommHandler(), _qdHandler(), _receivedDetDataHandler(), _receivedTNDataHandler(), _receiveLocationHandler(), _receiveMigrationNoticeAckHandler(), _recvCheckpointHandler(), _recvGlobalStepHandler(), _recvRestartCheckpointHandler(), _sendDetsReplyHandler(), _sendReadonlies(), _startCheckpointHandler(), _storeCheckpointHandler(), _updateHomeRequestHandler(), _verifyAckHandler(), _verifyAckRequestHandler(), ackEntryMethodHandler(), bad_location(), TraceCounter::beginExecute(), TraceCounter::beginOverview(), TraceCounter::beginPack(), TraceCounter::beginUnpack(), CkArray::broadcastHomeElements(), CcsImpl_reply(), CcsInit(), CfutureCreate(), CfutureDestroy(), CfutureStoreBuffer(), CfutureWait(), check_range(), CkArray::CkArray(), CkCppInterpreter::CkCppInterpreter(), CkDieNow(), Converse::CkMyPe(), CldAckNoTaskHandler(), CldAverageHandler(), CldBalancePeriod(), CldComputeNeighborData(), CldEnqueue(), CldGraphModuleInit(), CldMinAvg(), CldModuleGeneralInit(), CldModuleInit(), CldMoveAllSeedsAway(), CldNodeEnqueue(), CldOtherInit(), CldReadNeighborData(), CldReadytoExec(), CldSendLoad(), CldSetPEBitVector(), CldStillIdle(), clearUpMigratedRetainedLists(), CmiAbortHelper(), CmiAddCLA(), CmiAlloc(), CmiArgGivingUsage(), CmiArgInit(), CmiBacktracePrint(), CmiCheckAffinity(), CmiCreateCompressPersistent(), CmiCreateCompressPersistentSize(), CmiCreatePersistent(), CmiCreateReceiverPersistent(), CmiEstablishGroup(), CmiGetDynamicReduction(), CmiGetDynamicReductionRemote(), CmiGetNonLocal(), CmiGetNonLocalNodeQ(), CmiGlobalReduce(), CmiGlobalReduceStruct(), CmiInitCell(), CmiInitCPUAffinity(), CmiInitMemAffinity(), CmiInterFreeSendFn(), CmiInterSendNetworkFunc(), CmiIsomallocBlockListPup(), CmiIsomallocInit(), CmiListReduce(), CmiListReduceStruct(), CmiMemorySweep(), CmiMulticastDeliver(), CmiMultiMsgHandler(), CmiPrintCLAs(), CmiProcessPriority(), CmiReduce(), CmiReduceID(), CmiReduceStruct(), CmiReduceStructID(), CmiRegisterHandlerGlobal(), CmiSendMessageCma(), CmiSyncBroadcastAllFn(), CmiSyncBroadcastFn1(), CmiSyncListSendFn(), CmiTLSInit(), converse_handlerBegin(), converse_handlerEnd(), ConverseCommonInit(), ConverseDeliver(), ConverseExit(), copyOut(), CountLogPool::CountLogPool(), CPathGetEltset(), CPathMakeArray(), CPathSendHandler(), cpd_memory_single_pup(), CpdNotify(), CpdStartGdb(), Cpthread_cond_broadcast(), Cpthread_cond_destroy(), Cpthread_cond_init(), Cpthread_cond_signal(), Cpthread_cond_wait(), Cpthread_mutex_destroy(), Cpthread_mutex_init(), Cpthread_mutex_lock(), Cpthread_mutex_trylock(), Cpthread_mutex_unlock(), cpuAffinityHandler(), cpuAffinityRecvHandler(), CQdBcastQD1(), CQdBcastQD2(), CQdHandlePhase0(), CQdHandlePhase1(), CQdHandlePhase2(), CQdStateCreate(), CsdInit(), CtgInit(), CthThreadBaseInit(), CWeb_Collect(), CWeb_Reduce(), CWebHandler(), CkArrayBroadcaster::deliver(), disable_isomalloc(), disabled_map(), StatTable::doReduction(), emptyReduction(), TraceCounter::endExecute(), TraceCounter::endOverview(), TraceCounter::endPack(), TraceCounter::endUnpack(), expand_ccd_heap(), find_largest_free_region(), finishedCheckpointLoadBalancing(), gengraph(), getCheckPointPE(), getGlobalStep(), getNewPagetable(), getNUMANidByRank(), getReverseCheckPointPE(), heartBeatCheckHandler(), heartBeatPartner(), HigherPriorityWork(), informLocationHome(), StatTable::init(), init_ranges(), initQd(), initTraceTauBOC(), CkMemCheckPT::inmem_restore(), CkMemCheckPT::isMaster(), isomalloc_internal_alloc_block(), isomallocfn(), LrtsInitCpuTopo(), machine_procBusy(), machine_procIdle(), map_slots(), memAbort(), memory_check(), mempool_free(), meta_aligned_alloc(), meta_calloc(), meta_cfree(), meta_free(), meta_init(), meta_malloc(), meta_memalign(), meta_posix_memalign(), meta_pvalloc(), meta_realloc(), meta_valloc(), ntohl(), on_timeout(), one_slotOP(), CountLogPool::openFile(), TraceLogger::openLogFiles(), GridMetisLB::Partition_ClusterObjects_Into_PEs(), prepare_slotmsg(), CkNcpyBuffer::print(), print_cpu_affinity(), print_mem_affinity(), print_myslots(), print_node0(), print_thread_affinity(), printBGP_UPC_Counters(), printSlot(), processReceivedTN(), CentralLB::ProcessReceiveMigration(), PumpMsgsBlocking(), CkLocMgr::pup(), ChareMlogData::pup(), pupArrayElementsSkip(), QdState::QdState(), readBlacklist(), CentralLB::ReceiveStats(), TraceCounter::registerArg(), TraceLogger::RegisterLanguage(), ReleasePostedMessages(), req_fw_handler(), ChareMlogData::searchRestoredLocalQ(), seedBalancerExit(), sendCheckpointData(), sendDummyMigrationCounts(), sendGroupMsg(), sendLocalMsg(), sendMlogLocation(), sendMsg(), SendMsgBuf(), sendRecvDoneMsgToPeers(), sendRemoveLogRequests(), CentralLB::SendStats(), SendTasktoPe(), set_process_affinity(), set_thread_affinity(), slotAbort(), StartInteropScheduler(), startLoadBalancingMlog(), startMlogCheckpoint(), StatTable::StatTable(), StatTableReduction(), status(), StealLoad(), StopInteropScheduler(), TraceCounter::switchCounters(), TaskQueuePop(), TraceCounter::traceBegin(), TraceCounter::traceClose(), traceCommonInit(), TraceCounter::traceEnd(), TraceCounter::traceInit(), TraceCounter::traceWriteSts(), try_largest_mmap_region(), unmap_slots(), CountLogPool::write(), StatTable::write(), CountLogPool::writeSts(), and zlib_compress().
int CmiMyPeGlobal | ( | void | ) |
Definition at line 402 of file machine-common-core.C.
References CmiGetState(), and CmiStateStruct::pe.
Referenced by CmiInitCPUAffinity().
int CmiMyRank | ( | void | ) |
Definition at line 405 of file machine-common-core.C.
References CmiGetState(), and CmiStateStruct::rank.
Referenced by _deliverForBocMsg(), _initCharm(), _libExitHandler(), _processRODataMsg(), _processROMsgMsg(), _speedHdlr(), CkReduction::addReducer(), AdvanceCommunication(), bind_process_and_threads(), bind_threads_only(), call_startfn(), CcsInit(), CharmLibExit(), checkForInitDone(), CkMessageWatcherInit(), CkRestartMain(), CldAskLoadHandler(), CldBalance(), CldGraphModuleInit(), CmiAlloc_ppcq(), CmiAssignOnce(), CmiGetNonLocalNodeQ(), CmiInitCPUAffinity(), CmiInitNotifyCommThdScheme(), CmiMemoryInit(), CmiMyRank_(), CmiOutOfMemoryInit(), CmiProcessPriority(), CmiRegisterHandlerAssignOnce(), CmiRegisterHandlerExAssignOnce(), CmiSyncBroadcastFn1(), CmiTLSInit(), ConverseCommonExit(), ConverseCommonInit(), ConverseExit(), ConverseRunPE(), cpd_memory_single_pup(), Cpthread_once(), Cpthread_start_main(), CsdInit(), CthEnqueueSuspendedStealableThread(), CthScheduledDecrement(), CthSuspend(), CWebPerformanceRegisterFunction(), FuncCkLoop::destroyHelpers(), EnqueueMsg(), NullLB::init(), init_ranges(), initQd(), CkMemCheckPT::isMaster(), CurLoopInfo::localReduce(), LrtsInitCpuTopo(), meta_init(), MPIPostOneBuffer(), FuncCkLoop::parallelizeFunc(), CkNcpyBuffer::print(), RegisterCkLoopHdlrs(), CurLoopInfo::runChunk(), QdState::sendCount(), SendMsgBuf(), StartInteropScheduler(), StealTask(), and traceCommonInit().
Definition at line 408 of file machine-common-core.C.
References _Cmi_mynodesize.
Referenced by _speedHdlr(), ccs_getinfo(), and LrtsNodeSize().
Definition at line 412 of file machine-common-core.C.
References _Cmi_mynodesize.
Referenced by _sendTriggers(), _speedHdlr(), CmiAsyncNodeSendFn(), CmiCreateCompressNodePersistent(), CmiCreateCompressNodePersistentSize(), CmiCreateNodePersistent(), CmiInitCPUAffinity(), CmiInterFreeNodeSendFn(), CmiNodeReduce(), BGQTorusManager::coordinatesToRank(), ST_RecursivePartition< Iterator >::initPhyNodes(), CkMemCheckPT::isMaster(), LrtsNodeFirst(), BGQTorusManager::populateLocalNodes(), PumpMsgsBlocking(), readonlyGetCompleted(), QdState::sendCount(), SendHyperCube(), SendMsgBuf(), SendSpanningChildren(), TopoManager_init(), and updatePeerCounterAndPush().
Definition at line 415 of file machine-common-core.C.
References _Cmi_mynodesize.
Referenced by _skipCldEnqueue(), topo::impl::buildNextGen_topoUnaware(), CkGetSrcNode(), CldEnqueue(), CldHopHandler(), CldNodeEnqueue(), CldStillIdle(), CmiAsyncSendFn(), CmiCreateCompressPersistent(), CmiCreateCompressPersistentSize(), CmiCreatePersistent(), CmiInitCPUAffinity(), CmiInterFreeSendFn(), CmiInterSendNetworkFunc(), BGQTorusManager::coordinatesToRank(), findTransferMode(), LrtsInitCpuTopo(), LrtsIssueRget(), LrtsIssueRput(), LrtsNodeOf(), LrtsPeOnSameNode(), MPIPostOneBuffer(), pe_lToGTranslate(), persistentReqGrantedHandler(), pidtonid(), BGQTorusManager::populateLocalNodes(), TopoManager::printAllocation(), LV3D0_ClientManager_toMaster::progress(), SendHyperCubeProc(), CpuTopology::sort(), and TopoManager_init().
Definition at line 418 of file machine-common-core.C.
References _Cmi_mynodesize.
Referenced by CldAskLoadHandler(), CldStillIdle(), CmiInterFreeSendFn(), BGQTorusManager::coordinatesToRank(), enqueueNcpyMessage(), LrtsRankOf(), pe_lToGTranslate(), traceCommonInit(), and updatePeerCounterAndPush().
static int CmiState_hasMessage | ( | void | ) | [static] |
Definition at line 424 of file machine-common-core.C.
References CmiGetState(), and CmiIdleLock_hasMessage().
CmiCommHandle CmiInterSendNetworkFunc | ( | int | destPE, | |
int | partition, | |||
int | size, | |||
char * | msg, | |||
int | mode | |||
) |
Definition at line 626 of file machine-common-core.C.
References _cmi_log2(), cma_max_threshold, cma_min_threshold, cma_reg_msg, CmiMyPe(), CmiNodeOf(), CmiPeOnSamePhysicalNode(), CmiSendMessageCma(), CmiSendMessagePxshm(), CmiSendMessageXpmem(), CmiValidPxshm(), CmiValidXpmem(), CMK_REG_NO_CMA_MSG, LrtsSendFunc(), LrtsSendPersistentMsg(), msg_histogram, MSG_STATISTIC, rank, and refcount.
Referenced by CmiInterFreeNodeSendFn(), CmiInterFreeSendFn(), CmiSendNetworkFunc(), and handleOneCmaMdMsg().
int CmiDoesCMAWork | ( | void | ) |
Definition at line 441 of file machine-common-core.C.
References cma_works.
Referenced by findTransferMode().
Definition at line 600 of file machine-common-core.C.
References CmiInterFreeSendFn(), and CopyMsg().
CpvExtern | ( | int | , | |
_urgentSend | ||||
) |
INLINE_KEYWORD CmiCommHandle CmiSendNetworkFunc | ( | int | destPE, | |
int | size, | |||
char * | msg, | |||
int | mode | |||
) |
Definition at line 620 of file machine-common-core.C.
References CmiInterSendNetworkFunc(), and CMK_REG_NO_CMA_MSG.
Referenced by CmiAsyncNodeSendFn(), CmiAsyncSendFn(), SendHyperCube(), and SendSpanningChildren().
Definition at line 687 of file machine-common-core.C.
References CmiInterSendNetworkFunc(), CmiMyPe(), CmiNodeOf(), CmiPushPE(), CmiRankOf(), CmiSendSelf(), CMK_REG_NO_CMA_MSG, and CQdCreate().
Referenced by CmiFreeSendFn(), and CmiInterSyncSendFn().
Definition at line 771 of file machine-common-core.C.
References CmiInterFreeNodeSendFn(), and CopyMsg().
Definition at line 781 of file machine-common-core.C.
References _cmi_log2(), CmiInterSendNetworkFunc(), CmiNodeFirst(), CmiSendNodeSelf(), CMK_REG_NO_CMA_MSG, CQdCreate(), msg_histogram, and MSG_STATISTIC.
Referenced by CmiFreeNodeSendFn(), and CmiInterSyncNodeSendFn().
Definition at line 3 of file custom_partitioner.C.
Referenced by create_topoaware_partitions().
void setDefaultPartitionParams | ( | void | ) |
Definition at line 5 of file set_partition_params.C.
Referenced by create_partition_map().
void create_topoaware_partitions | ( | void | ) |
Definition at line 839 of file machine-common-core.C.
References _Cmi_mynode, _Cmi_mynodesize, _Cmi_numnodes, _Cmi_numpes, assert, calloc(), createCustomPartitions(), free(), int, malloc(), PartitionInfo::myPartition, PartitionInfo::nodeMap, PartitionInfo::numPartitions, PARTITION_SINGLETON, PartitionInfo::partitionPrefix, PartitionInfo::partitionSize, PartitionInfo::scheme, TopoManager_createPartitions(), TopoManager_free(), TopoManager_init(), and PartitionInfo::type.
Referenced by create_partition_map().
void CmiSetNumPartitions | ( | int | nump | ) |
void CmiSetMasterPartition | ( | void | ) |
Definition at line 894 of file machine-common-core.C.
References CmiAbort(), PARTITION_DEFAULT, PARTITION_MASTER, and PartitionInfo::type.
void CmiSetPartitionSizes | ( | char * | sizes | ) |
Definition at line 901 of file machine-common-core.C.
References CmiAbort(), length, malloc(), PARTITION_DEFAULT, PARTITION_PREFIX, PartitionInfo::partsizes, and PartitionInfo::type.
void CmiSetPartitionScheme | ( | int | scheme | ) |
Definition at line 914 of file machine-common-core.C.
References PartitionInfo::isTopoaware, and PartitionInfo::scheme.
void CmiSetCustomPartitioning | ( | void | ) |
Definition at line 919 of file machine-common-core.C.
References PartitionInfo::isTopoaware, and PartitionInfo::scheme.
static void create_partition_map | ( | char ** | argv | ) | [static] |
Definition at line 924 of file machine-common-core.C.
References _Cmi_mynode, _Cmi_mynode_global, _Cmi_numnodes_global, calloc(), CmiAbort(), CmiGetArgFlagDesc(), CmiGetArgIntDesc(), CmiGetArgStringDesc(), create_topoaware_partitions(), flag, PartitionInfo::isTopoaware, PartitionInfo::myPartition, PartitionInfo::numPartitions, PARTITION_DEFAULT, PARTITION_MASTER, PARTITION_PREFIX, PartitionInfo::partitionPrefix, PartitionInfo::partitionSize, PartitionInfo::partsizes, PartitionInfo::scheme, setDefaultPartitionParams(), size, stride, and PartitionInfo::type.
Referenced by CmiCreatePartitions().
void CmiCreatePartitions | ( | char ** | argv | ) |
Definition at line 1069 of file machine-common-core.C.
References _Cmi_mynode, _Cmi_mynode_global, _Cmi_mynodesize, _Cmi_numnodes, _Cmi_numnodes_global, _Cmi_numpes_global, Cmi_nodestart, Cmi_nodestartGlobal, CmiAbort(), create_partition_map(), and PartitionInfo::numPartitions.
Referenced by ConverseInit().
Definition at line 1091 of file machine-common-core.C.
References CmiAbort(), PartitionInfo::isTopoaware, PartitionInfo::nodeMap, PARTITION_DEFAULT, PARTITION_MASTER, PARTITION_PREFIX, PARTITION_SINGLETON, PartitionInfo::partitionPrefix, PartitionInfo::partitionSize, rank, and PartitionInfo::type.
Referenced by pe_lToGTranslate().
Definition at line 1116 of file machine-common-core.C.
References CmiNodeOf(), CmiRankOf(), node_lToGTranslate(), PARTITION_SINGLETON, and PartitionInfo::type.
Definition at line 1127 of file machine-common-core.C.
References CmiAbort().
Definition at line 1132 of file machine-common-core.C.
References CmiAbort().
Definition at line 1160 of file machine-common-core.C.
Referenced by check_and_set_queue_parameters().
void check_and_set_queue_parameters | ( | ) |
Definition at line 1166 of file machine-common-core.C.
References CmiAbort(), CmiPrintf(), DataNodeSize, DataNodeWrap, MaxDataNodes, power_of_two_check(), QueueUpperBound, and QueueWrap.
Referenced by ConverseInit().
void CthInit | ( | char ** | argv | ) |
Definition at line 1077 of file threads.C.
References CmiThreadIs_flag, CthBaseInit(), CthDummy(), CthThreadInit(), malloc(), p, size_t, CthProcInfo_s::stackbase, CthProcInfo_s::switchbuf, CthProcInfo_s::switchbuf_sp, and PUP::t.
Referenced by ConverseRunPE().
void ConverseExit | ( | int | exitcode | ) |
Definition at line 1669 of file machine-common-core.C.
References _exitcode, CharmLibInterOperate, Cmi_smp_mode_setting, CmiExitPxshm(), CmiExitXpmem(), CmiMyPe(), CmiMyRank(), CmiNodeAllBarrier(), CmiPrintf(), CmiYield(), COMM_THREAD_NOT_EXIST, COMM_THREAD_ONLY_RECV, ConverseCommonExit(), LrtsDrainResources(), LrtsExit(), memory_order_release, msg_histogram, MSG_STATISTIC, quietMode, quietModeRequested, and userDrivenMode.
Referenced by _exitHandler(), CkMessageDetailReplayDone(), ConverseRunPE(), and TraceCounter::traceInit().
void CmiAbortHelper | ( | const char * | source, | |
const char * | message, | |||
const char * | suggestion, | |||
int | tellDebugger, | |||
int | framesToSkip | |||
) |
Definition at line 1731 of file machine-common-core.C.
References CmiError(), CmiExitPxshm(), CmiExitXpmem(), CmiMyPe(), CmiPrintStackTrace(), CpdAborting(), and LrtsAbort().
Referenced by CmiAbort(), and SendMsgBuf().
Definition at line 60 of file machine-common-core.C.
int MSG_STATISTIC = 0 [static] |
Definition at line 63 of file machine-common-core.C.
Referenced by CmiAsyncNodeSendFn(), CmiAsyncSendFn(), CmiInterFreeNodeSendFn(), CmiInterSendNetworkFunc(), ConverseExit(), and ConverseInit().
int msg_histogram[22] |
Definition at line 64 of file machine-common-core.C.
Referenced by CmiAsyncNodeSendFn(), CmiAsyncSendFn(), CmiInterFreeNodeSendFn(), CmiInterSendNetworkFunc(), ConverseExit(), and ConverseInit().
int CmiNodesDim [static] |
Definition at line 76 of file machine-common-core.C.
Referenced by ConverseInit(), and SendHyperCube().
Definition at line 151 of file machine-common-core.C.
Definition at line 154 of file machine-common-core.C.
Referenced by CmiCreatePartitions(), CmiStartThreads(), and create_partition_map().
Definition at line 155 of file machine-common-core.C.
Referenced by CmiCreatePartitions(), and create_partition_map().
int _writeToStdout = 1 [static] |
Definition at line 160 of file machine-common-core.C.
Referenced by call_startfn(), CmiCreatePartitions(), CmiNodeFirst(), CmiNodeOf(), CmiNodeSize(), CmiRankOf(), CmiStartThreads(), ConverseInit(), create_topoaware_partitions(), and SendMsgBuf().
Definition at line 161 of file machine-common-core.C.
Referenced by call_startfn(), CmiCreatePartitions(), CmiDisplayCMAThresholds(), CmiExitPxshm(), CmiExitXpmem(), CmiInitPxshm(), CmiInitXpmem(), CmiSendMessagePxshm(), CmiSendMessageXpmem(), CmiStartThreads(), ConverseInit(), create_partition_map(), create_topoaware_partitions(), and SendMsgBuf().
Definition at line 162 of file machine-common-core.C.
Referenced by arg_init(), CmiCreatePartitions(), CmiSendMessagePxshm(), CmiSendMessageXpmem(), ConverseInit(), and create_topoaware_partitions().
Definition at line 163 of file machine-common-core.C.
Referenced by CkMessageWatcherInit(), CmiSyncBroadcastFn1(), ConverseInit(), and create_topoaware_partitions().
enum MACHINE_SMP_MODE Cmi_smp_mode_setting = COMM_THREAD_SEND_RECV [static] |
Definition at line 188 of file machine-common-core.C.
Referenced by ConverseExit(), ConverseInit(), LrtsIssueRget(), LrtsIssueRput(), LrtsSendFunc(), MPIPostOneBuffer(), and SendMsgBuf().
int Cmi_commthread = 0 |
Definition at line 222 of file machine-common-core.C.
Referenced by CmiNodeAllBarrier(), CmiStartThreads(), and traceCommonInit().
int Cmi_nodestart = -1 |
Definition at line 230 of file machine-common-core.C.
Referenced by call_startfn(), CmiCreatePartitions(), CmiMemAllocInit_ppcq(), CmiStartThreads(), and ConverseInit().
int Cmi_nodestartGlobal = -1 [static] |
char** Cmi_argv [static] |
Definition at line 300 of file machine-common-core.C.
Referenced by ConverseInit(), and ConverseRunPE().
char** Cmi_argvcopy [static] |
Definition at line 301 of file machine-common-core.C.
Referenced by ConverseInit(), and ConverseRunPE().
CmiStartFn Cmi_startfn [static] |
Definition at line 302 of file machine-common-core.C.
Referenced by ConverseInit(), and ConverseRunPE().
int Cmi_usrsched [static] |
Definition at line 303 of file machine-common-core.C.
Referenced by ConverseInit(), and ConverseRunPE().
struct CmiStateStruct Cmi_state [static] |
Definition at line 355 of file machine-common-core.C.
Referenced by CkMessageWatcherInit(), and CmiStartThreads().
Definition at line 439 of file machine-common-core.C.
Referenced by CmiDoesCMAWork(), CmiInitCma(), and ConverseInit().
Definition at line 439 of file machine-common-core.C.
Referenced by CmiInterSendNetworkFunc(), ConverseInit(), and handleOneRecvedMsg().
Definition at line 439 of file machine-common-core.C.
Referenced by CmiInterSendNetworkFunc(), and ConverseInit().
Definition at line 439 of file machine-common-core.C.
Referenced by CmiInterSendNetworkFunc(), and ConverseInit().
Definition at line 612 of file machine-common-core.C.
Referenced by LocalBarrier::AtBarrier(), and CmiInterSendNetworkFunc().