▼NExitGames | |
►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 |
CDelegateAction | |
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 |
CNullAction | |
CQueueFullException | Thrown when a queue is full |
CScheduler | Enqueues actions on to context after schedule elapses. /summary> |
►NFibers | |
CEmptyCounter | |
CExtendedPoolFiber | PoolFiber which supports pausing |
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.) |
CIFiberAction | |
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 |
►NDiagnostics | |
►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 |
►NExtensions | |
CDateTimeExtensions | Date time extension methods |
CReflectionExtensions | Provides extension methods for the Type instances |
►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 |
CLoggerExtensions | |
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 |
►NMemory | |
CObjectPool | Simple implementation of pool for fiber actions |
CTLSObjectPool | Simple implementation of pool for fiber actions |
►NThreading | |
►NCachedSingletonFactory | |
CCacheKey | A key used by the SynchronizedCachedSingletonFactory<TKey, TValue> |
CCacheValue | A value used by the SynchronizedCachedSingletonFactory<TKey, TValue> |
CBeforeAfterExecutor | |
CBlockingQueue | This class is a Queue<T> wrapper that waits at Dequeue() until an item becomes available |
CExtendedBeforeAfterExecutor | Executor that can be paused/resumed and that executes actions before and after executing of actions batch |
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 |
CRegisterWaitHandleSafe | Helps safely unregister waithandles registered with RegisterWaitForSingleObject |
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 |
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 | |
►NAnnotations | |
CCanBeNullAttribute | Indicates that the value of the marked element could be null sometimes, so the check for null is necessary before its usage |
CNotNullAttribute | Indicates that the value of the marked element could never be null |
►NAuthentication | |
►NConfiguration | |
►NAuth | |
CAuthProvider | |
►CAuthSettings | |
CHttpQueueSettingsClass | |
►NCustomAuthentication | |
CAsyncHttpResponse | |
►CClientAuthenticationQueue | |
CCreateParam | |
CRoundRobinCounter | |
CCustomAuthenticationResult | |
CCustomAuthenticationResultCode | |
CCustomByteConverter | |
CIClientAuthenticationQueue | |
►NDiagnostic | |
CCustomAuthResultCounters | |
CHttpRequestQueueCounters | |
CHttpRequestQueueCountersFactory | |
CIHttpRequestQueueCountersFactory | |
►NEncryption | |
CEncryptionDataGenerator | |
CAuthenticationToken | |
CAuthOnInitHandler | |
CAuthSettings | Represents the result from the authentication handler (i.e., from the account service) |
CAuthTimeoutChecker | |
CAuthTokenFactory | |
►CCustomAuthHandler | |
CAuthQueueState | |
CResult | |
CResultCodes | |
CErrorMessages | |
CIAuthenticateRequest | |
CIAuthOnceRequest | |
CIAuthTimeoutCheckerClient | |
CICustomAuthPeer | |
CSettings | |
►NConfiguration | |
CHttpQueueSettings | |
►NLoadBalancer | |
►NCommon | |
CServerStateData | |
►NLoadShedding | |
►NConfiguration | |
CFeedbackControllerElement | |
CFeedbackLevelElement | |
►NDiagnostics | |
►NLinux | |
CLinuxBandwidthValuesReader | |
CLinuxBytesInCounterReader | |
CLinuxBytesOutCounterReader | |
CLinuxCPUReader | |
CBandwidthCounterReader | Provides information about network throughput |
CCounter | Counter on Game Server application level |
CCpuUsageCounterReader | The process cpu usage counter |
CWorkloadPerformanceCounters | |
CAverageCounterReader | |
CFeedbackLevelData | |
CWorkloadController | |
►NPrediction | |
►NConfiguration | |
CLoadPredictionSystemSection | |
CLoadPrediction | |
CLoadStatsCollector | |
CLoadBalancer | Represents a collection of server instances which can be accessed randomly based on their current lod level |
CServerStateManager | |
►NMisc | |
CIpEndPointExtensions | |
CPublicIPAddressReader | |
CUnknownTypeMapper | |
►NPlugins | |
►NConfiguration | |
CPluginElement | |
CPluginSettings | |
CAssemblyResolver | |
CHttpResponseImpl | |
CICallInfoImpl | |
CIPluginHttpUtilClient | |
CIPluginManager | |
CPluginAssemblyLoader | |
CPluginHttpUtil | |
CPluginInfo | |
CPluginLogger | |
CPluginManagerBase | |
►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 | |
CEventCacheException | |
CGroupManager | |
CRoomEventCacheManager | |
►NCommon | |
CGameHttpQueueSettings | Provides http queue settings that we set in game server config section |
CGameParameterReader | Provides methods to read build in game properties from a hashtable |
CLoggers | |
CUtilities | A collection of methods useful in one or another context |
CWellKnownProperties | |
►NConfiguration | |
CPluginElement | |
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 | we use CreateGameRequest only on master, because only on master it is allowed to NOT set GameId. it will be set automatically in this case on GS we use JoinGameRequest even in case of game creation. because it does not allow empty game Id |
CDebugGameRequest | |
CDebugGameResponse | |
CGetPropertiesRequest | The get properties request |
CGetPropertiesResponse | Response for GetPropertiesRequest |
CHiveErrorMessages | |
CJoinGameRequest | This class implements the Join operation |
CJoinModes | |
CJoinResponse | Response for JoinGameRequest |
CLeaveRequest | Implements the Leave operation |
CRaiseEventRequest | Implements the RaiseEvent operation |
CSetPropertiesRequest | The set properties operation |
►NPlugin | |
CBeforeCloseGameCallInfo | |
CBeforeJoinGameCallInfo | |
CBeforeSetPropertiesCallInfo | |
CCacheOp | set of properties to execute cache operation |
CCacheOperations | Related to RaiseEvent operation. Allows you to control room events events cache by setting the required option. Events are cached per event code and player: Event 100 (example!) can be stored once per player. Cached events can be modified, replaced and removed |
CCallCounter | |
CCallEnv | |
CCallInfo | |
CCallStatus | Status of the ICallInfo argument passed to plugin callbacks |
CCloseGameCallInfo | |
CCreateGameCallInfo | |
CDisconnectCallInfo | |
CEnqueueStatus | |
CEnvironmentVersion | Contains version of PhotonHivePlugin at build time and currently running |
CErrorCodes | Internal plugin errors codes |
CErrorPlugin | Special plugin that causes most callbacks to fail |
CExcludedActorInfo | A serializable container of exluded (explicitly removed) actor info |
CFactoryHost | |
CFactoryParams | |
CGameParameters | |
CHttpRequest | HTTP request to be sent |
CHttpRequestQueueResult | Codes returned as a result of process of queued HTTP request |
CIActor | Base interface of actor class inside the room |
CIBeforeCloseGameCallInfo | Base interface of argument passed to BeforeCloseGame callback |
CIBeforeJoinGameCallInfo | Base interface of argument passed to BeforeJoin callback |
CIBeforeSetPropertiesCallInfo | Base interface of argument passed to BeforeSetProperties plugin callback |
CICallInfo | Common/base interface of all arguments passed to plugin callbacks |
CICloseGameCallInfo | Base interface of argument passed to OnCloseGame callback |
CICloseRequest | Base interface of close request as sent by server |
CICreateGameCallInfo | Base interface of argument passed to OnCreateGame callback |
CIDisconnectCallInfo | Base interface of argument passed to OnDisconnect callback |
CIFactoryHost | |
CIGamePlugin | Base interface that should be implemented by any plugin class |
CIHttpResponse | Base interface of HTTP response |
CIJoinGameCallInfo | Base interface of argument passed to OnJoinGame callback |
CIJoinGameRequest | Base interface of Op Join request containing the parameters as sent by client |
CIJoinRequest | |
CILeaveGameCallInfo | Base interface of argument passed to OnLeave callback |
CILeaveGameRequest | Base interface of Op LeaveRoom request containing the parameters as sent by client |
CIOperationRequest | Base interface of all operation requests containing common parameters as sent by client |
CIPluginFactory | Base interface of plugin factory pattern |
CIPluginFactory2 | |
CIPluginFiber | |
CIPluginHost | Base interface that should be implemented as a wrapper of the game that is hosting the plugin instance |
CIPluginInstance | |
CIPluginLogger | Interface for a logger |
CIPluginManager | |
CIRaiseEventCallInfo | Base interface of argument passed to OnRaiseEvent plugin callback |
CIRaiseEventRequest | Base interface of Op RaiseEvent request containing the parameters as sent by client |
CISetPropertiesCallInfo | Base interface of argument passed to OnSetProperties plugin callback |
CISetPropertiesFailedCallInfo | Base interface of argument passed to OnSetPropertiesFailed callback |
CISetPropertiesRequest | Base interface of Op SetProperties request containing the parameters as sent by client |
CITypedCallInfo | |
CJoinGameCallInfo | |
CJoinModeConstants | Op JoinGame modes |
CLeaveGameCallInfo | |
CLeaveReason | Code of the reasons why a peer may leave a room |
CPluginBase | Base plugin class that should be extended to make custom ones |
CPluginFactoryBase | Base abstract class of plugin factory pattern |
CPluginFiber | |
CPluginInstance | |
CPluginLogger | |
CPluginManager | |
CPluginTraits | |
CPluginWrapper | |
CProcessJoinParams | Join options used in Photon.Hive.Plugin.IJoinGameCallInfo |
CProperty | The property |
CPropertyBag | The property bag |
CPropertyChangedEventArgs | The property changed event args |
CPropertyValueComparer | |
CRaiseEventCallInfo | |
CReciverGroup | Related to RaiseEvent operation. Lets you choose which actors in the room should receive events |
CRemoveActorReason | Reasons why an actor was excluded from a room: removed from actors list and added to excluded list. RemoveActorReason |
CRoomOptionFlags | |
CSendParameters | The struct contains the parameters for Photon.SocketServer.PeerBase.SendOperationResponse(Photon.SocketServer.OperationResponse,Photon.SocketServer.SendParameters), Photon.SocketServer.PeerBase.SendEvent(Photon.SocketServer.IEventData,Photon.SocketServer.SendParameters) and Photon.SocketServer.ServerToServer.S2SPeerBase.SendOperationRequest(Photon.SocketServer.OperationRequest,Photon.SocketServer.SendParameters) and contains the info about incoming data at Photon.SocketServer.PeerBase.OnOperationRequest(Photon.SocketServer.OperationRequest,Photon.SocketServer.SendParameters), Photon.SocketServer.ServerToServer.S2SPeerBase.OnEvent(Photon.SocketServer.IEventData,Photon.SocketServer.SendParameters) and Photon.SocketServer.ServerToServer.S2SPeerBase.OnOperationResponse(Photon.SocketServer.OperationResponse,Photon.SocketServer.SendParameters) |
CSerializableActor | A serializable room actor entry |
CSerializableGameState | A serializable snapshot of the room's full state |
CSetPropertiesCallInfo | |
CSetPropertiesFailedCallInfo | |
CTypedCallInfo | |
CWebFlags | Optional flags to be used in Photon client SDKs with Op RaiseEvent and Op SetProperties. Introduced mainly for webhooks 1.2 to control behavior of forwarded HTTP requests |
►NSerialization | |
CSerializer | |
►NWebRpc | |
►NConfiguration | |
►CWebRpcSettings | Section may look like this: |
CHttpQueueSettingsClass | specialization to set custom default values |
CIRpcHandlerAppCounters | |
CWebRpcHandler | |
CWebRpcManager | |
CWebRpcRequest | |
CWebRpcResponse | |
CActor | An actor is the glue between HivePeer and Room. In addition to the peer it has a number and Properties |
CActorExtension | |
CActorGroup | |
CGameCreateOptions | |
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 | |
CHttpResponseImpl | |
►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 | |
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 | |
CCommonSettings | |
CConnectionRequirementsChecker | Checks that client used connection with required properties |
CDictionaryExtensions | |
CGameRemoveReason | |
CLBErrorMessages | |
COperationHandlerBase | Provides basic methods for IOperationHandler implementations |
CS2SCustomTypeCacheMan | |
►NEvents | |
CAppStatsEvent | |
CGameListEvent | |
CGameListUpdateEvent | |
CGameServerOfflineEvent | |
CQueueEvent | |
►NGameServer | |
CApplicationStatsPublisher | |
CGame | |
CGameApplication | |
CGameCache | |
CGameClientPeer | |
►CGameServerSettings | |
►CGSLimitSettings | |
►CInboundLimitSettings | |
CEventCacheSettings | |
COperationSettings | |
CPropertiesLimitsSettings | |
CGSMasterSettings | |
CGSS2SSettings | |
CGameUpdatesBatcher | |
CGameUpdatesBatcherParams | |
CGameUpdatesBatchEvent | |
CLBGameCreateOptions | |
CMasterServerConnection | |
CMasterServerConnectionBase | |
COutgoingMasterServerPeer | |
►NMaster | |
►NOperationHandler | |
COperationHandlerAuthenticating | |
COperationHandlerInitial | |
►NMasterServer | |
►NChannelLobby | |
►CGameChannel | |
CSubscription | |
CGameChannelKey | |
CGameChannelList | |
►NGameServer | |
CGameServerAddressInfo | |
CGameServerContext | |
►CGameServerContextManager | |
CContextKeeper | |
CIGameServerPeer | |
CIncomingGameServerPeer | |
CReplicationAssistant | |
CReplicationAssistantBase | |
►NLobby | |
CAppLobby | |
CAsyncRandomGameList | |
CDeferredUser | |
CGameList | |
CGameListBase | |
CGameState | |
CGameSubscriptionBase | |
CGameTable | |
CIGameList | |
CIGameListSubscription | |
CILobbyPeer | |
CLimitedGameList | |
CLinkedListDictionary | |
CLobbyFactory | |
CLobbyStatsPublisher | |
CPeerState | Stores properties of peers which have joined a game |
CSqlFilterGameList | |
CSqlGameList | |
►NOperationHandler | |
COperationHandlerDefault | |
CApplicationStats | |
CGameApplication | |
CMasterApplication | |
CMasterClientPeer | |
►CMasterServerSettings | |
CMSGameServerSettings | |
►CMSLimitSettings | |
CInboundLimitSettings | |
CLobbySettings | |
CMSS2SSettings | |
COperationHelper | Provides static methods to validate operation requests and create operation responses for invalid operation request |
CPlayerCache | |
►CPlayerState | |
CSessionInfo | |
►NOperations | |
CAuthenticateRequest | |
CAuthenticateResponse | |
CCreateGameResponse | Defines the response paramters for create game requests |
CFindFriendsOptions | |
CFindFriendsRequest | |
CFindFriendsResponse | |
CGetGameListRequest | |
CGetGameListResponse | |
CGetLobbyStatsRequest | |
CGetLobbyStatsResponse | |
CJoinGameResponse | used by master code and by tests to not create extra overloads for JoinGame methods |
CJoinGameResponseBase | |
CJoinLobbyRequest | |
CJoinRandomGameRequest | |
CJoinRandomGameResponse | |
CRedirectRepeatResponse | |
CSettingsRequest | |
CSettingsRequestParameters | |
►NServerToServer | |
►NEvents | |
CRemoveGameEvent | |
CReplicationHelperEvent | |
CUpdateAppStatsEvent | |
CUpdateGameEvent | |
CUpdateServerEvent | |
►NOperations | |
CIRegisterGameServer | |
CRegisterGameServer | Defines the parameters which should be send from game server instances to register at the master application |
CRegisterGameServerDataContract | |
CRegisterGameServerInitResponse | |
CRegisterGameServerResponse | |
CReplicationId | |
►NNameServer | |
►NConfiguration | |
CConfigurationLoader | |
CNode | The node config |
CNodeList | |
CServerConfig | |
►NDiagnostic | |
CErrorMessages | |
►NOperations | |
CAuthenticateRequest | |
CAuthenticateResponse | |
CAuthOnceRequest | |
CGetRegionListRequest | |
CGetRegionListResponse | |
CClientPeer | |
CConnectionRequirementsChecker | |
CMasterServerCache | |
CPhotonApp | |
CPhotonEndpointInfo | |
CSettings | |
►NSocketServer | |
►NAnnotations | |
CCanBeNullAttribute | Indicates that the value of the marked element could be null sometimes, so the check for null is necessary before its usage |
CNotNullAttribute | Indicates that the value of the marked element could never be null |
CSettingsMarker | we apply this marker to settings classes in order to generate default configuration based on them |
►NConcurrency | |
CActionQueue | This class is an IFiber wrapper. It ensures that async actions are executed in a serial manner |
CCPUResourceManager | |
CDefaultFiberFactory | |
CIFiberFactory | |
►NConfiguration | |
►CPhotonSettings | |
CLimitSettings | |
CS2SConfig | |
►NDiagnostics | |
►NCounters | |
►NWrappers | |
CAverageCounterWrapper | |
CPerformanceCounterWrapper | Wrapper for base PerformanceCounter counter |
CPerSecondCounterWrapper | |
CICounterProvider | |
CMissingPerfomanceCounterProviderException | |
CNoCategoryInPerfomanceCounterSpecifiedException | |
CNoPerfomanceCategoriesDeclaredException | |
CNoPerfomanceCounterDeclaredException | |
CPerfCounterAttribute | Attribute for defining performance counters in ExtendedPerfCounterManagerBase children |
CPerfCounterCategoryAttribute | Attribute for declaring one or multiple categories for class that contains counters |
CPerfCounterManagerBase | Provides basic functionality for performance counters managers |
CUnknownCategoryInPerfomanceCounterSpecifiedException | |
CEncryptionQueuePerfCounters | |
CExtPerfCounterAttribute | |
CHttpQueuePerformanceCounters | |
CIHttpQueueCountersInstance | |
CIsAdminUtil | |
CLogCountGuard | |
CLogExtensions | |
CManagedCorePerformanceCounters | |
►CPeerMetaDataContext | |
CContextItem | |
CPerfCounterManagerBase | This counter manager is obsolete and will be removed. Use attribute based Counters.PerfCounterManagerBase<T> instead |
CTimeIntervalCounter | |
CTimeIntervalCounterLF | Lock free version of TimeInterval Counter |
CTimeIntervalCounterLite | Simplified version of TimeIntervalCounter for case steps == 1 access to all public methods should be synchronized for thread safety. This is not the case for TimeIntervalCounter |
CValueToString | |
►NMisc | |
CJsonUtils | we use this class when we need to represent our ops, responses and events as JSON. it could be wrong json. it could fail to convert data in some cases. we use it only for debugging |
CStringExtensions | |
►NNet | |
CAsyncHttpRequest | |
CAsyncRequestHttpException | |
CHttpRequestQueue | |
CHttpRequestQueueCounterWrapper | we use this class to call external counters interface safely |
CIHttpRequestQueueCounters | |
►NPeers | |
CWebSocketManagedPeer | |
►NREST | |
CIRestRequestContext | |
CRestRequest | |
CRestRequestHandler | |
►NRpc | |
►NProtocols | |
►NGpBinaryByte | |
CReadContext16 | ReadContext for protocol 1.6 |
►NGpBinaryV18 | |
CGpBinaryByteReaderV18 | |
CGpBinaryByteWriterV18 | |
►NJson | |
CJsonParseContext | |
CCustomTypeCache | |
CCustomTypeInfo | |
CDisconnectMessage | |
CGlobalProtocolTraits | |
►CInboundController | |
COperationSettings | |
CInitV3Handler | |
CMessagesLimits | |
COperationLimits | |
CParameterData | struct defines operation parameter limits (size in bytes and count of elements) and what kind of meta data information should be provided |
CParameterMetaData | meta data container for request parameter |
CReadContext | |
CRequestMetaData | MetaData container for entire request |
CRtsMessageHeader | The rts message header |
CWriteContext | |
►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 |
CSerializeSetup | |
►NRuntime | |
CAppContextSettings | |
►NSecurity | |
CCryptoBase | Base class for encryptor/decryptor classes |
CDecryptor | Implements decryption |
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 |
CEncryptionData | |
CEncryptionDataParameters | |
CEncryptor | Implemenation of encryption for UDP trafic |
CICryptoProvider | Provides methods to encrypt and decrypt binary data |
CInitEncryptionResponseHandler | |
CInplaceEncryptionUtils | |
CNativeCryptoPlugin | |
CRijndaelCryptoProvider | An ICryptoProvider implementation using the Rijndael symmetric encryption algorithm |
►NServerToServer | |
CEventDataEventArgs | Provides data for the TcpClient.Event event |
CInboundS2SPeer | S2S peer is supposed to handle inbound connections from another photon server |
CInitializeEncryptionEventArgs | Contains information for a intiialize encryption operation response |
COperationResponseEventArgs | Provides data for the TcpClient.OperationResponse event |
COutboundS2SPeer | Server2Server peer for establishing server 2 server connection |
CPingResponse | The ping response |
CPingResponseEventArgs | Provides data for the TcpClient.PingResponse event |
CS2SPeerBase | The server2server 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 |
CApplicationBase | The base class for a Photon application. The main method to override is CreatePeer. See Setup for initialization recommendations |
CClientPeer | |
CErrorCodes | Error codes used internally during connection establishing with InitV3 space below 0 and 0 is photon space space above 0 is user space |
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 |
CInitV3Response | |
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 |
CEncryptionQueueFailureParams | |
CPeerHelper | This class provides access to some internal members of PeerBase and S2SPeerBase In general these methods are indended for testing |
CPlatforms | |
CProtocol | This class provides access to the available protocols |
CSdkIds | |
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 |