|
OverSim
|
This is the complete list of members for PubSubMMOG, including all inherited members.
| allowOldMoveMessages | PubSubMMOG | protected |
| AOIWidth | PubSubMMOG | protected |
| backupSubspaces | PubSubMMOG | protected |
| BaseOverlay() | BaseOverlay | |
| BaseRpc() | BaseRpc | |
| bindAndListenTcp(int port) | BaseTcpSupport | protected |
| bindToPort(int port) | BaseOverlay | protected |
| BOOTSTRAP enum value | BaseOverlay | |
| bootstrapList | BaseOverlay | protected |
| BSET enum value | BaseOverlay | |
| bytesAppDataForwarded | BaseOverlay | protected |
| bytesAppLookupForwarded | BaseOverlay | protected |
| bytesDropped | BaseOverlay | protected |
| bytesFailedNodeResponseSent | BaseOverlay | protected |
| bytesFailedNodeSent | BaseOverlay | protected |
| bytesFindNodeResponseSent | BaseOverlay | protected |
| bytesFindNodeSent | BaseOverlay | protected |
| bytesMaintenanceForwarded | BaseOverlay | protected |
| bytesPingResponseSent | BaseRpc | protected |
| bytesPingSent | BaseRpc | protected |
| callDeliver(BaseOverlayMessage *msg, const OverlayKey &destKey) | BaseOverlay | protected |
| callForward(const OverlayKey &key, BaseRouteMessage *msg, const NodeHandle &nextHopNode) | BaseOverlay | protected |
| callUpdate(const NodeHandle &node, bool joined) | BaseOverlay | protected |
| cancelAllRpcs() | BaseRpc | protected |
| cancelRpcMessage(uint32_t nonce) | BaseRpc | protected |
| childPingTimer | PubSubMMOG | protected |
| closeTcpConnection(TransportAddress address) | BaseTcpSupport | protected |
| collectPerHopDelay | BaseOverlay | protected |
| CONNECTION_RESET enum value | BaseTcpSupport | |
| CONNECTION_SUCC_ClOSED enum value | BaseTcpSupport | |
| countFailedNodeCall(const FailedNodeCall *call) | BaseOverlay | protected |
| countFindNodeCall(const FindNodeCall *call) | BaseOverlay | protected |
| createLookup(RoutingType routingType=DEFAULT_ROUTING, const BaseOverlayMessage *msg=NULL, const cPacket *findNodeExt=NULL, bool appLookup=false) | BaseOverlay | protectedvirtual |
| creationTime | BaseOverlay | protected |
| cryptoModule | BaseRpc | protected |
| currentRegionX | PubSubMMOG | protected |
| currentRegionY | PubSubMMOG | protected |
| debugOutput | BaseOverlay | protected |
| defaultRoutingType | BaseOverlay | protected |
| delayVector | BaseOverlay | protected |
| deleteOverlayNeighborArrow(const NodeHandle &neighbor) | TopologyVis | |
| DISCOVERY enum value | BaseOverlay | |
| distance(const OverlayKey &x, const OverlayKey &y, bool useAlternative=false) const | BaseOverlay | virtual |
| drawOverlayTopology | BaseOverlay | protected |
| dropFindNodeAttack | BaseOverlay | protected |
| dropRouteMessageAttack | BaseOverlay | protected |
| establishTcpConnection(TransportAddress address) | BaseTcpSupport | protected |
| estimateMeanDistance() | BaseOverlay | virtual |
| estimateOverlaySize() | BaseOverlay | virtual |
| EvCode enum name | BaseTcpSupport | |
| eventDeliveryTimer | PubSubMMOG | protected |
| FAILED enum value | BaseOverlay | |
| findNode(const OverlayKey &key, int numRedundantNodes, int numSiblings, BaseOverlayMessage *msg=NULL) | BaseOverlay | protectedvirtual |
| finishOverlay() | PubSubMMOG | virtual |
| finishRpcs() | BaseRpc | protected |
| getBitsPerDigit() | BaseOverlay | inlinevirtual |
| getBootstrapList() const | BaseOverlay | inline |
| getCompModule(CompType compType) | BaseOverlay | |
| getCompRpcGate(CompType compType) | BaseOverlay | |
| getCreationTime() | BaseOverlay | inline |
| getMaxNumRedundantNodes() | BaseOverlay | virtual |
| getMaxNumSiblings() | BaseOverlay | virtual |
| getMeasureAuthBlock() | BaseOverlay | inline |
| getState() | BaseOverlay | inline |
| getTcpOut() | BaseTcpSupport | inlineprotected |
| getThisCompType() | BaseOverlay | protectedvirtual |
| getThisNode() | BaseRpc | inline |
| getUdpTimeout() | BaseRpc | inline |
| globalNodeList | BaseOverlay | protected |
| globalParameters | BaseOverlay | protected |
| globalStatistics | BaseRpc | protected |
| handleAdoptChildCall(PubSubAdoptChildCall *adoptCall) | PubSubMMOG | protected |
| handleAdoptChildResponse(PubSubAdoptChildResponse *adoptResp) | PubSubMMOG | protected |
| handleAppMessage(cMessage *msg) | PubSubMMOG | virtual |
| handleBackupCall(PubSubBackupCall *backupCall) | PubSubMMOG | protected |
| handleBackupCallTimeout(PubSubBackupCall *backupCall, const TransportAddress &oldNode) | PubSubMMOG | protected |
| handleBackupResponse(PubSubBackupResponse *backupResp) | PubSubMMOG | protected |
| handleBaseOverlayMessage(BaseOverlayMessage *msg, const OverlayKey &destKey=OverlayKey::UNSPECIFIED_KEY) | BaseOverlay | protected |
| handleConnectionEvent(EvCode code, TransportAddress address) | BaseTcpSupport | protectedvirtual |
| handleDataReceived(TransportAddress address, cPacket *msg, bool urgent) | BaseTcpSupport | protectedvirtual |
| handleFailedNode(const TransportAddress &failed) | BaseOverlay | protectedvirtual |
| handleHelpResponse(PubSubHelpResponse *helpResp) | PubSubMMOG | protected |
| handleIncomingConnection(TransportAddress address) | BaseTcpSupport | protectedvirtual |
| handleIntermediateBackup(PubSubBackupIntermediateMessage *backupMsg) | PubSubMMOG | protected |
| handleIntermediateCall(PubSubIntermediateCall *intermediateCall) | PubSubMMOG | protected |
| handleIntermediateResponse(PubSubIntermediateResponse *intermediateResp) | PubSubMMOG | protected |
| handleJoinResponse(PubSubJoinResponse *joinResp) | PubSubMMOG | protected |
| handleMessage(cMessage *msg) | BaseOverlay | protected |
| handleMove(GameAPIPositionMessage *posMsg) | PubSubMMOG | protected |
| handleMoveListMessage(PubSubMoveListMessage *moveMsg) | PubSubMMOG | protected |
| handleMoveMessage(PubSubMoveMessage *moveMsg) | PubSubMMOG | protected |
| handleNodeGracefulLeaveNotification() | BaseOverlay | protectedvirtual |
| handleNodeLeaveNotification() | BaseOverlay | protectedvirtual |
| handleNodeLeftMessage(PubSubNodeLeftMessage *leftMsg) | PubSubMMOG | protected |
| handleParentTimeout(PubSubTimer *timer) | PubSubMMOG | protected |
| handlePingCall(PubSubPingCall *hearbeatCall) | PubSubMMOG | protected |
| handlePingCallTimeout(PubSubPingCall *pingCall, const TransportAddress &oldNode) | PubSubMMOG | protected |
| handlePingResponse(PubSubPingResponse *pingResp) | PubSubMMOG | protected |
| handleReleaseIntermediate(PubSubReleaseIntermediateMessage *releaseMsg) | PubSubMMOG | protected |
| handleReplacementMessage(PubSubReplacementMessage *replaceMsg) | PubSubMMOG | protected |
| handleResponsibleNodeResponse(PubSubResponsibleNodeResponse *subResp) | PubSubMMOG | protected |
| handleRpcCall(BaseCallMessage *msg) | PubSubMMOG | virtual |
| handleRpcResponse(BaseResponseMessage *msg, cPolymorphic *context, int rpcId, simtime_t rtt) | PubSubMMOG | virtual |
| BaseOverlay::handleRpcResponse(BaseResponseMessage *msg, const RpcState &rpcState, simtime_t rtt) | RpcListener | protectedvirtual |
| handleRpcTimeout(BaseCallMessage *msg, const TransportAddress &dest, cPolymorphic *context, int rpcId, const OverlayKey &destKey) | PubSubMMOG | virtual |
| BaseOverlay::handleRpcTimeout(const RpcState &rpcState) | RpcListener | protectedvirtual |
| handleSubscriptionBackup(PubSubBackupSubscriptionMessage *backupMsg) | PubSubMMOG | protected |
| handleSubscriptionCall(PubSubSubscriptionCall *subCall) | PubSubMMOG | protected |
| handleSubscriptionCallTimeout(PubSubSubscriptionCall *subscriptionCall, const TransportAddress &oldNode) | PubSubMMOG | protected |
| handleSubscriptionResponse(PubSubSubscriptionResponse *subResp) | PubSubMMOG | protected |
| handleTakeOver(PubSubTakeOverSubspaceCall *toCall) | PubSubMMOG | protected |
| handleTCPMessage(cMessage *msg) | BaseTcpSupport | protected |
| handleTimerEvent(cMessage *msg) | PubSubMMOG | virtual |
| handleTransportAddressChangedNotification() | BaseOverlay | protectedvirtual |
| handleUDPMessage(BaseOverlayMessage *msg) | PubSubMMOG | virtual |
| handleUnsubscribeBackup(PubSubBackupUnsubscribeMessage *backupMsg) | PubSubMMOG | protected |
| handleUnsubscriptionMessage(PubSubUnsubscriptionMessage *unsMsg) | PubSubMMOG | protected |
| heartbeatTimer | PubSubMMOG | protected |
| hopCountMax | BaseOverlay | protected |
| hopCountVector | BaseOverlay | protected |
| INIT enum value | BaseOverlay | |
| initializeOverlay(int stage) | PubSubMMOG | virtual |
| initRpcs() | BaseRpc | protected |
| initVis(cModule *terminal) | TopologyVis | protected |
| intermediateSubspaces | PubSubMMOG | protected |
| internalHandleMessage(cMessage *msg) | BaseRpc | protected |
| internalHandleRpcCall(BaseCallMessage *msg) | BaseOverlay | protectedvirtual |
| internalHandleRpcMessage(BaseRpcMessage *msg) | BaseRpc | protectedvirtual |
| internalHandleRpcResponse(BaseResponseMessage *msg, cPolymorphic *context, int rpcId, simtime_t rtt) | BaseOverlay | protectedvirtual |
| internalHandleRpcTimeout(BaseCallMessage *msg, const TransportAddress &dest, cPolymorphic *context, int rpcId, const OverlayKey &destKey) | BaseOverlay | protectedvirtual |
| internalSendRouteRpc(BaseRpcMessage *message, const OverlayKey &destKey, const std::vector< TransportAddress > &sourceRoute, RoutingType routingType) | BaseOverlay | protectedvirtual |
| invalidNodesAttack | BaseOverlay | protected |
| isAlreadyConnected(TransportAddress address) | BaseTcpSupport | protected |
| isInSimpleMultiOverlayHost() | BaseOverlay | |
| isMalicious() | BaseOverlay | |
| isSiblingAttack | BaseOverlay | protected |
| isSiblingFor(const NodeHandle &node, const OverlayKey &key, int numSiblings, bool *err) | BaseOverlay | virtual |
| iterativeLookupConfig | BaseOverlay | protected |
| JOIN enum value | BaseOverlay | |
| join(const OverlayKey &nodeID=OverlayKey::UNSPECIFIED_KEY) | BaseOverlay | |
| joinForeignPartition(const NodeHandle &node) | BaseOverlay | protectedvirtual |
| joinOverlay() | BaseOverlay | protectedvirtual |
| joinTimer | PubSubMMOG | protected |
| kbr | BaseOverlay | protected |
| lobbyServer | PubSubMMOG | protected |
| local_lookup(const OverlayKey &key, int num, bool safe) | BaseOverlay | virtual |
| localPort | BaseOverlay | protected |
| lookupRpc(LookupCall *call) | BaseOverlay | protectedvirtual |
| lookups | BaseOverlay | protected |
| LookupSet typedef | BaseOverlay | protected |
| lostMovementLists | PubSubMMOG | protected |
| maxChildren | PubSubMMOG | protected |
| maxMoveDelay | PubSubMMOG | protected |
| measureAuthBlock | BaseOverlay | protected |
| moveListMessagesSize | PubSubMMOG | protected |
| movementRate | PubSubMMOG | protected |
| moveMessagesSize | PubSubMMOG | protected |
| neighborCache | BaseRpc | protected |
| neighborSet(int num) | BaseOverlay | virtual |
| nextHopRpc(NextHopCall *call) | BaseOverlay | protectedvirtual |
| NO_EST_CONNECTION enum value | BaseTcpSupport | |
| notificationBoard | BaseOverlay | protected |
| numAppDataForwarded | BaseOverlay | protected |
| numAppLookupForwarded | BaseOverlay | protected |
| numDropped | BaseOverlay | protected |
| numEventsCorrectTimeslot | PubSubMMOG | protected |
| numEventsWrongTimeslot | PubSubMMOG | protected |
| numFailedNodeResponseSent | BaseOverlay | protected |
| numFailedNodeSent | BaseOverlay | protected |
| numFindNodeResponseSent | BaseOverlay | protected |
| numFindNodeSent | BaseOverlay | protected |
| numInitStages() const | BaseOverlay | protected |
| numMaintenanceForwarded | BaseOverlay | protected |
| numMoveListMessages | PubSubMMOG | protected |
| numMoveMessages | PubSubMMOG | protected |
| numPingResponseSent | BaseRpc | protected |
| numPingSent | BaseRpc | protected |
| numPubSubSignalingMessages | PubSubMMOG | protected |
| numSubspaces | PubSubMMOG | protected |
| overlay | BaseRpc | protected |
| overlayId | BaseOverlay | protected |
| parentTimeout | PubSubMMOG | protected |
| PEER_CLOSED enum value | BaseTcpSupport | |
| PEER_REFUSED enum value | BaseTcpSupport | |
| PEER_TIMEDOUT enum value | BaseTcpSupport | |
| pingNode(const TransportAddress &dest, simtime_t timeout=-1, int retries=0, cPolymorphic *context=NULL, const char *caption="PING", RpcListener *rpcListener=NULL, int rpcId=-1, TransportType transportType=INVALID_TRANSPORT) | BaseRpc | protected |
| pingResponse(PingResponse *pingResponse, cPolymorphic *context, int rpcId, simtime_t rtt) | BaseRpc | protectedvirtual |
| pingTimeout(PingCall *pingCall, const TransportAddress &dest, cPolymorphic *context, int rpcId) | BaseRpc | protectedvirtual |
| POSTJOIN enum value | BaseOverlay | |
| PREJOIN enum value | BaseOverlay | |
| providesKbr() | BaseOverlay | inline |
| publishEvents() | PubSubMMOG | protected |
| pubSubSignalingMessagesSize | PubSubMMOG | protected |
| READY enum value | BaseOverlay | |
| receiveChangeNotification(int category, const cPolymorphic *details) | PubSubMMOG | virtual |
| receivedMovementLists | PubSubMMOG | protected |
| recNumRedundantNodes | BaseOverlay | protected |
| recordOverlaySentStats(BaseOverlayMessage *msg) | BaseOverlay | protectedvirtual |
| recordRoute | BaseOverlay | protected |
| recursiveLookupConfig | BaseOverlay | protected |
| REFRESH enum value | BaseOverlay | |
| registerComp(CompType compType, cModule *module) | BaseOverlay | |
| rejoinOnFailure | BaseOverlay | protected |
| removeLookup(AbstractLookup *lookup) | BaseOverlay | protectedvirtual |
| respMoveListMessagesSize | PubSubMMOG | protected |
| responsibleSubspaces | PubSubMMOG | protected |
| restoreContext | BaseOverlay | protected |
| route(const OverlayKey &key, CompType destComp, CompType srcComp, cPacket *msg, const std::vector< TransportAddress > &sourceRoute=TransportAddress::UNSPECIFIED_NODES, RoutingType routingType=DEFAULT_ROUTING) | BaseOverlay | protectedvirtual |
| routeMsgAcks | BaseOverlay | protected |
| RSET enum value | BaseOverlay | |
| sendHearbeatToChildren() | PubSubMMOG | protected |
| sendInternalRpcCall(CompType destComp, BaseCallMessage *msg, cPolymorphic *context=NULL, simtime_t timeout=-1, int retries=0, int rpcId=-1, RpcListener *rpcListener=NULL) | BaseRpc | inlineprotected |
| sendMessageToAllComp(cMessage *msg, CompType srcComp) | BaseOverlay | |
| sendMessageToChildren(PubSubSubspaceResponsible &subspace, BaseOverlayMessage *toIntermediates, BaseOverlayMessage *toBackup, BaseOverlayMessage *toPlayers) | PubSubMMOG | protected |
| sendMessageToUDP(const TransportAddress &dest, cPacket *msg, simtime_t delay=SIMTIME_ZERO) | BaseOverlay | virtual |
| sendPingToChildren() | PubSubMMOG | protected |
| sendRouteRpcCall(CompType destComp, const TransportAddress &dest, const OverlayKey &destKey, BaseCallMessage *msg, cPolymorphic *context=NULL, RoutingType routingType=DEFAULT_ROUTING, simtime_t timeout=-1, int retries=0, int rpcId=-1, RpcListener *rpcListener=NULL) | BaseRpc | inlineprotected |
| sendRouteRpcCall(CompType destComp, const OverlayKey &destKey, BaseCallMessage *msg, cPolymorphic *context=NULL, RoutingType routingType=DEFAULT_ROUTING, simtime_t timeout=-1, int retries=0, int rpcId=-1, RpcListener *rpcListener=NULL) | BaseRpc | inlineprotected |
| sendRouteRpcCall(CompType destComp, const TransportAddress &dest, BaseCallMessage *msg, cPolymorphic *context=NULL, RoutingType routingType=DEFAULT_ROUTING, simtime_t timeout=-1, int retries=0, int rpcId=-1, RpcListener *rpcListener=NULL) | BaseRpc | inlineprotected |
| sendRpcResponse(TransportType transportType, CompType destComp, const TransportAddress &dest, const OverlayKey &destKey, BaseCallMessage *call, BaseResponseMessage *response) | BaseRpc | protected |
| sendRpcResponse(BaseCallMessage *call, BaseResponseMessage *response) | BaseRpc | protected |
| sendRpcResponseToLastHop | BaseOverlay | protected |
| sendTcpData(cPacket *msg, TransportAddress address) | BaseTcpSupport | protected |
| sendToKey(const OverlayKey &key, BaseOverlayMessage *message, int numSiblings=1, const std::vector< TransportAddress > &sourceRoute=TransportAddress::UNSPECIFIED_NODES, RoutingType routingType=DEFAULT_ROUTING) | BaseOverlay | |
| sendUdpRpcCall(const TransportAddress &dest, BaseCallMessage *msg, cPolymorphic *context=NULL, simtime_t timeout=-1, int retries=0, int rpcId=-1, RpcListener *rpcListener=NULL) | BaseRpc | inlineprotected |
| setBootstrapedIcon() | PubSubMMOG | protected |
| setOverlayReady(bool ready) | BaseOverlay | protected |
| setTcpOut(cGate *gate) | BaseTcpSupport | inlineprotected |
| showOverlayNeighborArrow(const NodeHandle &neighbor, bool flush=true, const char *displayString=NULL) | TopologyVis | |
| SHUTDOWN enum value | BaseOverlay | |
| singleHopDelays | BaseOverlay | protected |
| socketDataArrived(int connId, void *yourPtr, cPacket *msg, bool urgent) | BaseTcpSupport | virtual |
| socketEstablished(int connId, void *yourPtr) | BaseTcpSupport | virtual |
| socketFailure(int connId, void *yourPtr, int code) | BaseTcpSupport | virtual |
| socketPeerClosed(int connId, void *yourPtr) | BaseTcpSupport | virtual |
| socketStatusArrived(int connId, void *yourPtr, TCPStatusInfo *status) | BaseTcpSupport | inlinevirtual |
| startTimer(PubSubTimer *timer) | PubSubMMOG | protected |
| state | BaseOverlay | protected |
| States enum name | BaseOverlay | |
| subscribedSubspaces | PubSubMMOG | protected |
| subspaceSize | PubSubMMOG | protected |
| takeOverNewSubspace(PubSubSubspaceId subspaceId) | PubSubMMOG | protected |
| takeOverSubspace(PubSubSubspaceResponsible &subspaceId, bool isNew) | PubSubMMOG | protected |
| thisCompType | BaseRpc | protected |
| thisNode | BaseRpc | protected |
| thisTerminal | TopologyVis | protected |
| TopologyVis() | TopologyVis | |
| underlayConfigurator | BaseOverlay | protected |
| unsubscribeChild(const NodeHandle &node, PubSubSubspaceResponsible &subspace) | PubSubMMOG | protected |
| useCommonAPIforward | BaseOverlay | protected |
| ~BaseOverlay() | BaseOverlay | virtual |
| ~PubSubMMOG() | PubSubMMOG | virtual |
| ~RpcListener() | RpcListener | virtual |