▼NExitGames | |
►NCaching | |
CCachedFunc | |
CCachedFuncBase | |
CCacheItem | |
CFuncParams | |
►NConcurrency | |
►NChannels | |
CBaseSubscription | Base implementation for subscription |
CBatchSubscriber | Batches actions for the consuming thread |
CChannel | Default Channel Implementation. Methods are thread safe. /summary> typeparam name="T"> |
CChannelSubscription | Subscription for actions on a channel |
CIChannel | A channel provides a conduit for messages. It provides methods for publishing and subscribing to messages. The class is thread safe |
CIProducerThreadSubscriber | Action subscriber that receives actions on producer thread |
CIPublisher | Channel publishing interface |
CIQueueChannel | Creates a queue that will deliver a message to a single consumer. Load balancing can be achieved by creating multiple subscribers to the queue |
CIReply | Used to receive one or more replies |
CIReplySubscriber | Methods for working with a replyChannel |
CIRequest | A request object that can be used to send 1 or many responses to the initial request |
CIRequestPublisher | |
CIRequestReplyChannel | Typed channel for request/reply |
CISnapshotChannel | An ISnapshotChannel is a channel that allows for the transmission of an initial snapshot followed by incremental updates. The class is thread safe. /summary> typeparam name="T"> |
CISubscribable | Callback method and parameters for a channel subscription |
CISubscriber | Channel subscription methods |
CKeyedBatchSubscriber | Channel subscription that drops duplicates based upon a key |
CLastSubscriber | Subscribes to last action received on the channel |
CQueueChannel | Default QueueChannel implementation. Once and only once delivery to first available consumer |
CRequestReplyChannel | Channel for synchronous and asynchronous requests |
CSnapshotChannel | A SnapshotChannel is a channel that allows for the transmission of an initial snapshot followed by incremental updates. The class is thread safe. /summary> typeparam name="T"> |
►NCore | |
CBoundedQueue | Queue with bounded capacity. Will throw exception if capacity does not recede prior to wait time |
CBusyWaitQueue | Busy waits on lock to execute. Can improve performance in certain situations |
CDefaultExecutor | Default executor |
CDefaultQueue | Default implementation |
CDefaultThreadPool | Default implementation that uses the .NET thread pool |
CIExecutionContext | Context of execution |
CIExecutor | Executes pending action(s) |
CIPendingEvent | A scheduled event |
CIQueue | Holds on to actions until the execution context can process them |
CIScheduler | Methods for scheduling actions that will be executed in the future |
CISchedulerRegistry | Enqueues actions and |
CISubscriptionRegistry | Allows for the registration and deregistration of subscriptions /summary> |
CIThreadPool | A thread pool for executing asynchronous actions |
CQueueFullException | Thrown when a queue is full |
CScheduler | Enqueues actions on to context after schedule elapses. /summary> |
►NFibers | |
CDispatcherFiber | Adapts Dispatcher to a Fiber. Transparently moves actions onto the Dispatcher thread |
CEmptyCounter | |
CExtendedPoolFiber | PoolFiber which supports pausing |
CFormFiber | Allows interaction with Windows Forms. Transparently moves actions onto the Form's thread. /summary> |
CGuiFiber | Allows interaction with Windows Forms. Transparently moves actions onto the Form's thread. /summary> |
CIExtendedExecutor | Extended executor should support pausing |
CIExtendedFiber | |
CIFiber | Enqueues pending actions for the context of execution (thread, pool of threads, message pump, etc.) |
CPoolFiber | Fiber that uses a thread pool for execution |
CStubFiber | StubFiber does not use a backing thread or a thread pool for execution. Actions are added to pending lists for execution. These actions can be executed synchronously by the calling thread. This class is not thread safe and should not be used in production code |
CStubScheduledAction | For use only in testing. Allows for controlled execution of scheduled actions on the StubFiber. /summary> |
CThreadFiber | Fiber implementation backed by a dedicated thread. IFiber |
►NConfiguration | |
CConfigurationException | A configuration exception |
CNameValueCollectionReader | Reads values from a NameValueCollection |
CProfileReader | This class reads a configuration section for a profile name and merges it with profile section 'Common' |
►NDiagnostics | |
►NConfiguration | |
CCaseInsensitiveEnumConfigConverter | |
CCounterSampleSenderSettings | |
CGraphiteTextWriterSettings | |
CInfluxDB090TextWriterSettings | |
CPacketWriterSettings | |
CPhotonBinaryWriterSettings | |
CStatsDWriterSettings | |
►NCounter | |
CAverageCounter | The average counter |
CCounterBase | The base class for counters |
CCounterSample | Represents the value of a counter calculated at a specific time |
CCountsPerSecondCounter | The counts per second rate counter |
CDummyCounter | A dummy counter that does nothing |
CICounter | Represents a counter instance |
CNumericCounter | A numeric counter |
CPerformanceCounterReader | A read only ICounter that wraps a windows PerformanceCounter |
CRawCounterSample | Defines a structure that holds the raw data for a performance counter |
CWindowsPerformanceCounter | An ICounter that wraps a windows PerformanceCounter |
►NCounterData | |
CCounterDataSet | |
CCounterDataSetCategory | |
CCounterDataSetCounter | |
CCounterInstanceDataBase | |
CCounterInstanceKey | |
CCounterInstanceValue | |
CCounterInstanceValueList | |
CCounterValue | Contains the value for a counter at a specified time stamp |
CICounterInstanceData | |
►NInternal | |
CCategoryPublisher | |
CPerformanceCounterId | |
►NMessaging | |
CCounterDataSetReceiver | |
CCounterDataSetSender | |
CCounterPublisherBase | |
CICounterPublisher | |
CPerformanceCounterCategoryPublisher | |
CPerformanceCounterPublisher | |
►NMonitoring | |
►NProtocol | |
►NGraphite | |
►NText | |
CGraphiteTextWriter | Graphite text protocol writer http://graphite.wikidot.com/getting-your-data-into-graphite metric_path value timestamp |
►NInfluxDB090 | |
►NGraphite | |
►NText | |
CGraphiteTextWriter | Graphite text protocol writer http://graphite.wikidot.com/getting-your-data-into-graphite metric_path value timestamp |
►NPhoton | |
►NBinary | |
CPhotonBinaryReader | |
CPhotonBinaryWriter | |
►NStatsD | |
►NText | |
CStatsDTextWriter | StatsD Metric Types https://github.com/etsy/statsd/blob/master/docs/metric_types.md https://github.com/b/statsd_spec |
CICounterSampleReader | |
CICounterSampleWriter | |
CPhotonBinaryWriterBase | |
CCounterFactory | Provides methods to create ICounter instances |
CCounterSampleCollection | A collectin of CounterSamples |
CCounterSampleMessage | A message used by the CounterSamplePublisher |
CCounterSamplePublisher | Collects and publishes data from ICounter instances in a specified interval |
CCounterSamplePublisherFactory | A factory for CounterSamplePublishers |
CCounterSampleReceiver | A receiver of CounterSamplesPackages |
CCounterSampleSender | Collects data from ICounter instances and publishes the data in a specified interval using an ISocketSender implementation |
CCounterSampleSenderBase | Collects data from ICounter instances and publishes the data in a specified interval using an ICounterSampleWriter implementation |
CCounterSamplesPackage | Argument for event CounterSampleReceiver.OnCounterDataReceived and message type for CounterSampleReceiver.Channel |
CCounterSetAttribute | Attribute to set a name for a group of counters |
CPerformanceCounterWatcher | This class monitors the windows performance counters for new instances |
CPublishCounterAttribute | Attribute for ICounter fields or properties to publish with the CounterSamplePublisher |
►NExtensions | |
CDateTimeExtensions | Date time extension methods |
►NIO | |
CBigEndianBinaryReader | DataInputStreamWrapper provides functions to Read binary data from a stream |
CBigEndianBinaryWriter | Provides methods to write binary data into a stream |
CBinaryConverter | This class converts binary data to streams and vice versa and de-/serialzes objects with the BinaryFormatter |
CIBinaryReader | Interface for a binary reader |
CIBinaryWriter | The interface for a binary writer |
►NLogging | |
►NLog4Net | |
CLog4NetLogger | An ILogger that wraps log4net ILog |
CLog4NetLoggerFactory | This ILoggerFactory creates ILogger that log to the log4net framework |
CILogger | Interface for a logger |
CILoggerFactory | The implementor creates ILogger instances |
CLogManager | The log manager provides methods to get instances of ILogger using a ILoggerFactory. Any logging framework of choice can be used by assigining a new ILoggerFactory with SetLoggerFactory. The default logger factory creates ILogger that do not log |
►NMessaging | |
►NChannels | |
CChannel | A Concurrency.Channels.Channel<T> implementing the IChannel<T> |
CGenericSerializer | An IMessageSerializer<T> that uses the IO.BinaryConverter to serialze any message type |
CIChannel | An Concurrency.Channels.IChannel<T> implementing the IPublisher<T> interface |
CIMessageQueue | The implementor stores messages of type T |
CIMessageSerializer | The implementor converts a message to a byte array and back. The IMessageSerializer<T> is used to de-/serialize messages to the TopicPublisher<T> and the TopicSubscription<T> |
CIPublisher | An Concurrency.Channels.IPublisher<T> with an additional Publish method that includes a host id. The host id is included to identify and filter received messages that were sent from the same host |
CLockedMessageQueue | The LockedMessageQueue<T> is a thread safe extension of the MessageQueue<T> |
CMessageQueue | This class collects messages from a Channel<T> for later use, for example for a http client |
CSubscriptionContainer | A container for IChannel<T> subscriptions with a topic |
CTopicChannel | this class is a hybrid between TopicSubscription<T> and TopicPublishChannel<T>: it sends locally published messages through a ISocketSender and receives remote messages through the TopicMessageReceiver |
CTopicChannelFactory | A factor for TopicChannel<T>s |
CTopicMessage | This stuct is sent through the socket |
CTopicMessageReceiver | The TopicMessageReceiver receives TopicMessages from an ISocketReceiver |
CTopicPublishChannel | A Concurrency.Channels.IChannel<T> wrapper that extends class TopicPublisher<T> |
CTopicPublisher | This is a IPublisher<T> wrapper that sends all messages as TopicMessage to a ISocketSender |
CTopicSubscription | A topic subscription receives TopicMessages and filters them by a topic string. The payload of the remainging messages are deserialized with a IMessageSerializer<T> and published on a Concurrency.Channels.IPublisher<T> (typically a Concurrency.Channels.Channel<T>) |
CMessageQueueException | message queue exception |
CMessageQueueReader | Reads messages from MessageQueues, dispatches them, and checks for dispatch timeouts |
CMessageQueueReaderSingleThreaded | Reads messages from MessageQueues and dispatches them |
CThrottledMessageQueue | The throttled message queue |
CThrottledMessageQueueReader | This class can read multiple message queues and dispatch the messages of each queue with a different priority |
►NNet | |
►NSockets | |
►NHttp | |
CHttpSender | |
►NPgm | |
CPgmBase | Base class for Pgm sender and receiver implemenatations |
CPgmListener | The PGM listener receives PGM messages from one or more network interfaces. This class is used internally by the PgmReceiver |
CPgmReceiver | This PGM receiver is a ISocketReceiver implementation that wraps a PgmListener |
CPgmSender | Provides methods to send data using the Pragmatic General Multicast (PGM) protocol |
CPgmSenderPool | A pool of PgmSenders |
CPgmSendWindowSize | The RM_SEND_WINDOW structure specifies the Reliable Multicast send window. This structure is used with the RM_RATE_WINDOW_SIZE socket option |
CPgmSocket | A socket for PGM |
CPgmSocketReceiver | This ISocketReceiver wraps a Sockets.PooledReceiver and uses a Pgm.PgmReceiver |
CPgmSocketSender | This ISocketSender wraps a Sockets.PooledSender and uses a Pgm.PgmSender |
►NStub | |
CStubReceiver | An ISocketReceiver implementation for unit testing |
CStubSender | An ISocketSender implementation for unit testing |
►NUdp | |
CUdpReceiver | An ISocketReceiver implementation for UDP |
CUdpSender | An ISocketSender implementation for UDP |
CAsyncSocketReceiver | The AsyncSocketReceiver receives data from a socket using the asynchronous programming model including IO completion ports |
CBinaryBuffer | binary buffer |
CISocketReceiver | Interface for a class that receives data from a socket |
CISocketSender | Interface for a class that sends data to a socket |
CPooledReceiver | This ISocketReceiver wrapper dispatches received data async with the .NET thread pool |
►CPooledSender | This ISocketSender wrapper is used to send the data async using a the .NET thread pool. An optional settings allows the PooledSender to send multiple messages in a batch |
CSendErrorEventArgs | The event args for event SendError |
CSocketAcceptEventArgs | The socket accept event args. Used by the PgmReceiver |
CSocketDisconnectEventArgs | The socket disconnect event args. Used by the PgmReceiver |
CSocketEndPoint | |
CSocketReceiveEventArgs | The socket receive event args |
CIPAddressCollection | The IP address collection |
►NThreading | |
►NCachedSingletonFactory | |
CCachedSingletonFactoryAbsolute | A SynchronizedCachedSingletonFactory<TKey,TValue> for absolute caching |
CCachedSingletonFactorySliding | A SynchronizedCachedSingletonFactory<TKey,TValue> for sliding caching |
CCacheKey | A key used by the SynchronizedCachedSingletonFactory<TKey, TValue> |
CCacheValue | A value used by the SynchronizedCachedSingletonFactory<TKey, TValue> |
CSynchronizedCachedSingletonFactory | A SynchronizedSingletonFactory<TKey,TValue> that uses the ASP.NET cache. It offers limited lifetime for items and requires no locking to access items that are cached. The subclasses support sliding and absolute timeouts |
CAsyncResult | async result |
CBeforeAfterExecutor | |
CBlockingQueue | This class is a Queue<T> wrapper that waits at Dequeue() until an item becomes available |
CExtendedBeforeAfterExecutor | |
CExtendedFailSafeExecutor | |
CFailSafeBatchExecutor | An IExecutor that can be used for a PoolFiber to catch and log or forward exceptions that happen during execution |
CLock | This IDisposable uses the Monitor class. It is used to replaces try-finally blocks with "using" statements |
CLockTimeoutException | This exception type is thrown if a timeout occurs when creating an instance of Lock, ReadLock, WriteLock or UpgradeableReadLock |
CReadLock | This IDisposable uses the ReaderWriterLockSlim for critical sections that allow one writer and multiple reader. The counter parts are WriteLock and UpgradeableReadLock. It is used to replaces try-finally blocks with "using" statements |
CSimpleBaseFactory | A base class for a simple factory using a ReaderWriterLockSlim |
CSynchronizedDictionary | Represents a thread-safe collection of key-value pairs that can be accessed by multiple threads concurrently. If using the Net 4.0 framework you should consider to use the new System.Collections.Concurrent.ConcurrentDictionary. The SynchronizedDictionary provides methods similar to the ConcurrentDictionary to provide a thread safe Dictionary for .NET 3.5 and earlier |
CSynchronizedSingletonFactory | This class is used to create instances that are unique per key in a multi-threaded environment. It uses a ReaderWriterLockSlim for read and write access to the Instances. Instance creations are synchronized with a Monitor on an object that is unique per key. This approach is designed to minimize the impact of long running instance creations on other threads |
CTimer | This class is a manager for scheduled callbacks |
CUnsynchronizedSingletonFactory | This class is used to create instances that are unique per key |
CUpgradeableReadLock | This IDisposable uses the ReaderWriterLockSlim for critical sections that allow one writer and multiple reader. The counter parts are WriteLock and ReadLock. It is used to replaces try-finally blocks with "using" statements |
CWriteLock | This IDisposable uses the ReaderWriterLockSlim for critical sections that allow one writer and multiple reader. The counter parts are ReadLock and UpgradeableReadLock. It is used to replaces try-finally blocks with "using" statements |
▼NPhoton | |
►NCommon | |
►NAuthentication | |
►NConfiguration | |
►NAuth | |
CAuthProvider | |
CAuthProviderCollection | |
CAuthSettings | |
►NCustomAuthentication | |
CAsyncHttpResponse | |
►CClientAuthenticationQueue | |
CRoundRobinCounter | |
CCustomAuthenticationResult | |
CCustomAuthenticationResultCode | |
►NDiagnostic | |
►CCustomAuthResultCounters | |
CInstance | |
CNullInstance | |
CHttpRequestQueueCounters | |
CHttpRequestQueueCountersFactory | |
CIHttpRequestQueueCountersFactory | |
CAuthenticationToken | |
CAuthSettings | Represents the result from the authenticaton handler (i.e., from the account service) |
CAuthTokenFactory | |
CCustomAuthHandler | |
CErrorMessages | |
CIAuthenticateRequest | |
CICustomAuthPeer | |
CSettings | |
►NLoadBalancer | |
►NCommon | |
CIpEndPointExtensions | |
CPublicIPAddressReader | |
►NLoadShedding | |
►NDiagnostics | |
CCounter | Counter on Game Server application level |
CAverageCounterReader | |
CWorkloadController | |
CLoadBalancer | Represents a collection of server instances which can be accessed randomly based on their current lod level |
CServerStateManager | |
►NMisk | |
CUnknownTypeMapper | |
►NPlugins | |
►NConfiguration | |
CGenericPluginSettings | Class helper, which helps automate plugin settings initialization |
CPluginElement | |
CPluginElementCollection | |
CPluginSettings | |
CAssemblyResolver | |
CIPluginManager | |
CPluginInfo | |
CPluginManagerBase | |
►NCounterPublisher | |
CApplication | The application |
CSocketServerCounter | The socket server counter |
►CSocketServerCounterSchema | |
CCLR | |
CCommon | |
CEnet | |
CPolicy | |
CS2S | |
CTcp | |
CThreading | |
CUdp | |
►CSystemCounter | The system counter |
CNetworkInterfaceCounter | |
►NHive | |
►NCaching | |
CEventCache | A cache for events that a stored for actors that join a game later. The key is the event code, the value the event content. The event cache is ordered by event code |
CEventCacheDictionary | Dictionary implementation to store EventCache instances by actor number |
CHiveGameCache | The cache for HiveGames |
►CRoomCacheBase | Base class for room caches |
CRoomInstance | Used to track references for a room instance |
CRoomEventCache | |
CRoomReference | Used to observe references to room instances from a room cache. A reference to a room should be released (disposed) if it is not longer needed. The related cache observes the number of references to a room and removes a room if it has no references left |
►NCollections | |
CActorsManager | |
CGroupManager | |
CRoomEventCacheManager | |
►NCommon | |
CGameParameterReader | Provides methods to read build in game properties from a hashtable |
CHttpRequestQueueOptions | |
CUtilities | A collection of methods useful in one or another context |
►NConfiguration | |
CPluginElement | |
CPluginElementCollection | |
CPluginSettings | |
►NDiagnostics | |
►NOperationLogging | |
CLogEntry | |
CLogQueue | |
CCounter | Counter on application level |
CCounterLogger | Logs the most intersting counters into a log file |
CIHiveGameAppCounters | |
CNullHiveGameAppCounters | |
►NEvents | |
CCacheSliceChanged | Implementation if the PropertiesChanged event |
CCustomEvent | Implementation of a custom event |
CDisconnectEvent | |
CErrorInfoEvent | |
CHiveEventBase | Base class implementation for all Lite events |
CJoinEvent | This class implements the Join event |
CLeaveEvent | This class implements the Leave event |
CPropertiesChangedEvent | Implementation if the PropertiesChanged event |
►NMessages | |
CIMessage | Interface of a message |
CRoomMessage | Represents a message for rooms |
►NOperations | |
CChangeGroups | |
CCloseRequest | |
CCreateGameRequest | |
CCreateGameResponse | Defines the response paramters for create game requests |
CDebugGameRequest | |
CDebugGameResponse | |
CGetPropertiesRequest | The get properties request |
CGetPropertiesResponse | Response for GetPropertiesRequest |
CHiveErrorMessages | |
CJoinGameRequest | This class implements the Join operation |
CJoinGameResponse | |
CJoinModes | |
CJoinResponse | Response for JoinGameRequest |
CLeaveRequest | Implements the Leave operation |
CRaiseEventRequest | Implements the RaiseEvent operation |
CSetPropertiesRequest | The set properties operation |
►NPlugin | |
CBeforeCloseGameCallInfo | |
CBeforeJoinGameCallInfo | |
CBeforeSetPropertiesCallInfo | |
CCallCounter | |
CCallEnv | |
CCallInfo | |
CCloseGameCallInfo | |
CCreateGameCallInfo | |
CDisconnectCallInfo | |
CIPluginInstance | |
CIPluginManager | |
CJoinGameCallInfo | |
CLeaveGameCallInfo | |
CPluginInstance | |
CPluginManager | |
CPluginTraits | |
CRaiseEventCallInfo | |
CSetPropertiesCallInfo | |
CSetPropertiesFailedCallInfo | |
CTypedCallInfo | |
►NSerialization | |
CSerializer | |
►NTestConsole | |
CProgram | The program |
►NTests | |
►NClient | |
CTestClient | The test client |
►NDisconnected | |
CBasicUseCases | The basic use cases |
CDummyApplicationSink | TODO: Update summary |
CDummyPeer | The network peer dummy |
CLogHelper | The log helper |
CServerToServerTests | The s2s tests |
CSettings | The settings |
CSetupFixture | The setup fixture |
CTcpPerformanceTests | The tcp performance tests |
CTcpTests | The test base |
CTcpTestsBase | The tcp tests base |
CTestActor | |
CTestActorsManager | |
CTestGame | |
CTestGameCache | |
CTestGameState | |
CTestHivePeer | |
CTestPlugin | |
CTestPluginManager | |
►NWebRpc | |
►NConfiguration | |
CWebRpcBaseUrlElement | |
CWebRpcExtraParamsCollection | |
CWebRpcSettings | |
CIRpcHandlerAppCounters | |
CWebRpcHandler | |
CWebRpcRequest | |
CActor | An actor is the glue between HivePeer and Room. In addition to the peer it has a number and Properties |
CActorExtension | |
CActorGroup | |
CGameState | |
CHiveApplication | Main photon application. This application is started from the photon server. This class creates HivePeers for new clients. Operation dispatch logic is handled by the HivePeer |
CHiveGame | A Room that supports the following requests:
|
CHiveHostGame | |
►CHivePeer | Inheritance class of PeerBase. The LitePeer dispatches incoming OperationRequests at OnOperationRequest. When joining a Room a Caching.RoomReference is stored in the RoomReference property. An IFiber guarantees that all outgoing messages (events/operations) are sent one after the other |
CJoinStages | |
CHttpResponseImpl | |
CIGameStateFactory | |
►CRoom | A room has Actors, can have properties, and provides an ExecutionFiber with a few wrapper methods to solve otherwise complicated threading issues: All actions enqueued to the ExecutionFiber are executed in a serial order. Operations of all Actors in a room are handled via ExecutionFiber |
CDefaultGameStateFactory | |
►NLoadBalancing | |
►NCommon | |
CDictionaryExtensions | |
CLBErrorMessages | |
►CNodesReader | |
CNodeEventArgs | |
COperationHandlerBase | Provides basic methods for IOperationHandler implementations |
CS2SCustomTypeCacheMan | |
►NEvents | |
CAppStatsEvent | |
CGameListEvent | |
CGameListUpdateEvent | |
CGameServerOfflineEvent | |
CMatchEvent | |
CQueueEvent | |
►NGameServer | |
CApplicationStatsPublisher | |
CGame | |
CGameApplication | |
CGameCache | |
CGameClientPeer | |
CGameServerSettings | |
CGlobal | |
CMasterServerConnection | |
CMasterServerConnectionBase | |
COutgoingMasterServerPeer | |
►NLoadShedding | |
CILatencyMonitor | |
CLatencyMonitor | |
CLatencyOperation | |
CLatencyPeer | Peer implementation to handle requests from the LatencyMonitor |
►NMaster | |
►NOperationHandler | |
COperationHandlerAuthenticating | |
COperationHandlerDefault | |
COperationHandlerInitial | |
►NMasterServer | |
►NChannelLobby | |
►CGameChannel | |
CSubscription | |
CGameChannelKey | |
CGameChannelList | |
►NGameServer | |
CGameServerCollection | |
CGameServerState | |
CIncomingGameServerPeer | |
►NLobby | |
CAppLobby | |
CAsyncRandomGameList | |
CGameList | |
CGameListBase | |
CGameState | |
CGameTable | |
CIGameList | |
CIGameListSubscription | |
CILobbyPeer | |
CLinkedListDictionary | |
CLobbyFactory | |
CLobbyStatsPublisher | |
CPeerState | Stores properties of peers which have joined a game |
CSqlGameList | |
CApplicationStats | |
CGameApplication | |
CMasterApplication | |
CMasterClientPeer | |
CMasterServerSettings | |
COperationHelper | Provides static methods to validate operation requests and create operation responses for invalid operation request |
CPlayerCache | |
CPlayerState | |
CRedirectedClientPeer | |
►NOperations | |
CAuthenticateRequest | |
CAuthenticateResponse | |
CFindFriendsRequest | |
CFindFriendsResponse | |
CGetLobbyStatsRequest | |
CGetLobbyStatsResponse | |
CJoinLobbyRequest | |
CJoinRandomGameRequest | |
CJoinRandomGameResponse | |
CRedirectRepeatResponse | |
►NServerToServer | |
►NEvents | |
CAuthenticateUpdateEvent | |
CRemoveGameEvent | |
CUpdateAppStatsEvent | |
CUpdateGameEvent | |
CUpdateServerEvent | |
►NOperations | |
CRegisterGameServer | Defines the parameters which should be send from game server instances to register at the master application |
CRegisterGameServerResponse | |
►NTestClient | |
►NConnectionStates | |
CGameServer | |
CMaster | |
CProgram | |
CSettings | |
►NUnifiedClient | |
►NAuthenticationSchemes | |
CTokenAuthenticationScheme | |
CTokenLessAuthenticationScheme | |
CUnifiedTestClient | |
►NUnitTests | |
►NOffline | |
CAsyncJoinOfflineTests | |
CLoadBalancingOfflineTests | |
COfflineSecureTests | |
CPluginOfflineTests | |
►NOnline | |
CLoadbalancingOnlineTests | |
COnlineSecureTests | |
CPluginOnlineTests | |
►NTestsImpl | |
CLBAsyncJoinTestImpl | |
CSecureTestsImpl | |
►NUnifiedServer | |
►NOfflineExtra | |
CTestApplication | |
CTestGame | |
CTestGameCache | |
CTestPluginManager | |
►NPolicy | |
CLBConnectPolicyBase | |
COfflineConnectPolicy | |
COnlineConnectPolicy | |
CLoadBalancingUnifiedTestsBase | |
►NUnifiedTests | |
CLBApiTestsImpl | |
CLoadBalancerTests | |
►CPluginTestsImpl | |
CCustomPluginType | |
CSetupFixture | |
►NMmoDemo | |
►NClient | |
►NWinGrid | |
CGameTabPage | The double buffered game tab page |
CLogAppender | |
CRadarTabPage | |
CSettings | |
CWorldForm | |
CGame | |
CIGameListener | |
CInterestArea | |
CItem | |
CMyItem | |
COperations | |
CSettings | |
CWorldData | |
►NCommon | |
CBoundingBox | The 3D floating point bounding box |
CProtocol | (De)serialization procedures used in server and client |
CVector | The 3D floating point vector |
►NServer | |
►NEvents | |
CCounterDataEvent | Clients receive this event after executing operation SubscribeCounter |
CItemDestroyed | Client receive this event after executing operation DestroyItem |
CItemGeneric | Clients receive this event after executing operation RaiseGenericEvent/> |
CItemMoved | Clients receive this event after executing operation Move |
CItemProperties | The client receives this event after executing operation GetProperties |
CItemPropertiesSet | Clients receive this event after executing operation SetProperties |
CItemSubscribed | Client receives this event when an item enters interest an area |
CItemUnsubscribed | Client receive this event when an item exits an interest area |
CRadarUpdate | Clients receive this event frequently after executing operation RadarSubscribe |
CWorldExited | Clients receive this event after exiting a world, either because of operation ExitWorld or because another client with the same username executes operation EnterWorld |
►NOperations | |
CAddInterestArea | The operation adds client's InterestArea |
CAddInterestAreaResponse | |
CAttachInterestArea | The operation attaches InterestArea to an Item |
CAttachInterestAreaResponse | |
CCreateWorld | The operation creates new world |
CCreateWorldResponse | |
CDestroyItem | The operation destroys Item |
CDestroyItemResponse | |
CDetachInterestArea | The operation detaches InterestArea from an Item |
CDetachInterestAreaResponse | |
CEnterWorld | The operation enters client into world |
CEnterWorldResponse | |
CGetProperties | The operation requests Item properties |
CGetPropertiesResponse | |
CMove | The operation moves an Item |
CMoveInterestArea | The operation moves an InterestArea |
CMoveInterestAreaResponse | |
CMoveResponse | |
CRadarSubscribe | This operation subscribes to Radar. It can be executed any time |
CRadarSubscribeResponse | |
CRaiseGenericEvent | This operation raises generic item event |
CRaiseGenericEventResponse | |
CRemoveInterestArea | The operation removes client's InterestArea |
CRemoveInterestAreaResponse | |
CSetProperties | The operation sets the properties of an Item |
CSetPropertiesResponse | |
CSetViewDistance | The oeration sets view distsance for InterstArea |
CSetViewDistanceResponse | |
CSpawnItem | The operation creates a new Item |
CSpawnItemResponse | |
CSubscribeCounter | The operation subscribes to the PhotonApplication.CounterPublisher. It can be executed any time |
CSubscribeItem | The operation subscribes an InterestArea to an Item.EventChannel |
CSubscribeItemResponse | |
CUnsubscribeItem | The operation unsubscribes an InterestArea from an Item.EventChannel after |
CUnsubscribeItemResponse | |
CClientInterestArea | This InterestArea subclass automatically subscribes to the region.ItemEventChannel of every region in focus and forwards item events to the PeerBase |
CCounterOperations | Handles the operations SubscribeCounter and UnsubscribeCounter |
CGridWorld | Grid used to divide the world. It contains Regions |
CInterestArea | Subscribes to regions in the area. Each region relays events of items in region. Thread safety: All instance members require a lock on SyncRoot |
CInterestItems | Maintains subscriptions per item (manual) |
CItem | Represents an entity in a world |
CItemCache | A cache for items. Each World has one item cache |
CItemDisposedMessage | This type of message is pubished by items sent through the item Item.DisposeChannel |
CItemEventMessage | This message type contains EventData to be sent to clients. ItemEventMessages are published through the item Item.EventChannel |
CItemPositionMessage | This message contains the current position of the Item. This type of message is published by items through the Item.PositionUpdateChannel |
CItemRegionChangedMessage | Item notifies interest areas via regions this item exits and enters |
CItemSnapshot | Copy of current Item's state |
CMessageCounters | Counters that keep track of the amount of messages sent and received from item channels |
CMethodReturnValue | Сombines an error code with a debug message |
CMmoActor | Represents a player in a world |
CMmoActorOperationHandler | Сlient's Peer.CurrentOperationHandler after entering a world |
CMmoInitialOperationHandler | Сlient's Peer.CurrentOperationHandler immediately after connecting |
CMmoPeer | Photon Peer |
CPhotonApplication | This ApplicationBase subclass creates MmoPeer and has a CounterSamplePublisher that is used to send diagnostic values to the client |
CRadar | Subscribers of the Radar's Channel receive event RadarUpdate for all moving Items in the World. The receive interval is configured with Settings.RadarUpdateInterval |
CRegion | Represents a region used for region-based interest management |
CRequestItemEnterMessage | Interest area requests all items in entered region |
CRequestItemExitMessage | Interest area requests all items in exited region |
CSettings | The settings |
CWorld | GridWorld with name, item cache and radar |
CWorldCache | This is a cache for Worlds that have a unique name |
►NTests | |
►NConnected | |
CClient | |
CHeavyLoad | |
COperations | |
COperationTests | |
CPeerListener | |
►NDisconnected | |
CClient | |
CDummyPeer | |
CGridWorldTests | |
CHeavyLoad | |
COperations | |
COperationTests | |
CSettings | |
CSetupFixture | |
►NSocketServer | |
►NAnnotations | |
CBaseTypeRequiredAttribute | When applied to a target attribute, specifies a requirement for any type marked with the target attribute to implement or inherit specific type or types |
CCanBeNullAttribute | Indicates that the value of the marked element could be null sometimes, so the check for null is necessary before its usage |
CCannotApplyEqualityOperatorAttribute | Indicates that the value of the marked type (or its derivatives) cannot be compared using '==' or '!=' operators and Equals() should be used instead. However, using '==' or '!=' for comparison with null is always permitted |
CInstantHandleAttribute | Tells code analysis engine if the parameter is completely handled when the invoked method is on stack. If the parameter is a delegate, indicates that delegate is executed while the method is executed. If the parameter is an enumerable, indicates that it is enumerated while the method is executed |
CMeansImplicitUseAttribute | Should be used on attributes and causes ReSharper to not mark symbols marked with such attributes as unused (as well as by other usage inspections) |
CNotNullAttribute | Indicates that the value of the marked element could never be null |
CPublicAPIAttribute | This attribute is intended to mark publicly available API which should not be removed and so is treated as used |
CPureAttribute | Indicates that a method does not make any observable state changes. The same as System.Diagnostics.Contracts.PureAttribute |
CStringFormatMethodAttribute | Indicates that the marked method builds string by format pattern and (optional) arguments. Parameter, which contains format string, should be given in constructor. The format string should be in string.Format(IFormatProvider,string,object[])-like form |
CUsedImplicitlyAttribute | Indicates that the marked symbol is used implicitly (e.g. via reflection, in external library), so this symbol will not be marked as unused (as well as by other usage inspections) |
►NCollections | |
CWaitableQueue | |
►NConcurrency | |
CActionQueue | This class is an IFiber wrapper. It ensures that async actions are exeucted in a serial manner |
CMessageChannel | Subclass of ExitGames.Concurrency.Channels.Channel<T>. Uses an ExitGames.Diagnostics.Counter.ICounter to track the amount of published messages |
CUnsubscriberCollection | This is a collection of channel subscriptions. Dispose unsubcribes all subscriptions |
►NDiagnostics | |
►NConfiguration | |
CCounterPublisherSchemaCollection | The counter publisher photon schema collection |
CCounterPublisherSchemaElement | The counter publisher photon schema element |
CCounterPublisherSettings | The counter publisher settings |
CPhotonSettings | The photon settings |
CCounterPublisher | The counter publisher |
CCpuUsageCounterReader | The process cpu usage counter |
CHttpQueuePerformanceCounters | |
CIHttpQueueCountersInstance | |
CIsAdminUtil | |
CPerfCounterManagerBase | |
CPhotonCounter | The photon counter |
CTimeIntervalCounter | |
CValueToString | |
►NNet | |
CAsyncHttpRequest | |
CHttpRequestQueue | |
CHttpRequestQueueCounterWrapper | we use this class to call external counters interface safely |
CIHttpRequestQueueCounters | |
►NRpc | |
►NProtocols | |
►NAmf3 | |
CAmf3Serializer | |
►NGpBinaryByteV2 | |
CGpBinaryByteReaderV2 | |
CCustomTypeCache | |
CCustomTypeInfo | |
CGlobalProtocolTraits | |
CRtsMessageHeader | The rts message header |
►NReflection | |
CObjectDataMemberMapper | Provides methods to get and set objects fields and properties per reflection |
CObjectMemberInfo | This class contains reflection data about a property or a field |
COperationAttribute | This attribute is used to mark methods to be reflected by the OperationDispatcher |
COperationDispatcher | This class contains functions to dispatch operations. The target function depends on the incoming operation code. All registered methods require the OperationAttribute and the signature public OperationResponse MyMethod(PeerBase peer, OperationRequest request, SendParameters sendParameters); |
COperationMethodInfoCache | This cache enables high performance mapping of operation codes to operations. It collaborates with the OperationDispatcher. Instances of this class should be reused if possible since the method registration is slower than the mapping. Registered methods must have the followig structure: |
►NValueTypes | |
CRawCustomArray | Instances of this class will be created for arrays of unknown custom types sent by a client if the Protocol.AllowRawCustomValues property is set to true |
CRawCustomValue | Instances of this class will be created for unknown custom types sent by a client if the Protocol.AllowRawCustomValues property is set to true |
CDataContract | This class is a common base class for all data contracts. Properties flagged with the DataMemberAttribute can be converted from/to a dictionary |
CDataContractAttribute | TODO: Classes flagged with this attribute can be used as data contract |
CDataMemberAttribute | When applied to the member of a type, specifies that the member is part of a data contract and should by serialized |
CIOperationHandler | Peer.CurrentOperationHandler is an IOperationHandler. The implementor handles incoming OperationRequests (Peer.OnOperationRequest, peer disconnects (Peer.OnDisconnect) and disconnects that are invoked from other peers (Peer.OnDisconnectByOtherPeer) |
COperation | This class is a common base class for operations that have properties flagged with the DataMemberAttribute |
CPeer | Inheritance class of PeerBase. This class uses an IOperationHandler that can be set with SetCurrentOperationHandler. This is useful if operations should have a different behavior when the state of the peer changes, e.g. after authentication |
►NSecurity | |
CDiffieHellmanKeyExchange | An implementation of the Diffie–Hellman key exchange. Diffie–Hellman establishes a shared secret that can be used for secret communications by exchanging data over a public network |
CICryptoProvider | Provides methods to encrypt and decrypt binary data |
CRijndaelCryptoProvider | An ICryptoProvider implementation using the Rijndael symmetric encryption algorithm |
►NServerToServer | |
CEventDataEventArgs | Provides data for the TcpClient.Event event |
CInboundS2SPeer | |
CInitializeEncryptionEventArgs | Contains information for a intiialize encryption operation response |
COperationResponseEventArgs | Provides data for the TcpClient.OperationResponse event |
COutboundS2SPeer | |
CPingResponse | The ping response |
CPingResponseEventArgs | Provides data for the TcpClient.PingResponse event |
CS2SPeerBase | The server peer base |
CSocketErrorEventArgs | Provides data for the TcpClient.ConnectError event |
CTcpClient | Provides methods to communicate with other photon server applications |
CTcpClientBase | Base class for Tcp client implementations |
►NWeb | |
CHttpApplicationHandler | IHttpAsyncHandler implementation to host photon applications in a web application |
CHttpApplicationHandler2 | IHttpAsyncHandler implementation to host photon applications in a web application |
CHttpClientBase | Photon http application client implementation |
CApplicationBase | The base class for a Photon application. The main method to override is CreatePeer. See Setup for initialization recommendations |
CClientPeer | |
CEventData | This class contains data that is sent to clients with PhotonPeer.SendEvent. The IRpcProtocol serializes EventData with SerializeEventData. SetParameters(object) converts properties that are flagged with DataMemberAttribute into the Parameters dictionary |
CIEventData | The implementation class contains data that is sent to clients with PeerBase.SendEvent(IEventData,SendParameters). Implementors are EventData and SerializedEventData |
CInitRequest | Provides initialization request parameter |
CInitResponse | Provides initialization request parameter |
CIRpcProtocol | The implementation class supports a specific real time server protocol |
CIUnknownTypeMapper | |
COperationRequest | Each incoming operation is translated to an OperationRequest. It is then dispatched with PeerBase.OnOperationRequest |
COperationResponse | Incoming OperationRequests are often answered with a response (represented by this class). It can be sent to the client by using the PeerBase.SendOperationResponse method. The IRpcProtocol.SerializeOperationResponse method serializes OperationResponse instances. SetParameters(object) converts properties that are flagged with DataMemberAttribute into the Parameters dictionary |
CPeerBase | This class is a base class for server connections. The RequestFiber processes all incoming messages |
CPeerHelper | This class provides access to some internal members of PeerBase and S2SPeerBase In general these methods are indended for testing |
CProtocol | This class provides access to the available protocols |
CSendParameters | The struct contains the parameters for PeerBase.SendOperationResponse(OperationResponse,SendParameters), PeerBase.SendEvent(IEventData,SendParameters) and S2SPeerBase.SendOperationRequest(OperationRequest,SendParameters) and contains the info about incoming data at PeerBase.OnOperationRequest, S2SPeerBase.OnEvent and S2SPeerBase.OnOperationResponse |
CSerializedEventData | An IEventData wrapper that serializes the event upon creation. This has a performance benefit if multiple receivers use the same protocol |
CDemoSettings | |
CFramesPerSecond | The fps |
CItemBehaviour | |
COnStartDelete | This component will destroy the GameObject it is attached to (in Start()) |
CRadar | |
CRoundTripTime | |
CRunBehaviour | The run behaviour |