1234567891011121314151617181920212223242526272829303132333435363738394041424344454647484950515253545556575859606162636465666768697071727374757677787980818283848586878889909192939495969798991001011021031041051061071081091101111121131141151161171181191201211221231241251261271281291301311321331341351361371381391401411421431441451461471481491501511521531541551561571581591601611621631641651661671681691701711721731741751761771781791801811821831841851861871881891901911921931941951961971981992002012022032042052062072082092102112122132142152162172182192202212222232242252262272282292302312322332342352362372382392402412422432442452462472482492502512522532542552562572582592602612622632642652662672682692702712722732742752762772782792802812822832842852862872882892902912922932942952962972982993003013023033043053063073083093103113123133143153163173183193203213223233243253263273283293303313323333343353363373383393403413423433443453463473483493503513523533543553563573583593603613623633643653663673683693703713723733743753763773783793803813823833843853863873883893903913923933943953963973983994004014024034044054064074084094104114124134144154164174184194204214224234244254264274284294304314324334344354364374384394404414424434444454464474484494504514524534544554564574584594604614624634644654664674684694704714724734744754764774784794804814824834844854864874884894904914924934944954964974984995005015025035045055065075085095105115125135145155165175185195205215225235245255265275285295305315325335345355365375385395405415425435445455465475485495505515525535545555565575585595605615625635645655665675685695705715725735745755765775785795805815825835845855865875885895905915925935945955965975985996006016026036046056066076086096106116126136146156166176186196206216226236246256266276286296306316326336346356366376386396406416426436446456466476486496506516526536546556566576586596606616626636646656666676686696706716726736746756766776786796806816826836846856866876886896906916926936946956966976986997007017027037047057067077087097107117127137147157167177187197207217227237247257267277287297307317327337347357367377387397407417427437447457467477487497507517527537547557567577587597607617627637647657667677687697707717727737747757767777787797807817827837847857867877887897907917927937947957967977987998008018028038048058068078088098108118128138148158168178188198208218228238248258268278288298308318328338348358368378388398408418428438448458468478488498508518528538548558568578588598608618628638648658668678688698708718728738748758768778788798808818828838848858868878888898908918928938948958968978988999009019029039049059069079089099109119129139149159169179189199209219229239249259269279289299309319329339349359369379389399409419429439449459469479489499509519529539549559569579589599609619629639649659669679689699709719729739749759769779789799809819829839849859869879889899909919929939949959969979989991000100110021003100410051006100710081009101010111012101310141015101610171018101910201021102210231024102510261027102810291030103110321033103410351036103710381039104010411042104310441045104610471048104910501051105210531054105510561057105810591060106110621063106410651066106710681069107010711072107310741075107610771078107910801081108210831084108510861087108810891090109110921093109410951096109710981099110011011102110311041105110611071108110911101111111211131114111511161117111811191120112111221123112411251126112711281129113011311132113311341135113611371138113911401141114211431144114511461147114811491150115111521153115411551156115711581159116011611162116311641165116611671168116911701171117211731174117511761177117811791180118111821183118411851186118711881189119011911192119311941195119611971198119912001201120212031204120512061207120812091210121112121213121412151216121712181219122012211222122312241225122612271228122912301231123212331234123512361237123812391240124112421243124412451246124712481249125012511252125312541255125612571258125912601261126212631264126512661267126812691270127112721273127412751276127712781279128012811282128312841285128612871288128912901291129212931294129512961297129812991300130113021303 |
- /*
- * Copyright (c) Contributors, http://opensimulator.org/
- * See CONTRIBUTORS.TXT for a full list of copyright holders.
- *
- * Redistribution and use in source and binary forms, with or without
- * modification, are permitted provided that the following conditions are met:
- * * Redistributions of source code must retain the above copyright
- * notice, this list of conditions and the following disclaimer.
- * * Redistributions in binary form must reproduce the above copyright
- * notice, this list of conditions and the following disclaimer in the
- * documentation and/or other materials provided with the distribution.
- * * Neither the name of the OpenSimulator Project nor the
- * names of its contributors may be used to endorse or promote products
- * derived from this software without specific prior written permission.
- *
- * THIS SOFTWARE IS PROVIDED BY THE DEVELOPERS ``AS IS'' AND ANY
- * EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
- * WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
- * DISCLAIMED. IN NO EVENT SHALL THE CONTRIBUTORS BE LIABLE FOR ANY
- * DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES
- * (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES;
- * LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND
- * ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT
- * (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS
- * SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
- */
- using System;
- using System.Collections.Generic;
- using System.Diagnostics;
- using System.IO;
- using System.Net;
- using System.Net.Sockets;
- using System.Reflection;
- using System.Threading;
- using log4net;
- using Nini.Config;
- using OpenMetaverse.Packets;
- using OpenSim.Framework;
- using OpenSim.Framework.Statistics;
- using OpenSim.Region.Framework.Scenes;
- using OpenMetaverse;
- using TokenBucket = OpenSim.Region.ClientStack.LindenUDP.TokenBucket;
- namespace OpenSim.Region.ClientStack.LindenUDP
- {
- /// <summary>
- /// A shim around LLUDPServer that implements the IClientNetworkServer interface
- /// </summary>
- public sealed class LLUDPServerShim : IClientNetworkServer
- {
- LLUDPServer m_udpServer;
- public LLUDPServerShim()
- {
- }
- public void Initialise(IPAddress listenIP, ref uint port, int proxyPortOffsetParm, bool allow_alternate_port, IConfigSource configSource, AgentCircuitManager circuitManager)
- {
- m_udpServer = new LLUDPServer(listenIP, ref port, proxyPortOffsetParm, allow_alternate_port, configSource, circuitManager);
- }
- public void NetworkStop()
- {
- m_udpServer.Stop();
- }
- public void AddScene(IScene scene)
- {
- m_udpServer.AddScene(scene);
- }
- public bool HandlesRegion(Location x)
- {
- return m_udpServer.HandlesRegion(x);
- }
- public void Start()
- {
- m_udpServer.Start();
- }
- public void Stop()
- {
- m_udpServer.Stop();
- }
- }
- /// <summary>
- /// The LLUDP server for a region. This handles incoming and outgoing
- /// packets for all UDP connections to the region
- /// </summary>
- public class LLUDPServer : OpenSimUDPBase
- {
- /// <summary>Maximum transmission unit, or UDP packet size, for the LLUDP protocol</summary>
- public const int MTU = 1400;
- private static readonly ILog m_log = LogManager.GetLogger(MethodBase.GetCurrentMethod().DeclaringType);
- /// <summary>The measured resolution of Environment.TickCount</summary>
- public readonly float TickCountResolution;
- /// <summary>Number of prim updates to put on the queue each time the
- /// OnQueueEmpty event is triggered for updates</summary>
- public readonly int PrimUpdatesPerCallback;
- /// <summary>Number of texture packets to put on the queue each time the
- /// OnQueueEmpty event is triggered for textures</summary>
- public readonly int TextureSendLimit;
- /// <summary>Handlers for incoming packets</summary>
- //PacketEventDictionary packetEvents = new PacketEventDictionary();
- /// <summary>Incoming packets that are awaiting handling</summary>
- private OpenMetaverse.BlockingQueue<IncomingPacket> packetInbox = new OpenMetaverse.BlockingQueue<IncomingPacket>();
- /// <summary></summary>
- //private UDPClientCollection m_clients = new UDPClientCollection();
- /// <summary>Bandwidth throttle for this UDP server</summary>
- protected TokenBucket m_throttle;
-
- /// <summary>Bandwidth throttle rates for this UDP server</summary>
- public ThrottleRates ThrottleRates { get; private set; }
-
- /// <summary>Manages authentication for agent circuits</summary>
- private AgentCircuitManager m_circuitManager;
- /// <summary>Reference to the scene this UDP server is attached to</summary>
- protected Scene m_scene;
- /// <summary>The X/Y coordinates of the scene this UDP server is attached to</summary>
- private Location m_location;
- /// <summary>The size of the receive buffer for the UDP socket. This value
- /// is passed up to the operating system and used in the system networking
- /// stack. Use zero to leave this value as the default</summary>
- private int m_recvBufferSize;
- /// <summary>Flag to process packets asynchronously or synchronously</summary>
- private bool m_asyncPacketHandling;
- /// <summary>Tracks whether or not a packet was sent each round so we know
- /// whether or not to sleep</summary>
- private bool m_packetSent;
- /// <summary>Environment.TickCount of the last time that packet stats were reported to the scene</summary>
- private int m_elapsedMSSinceLastStatReport = 0;
- /// <summary>Environment.TickCount of the last time the outgoing packet handler executed</summary>
- private int m_tickLastOutgoingPacketHandler;
- /// <summary>Keeps track of the number of elapsed milliseconds since the last time the outgoing packet handler looped</summary>
- private int m_elapsedMSOutgoingPacketHandler;
- /// <summary>Keeps track of the number of 100 millisecond periods elapsed in the outgoing packet handler executed</summary>
- private int m_elapsed100MSOutgoingPacketHandler;
- /// <summary>Keeps track of the number of 500 millisecond periods elapsed in the outgoing packet handler executed</summary>
- private int m_elapsed500MSOutgoingPacketHandler;
- /// <summary>Flag to signal when clients should check for resends</summary>
- private bool m_resendUnacked;
- /// <summary>Flag to signal when clients should send ACKs</summary>
- private bool m_sendAcks;
- /// <summary>Flag to signal when clients should send pings</summary>
- private bool m_sendPing;
- private int m_defaultRTO = 0;
- private int m_maxRTO = 0;
- private bool m_disableFacelights = false;
- public Socket Server { get { return null; } }
- private int m_malformedCount = 0; // Guard against a spamming attack
- public LLUDPServer(IPAddress listenIP, ref uint port, int proxyPortOffsetParm, bool allow_alternate_port, IConfigSource configSource, AgentCircuitManager circuitManager)
- : base(listenIP, (int)port)
- {
- #region Environment.TickCount Measurement
- // Measure the resolution of Environment.TickCount
- TickCountResolution = 0f;
- for (int i = 0; i < 5; i++)
- {
- int start = Environment.TickCount;
- int now = start;
- while (now == start)
- now = Environment.TickCount;
- TickCountResolution += (float)(now - start) * 0.2f;
- }
- m_log.Info("[LLUDPSERVER]: Average Environment.TickCount resolution: " + TickCountResolution + "ms");
- TickCountResolution = (float)Math.Ceiling(TickCountResolution);
- #endregion Environment.TickCount Measurement
- m_circuitManager = circuitManager;
- int sceneThrottleBps = 0;
- IConfig config = configSource.Configs["ClientStack.LindenUDP"];
- if (config != null)
- {
- m_asyncPacketHandling = config.GetBoolean("async_packet_handling", true);
- m_recvBufferSize = config.GetInt("client_socket_rcvbuf_size", 0);
- sceneThrottleBps = config.GetInt("scene_throttle_max_bps", 0);
- PrimUpdatesPerCallback = config.GetInt("PrimUpdatesPerCallback", 100);
- TextureSendLimit = config.GetInt("TextureSendLimit", 20);
- m_defaultRTO = config.GetInt("DefaultRTO", 0);
- m_maxRTO = config.GetInt("MaxRTO", 0);
- m_disableFacelights = config.GetBoolean("DisableFacelights", false);
- }
- else
- {
- PrimUpdatesPerCallback = 100;
- TextureSendLimit = 20;
- }
- #region BinaryStats
- config = configSource.Configs["Statistics.Binary"];
- m_shouldCollectStats = false;
- if (config != null)
- {
- if (config.Contains("enabled") && config.GetBoolean("enabled"))
- {
- if (config.Contains("collect_packet_headers"))
- m_shouldCollectStats = config.GetBoolean("collect_packet_headers");
- if (config.Contains("packet_headers_period_seconds"))
- {
- binStatsMaxFilesize = TimeSpan.FromSeconds(config.GetInt("region_stats_period_seconds"));
- }
- if (config.Contains("stats_dir"))
- {
- binStatsDir = config.GetString("stats_dir");
- }
- }
- else
- {
- m_shouldCollectStats = false;
- }
- }
- #endregion BinaryStats
- m_throttle = new TokenBucket(null, sceneThrottleBps);
- ThrottleRates = new ThrottleRates(configSource);
- }
- public void Start()
- {
- if (m_scene == null)
- throw new InvalidOperationException("[LLUDPSERVER]: Cannot LLUDPServer.Start() without an IScene reference");
- m_log.Info("[LLUDPSERVER]: Starting the LLUDP server in " + (m_asyncPacketHandling ? "asynchronous" : "synchronous") + " mode");
- base.Start(m_recvBufferSize, m_asyncPacketHandling);
- // Start the packet processing threads
- Watchdog.StartThread(IncomingPacketHandler, "Incoming Packets (" + m_scene.RegionInfo.RegionName + ")", ThreadPriority.Normal, false);
- Watchdog.StartThread(OutgoingPacketHandler, "Outgoing Packets (" + m_scene.RegionInfo.RegionName + ")", ThreadPriority.Normal, false);
- m_elapsedMSSinceLastStatReport = Environment.TickCount;
- }
- public new void Stop()
- {
- m_log.Info("[LLUDPSERVER]: Shutting down the LLUDP server for " + m_scene.RegionInfo.RegionName);
- base.Stop();
- }
- public void AddScene(IScene scene)
- {
- if (m_scene != null)
- {
- m_log.Error("[LLUDPSERVER]: AddScene() called on an LLUDPServer that already has a scene");
- return;
- }
- if (!(scene is Scene))
- {
- m_log.Error("[LLUDPSERVER]: AddScene() called with an unrecognized scene type " + scene.GetType());
- return;
- }
- m_scene = (Scene)scene;
- m_location = new Location(m_scene.RegionInfo.RegionHandle);
- }
- public bool HandlesRegion(Location x)
- {
- return x == m_location;
- }
- public void BroadcastPacket(Packet packet, ThrottleOutPacketType category, bool sendToPausedAgents, bool allowSplitting)
- {
- // CoarseLocationUpdate and AvatarGroupsReply packets cannot be split in an automated way
- if ((packet.Type == PacketType.CoarseLocationUpdate || packet.Type == PacketType.AvatarGroupsReply) && allowSplitting)
- allowSplitting = false;
- if (allowSplitting && packet.HasVariableBlocks)
- {
- byte[][] datas = packet.ToBytesMultiple();
- int packetCount = datas.Length;
- if (packetCount < 1)
- m_log.Error("[LLUDPSERVER]: Failed to split " + packet.Type + " with estimated length " + packet.Length);
- for (int i = 0; i < packetCount; i++)
- {
- byte[] data = datas[i];
- m_scene.ForEachClient(
- delegate(IClientAPI client)
- {
- if (client is LLClientView)
- SendPacketData(((LLClientView)client).UDPClient, data, packet.Type, category, null);
- }
- );
- }
- }
- else
- {
- byte[] data = packet.ToBytes();
- m_scene.ForEachClient(
- delegate(IClientAPI client)
- {
- if (client is LLClientView)
- SendPacketData(((LLClientView)client).UDPClient, data, packet.Type, category, null);
- }
- );
- }
- }
- /// <summary>
- /// Start the process of sending a packet to the client.
- /// </summary>
- /// <param name="udpClient"></param>
- /// <param name="packet"></param>
- /// <param name="category"></param>
- /// <param name="allowSplitting"></param>
- public void SendPacket(LLUDPClient udpClient, Packet packet, ThrottleOutPacketType category, bool allowSplitting, UnackedPacketMethod method)
- {
- // CoarseLocationUpdate packets cannot be split in an automated way
- if (packet.Type == PacketType.CoarseLocationUpdate && allowSplitting)
- allowSplitting = false;
- if (allowSplitting && packet.HasVariableBlocks)
- {
- byte[][] datas = packet.ToBytesMultiple();
- int packetCount = datas.Length;
- if (packetCount < 1)
- m_log.Error("[LLUDPSERVER]: Failed to split " + packet.Type + " with estimated length " + packet.Length);
- for (int i = 0; i < packetCount; i++)
- {
- byte[] data = datas[i];
- SendPacketData(udpClient, data, packet.Type, category, method);
- }
- }
- else
- {
- byte[] data = packet.ToBytes();
- SendPacketData(udpClient, data, packet.Type, category, method);
- }
- }
- /// <summary>
- /// Start the process of sending a packet to the client.
- /// </summary>
- /// <param name="udpClient"></param>
- /// <param name="data"></param>
- /// <param name="type"></param>
- /// <param name="category"></param>
- public void SendPacketData(LLUDPClient udpClient, byte[] data, PacketType type, ThrottleOutPacketType category, UnackedPacketMethod method)
- {
- int dataLength = data.Length;
- bool doZerocode = (data[0] & Helpers.MSG_ZEROCODED) != 0;
- bool doCopy = true;
- // Frequency analysis of outgoing packet sizes shows a large clump of packets at each end of the spectrum.
- // The vast majority of packets are less than 200 bytes, although due to asset transfers and packet splitting
- // there are a decent number of packets in the 1000-1140 byte range. We allocate one of two sizes of data here
- // to accomodate for both common scenarios and provide ample room for ACK appending in both
- int bufferSize = (dataLength > 180) ? LLUDPServer.MTU : 200;
- UDPPacketBuffer buffer = new UDPPacketBuffer(udpClient.RemoteEndPoint, bufferSize);
- // Zerocode if needed
- if (doZerocode)
- {
- try
- {
- dataLength = Helpers.ZeroEncode(data, dataLength, buffer.Data);
- doCopy = false;
- }
- catch (IndexOutOfRangeException)
- {
- // The packet grew larger than the bufferSize while zerocoding.
- // Remove the MSG_ZEROCODED flag and send the unencoded data
- // instead
- m_log.Debug("[LLUDPSERVER]: Packet exceeded buffer size during zerocoding for " + type + ". DataLength=" + dataLength +
- " and BufferLength=" + buffer.Data.Length + ". Removing MSG_ZEROCODED flag");
- data[0] = (byte)(data[0] & ~Helpers.MSG_ZEROCODED);
- }
- }
- // If the packet data wasn't already copied during zerocoding, copy it now
- if (doCopy)
- {
- if (dataLength <= buffer.Data.Length)
- {
- Buffer.BlockCopy(data, 0, buffer.Data, 0, dataLength);
- }
- else
- {
- bufferSize = dataLength;
- buffer = new UDPPacketBuffer(udpClient.RemoteEndPoint, bufferSize);
- // m_log.Error("[LLUDPSERVER]: Packet exceeded buffer size! This could be an indication of packet assembly not obeying the MTU. Type=" +
- // type + ", DataLength=" + dataLength + ", BufferLength=" + buffer.Data.Length + ". Dropping packet");
- Buffer.BlockCopy(data, 0, buffer.Data, 0, dataLength);
- }
- }
- buffer.DataLength = dataLength;
- #region Queue or Send
- OutgoingPacket outgoingPacket = new OutgoingPacket(udpClient, buffer, category, null);
- // If we were not provided a method for handling unacked, use the UDPServer default method
- outgoingPacket.UnackedMethod = ((method == null) ? delegate(OutgoingPacket oPacket) { ResendUnacked(oPacket); } : method);
- // If a Linden Lab 1.23.5 client receives an update packet after a kill packet for an object, it will
- // continue to display the deleted object until relog. Therefore, we need to always queue a kill object
- // packet so that it isn't sent before a queued update packet.
- bool requestQueue = type == PacketType.KillObject;
- if (!outgoingPacket.Client.EnqueueOutgoing(outgoingPacket, requestQueue))
- SendPacketFinal(outgoingPacket);
- #endregion Queue or Send
- }
- public void SendAcks(LLUDPClient udpClient)
- {
- uint ack;
- if (udpClient.PendingAcks.Dequeue(out ack))
- {
- List<PacketAckPacket.PacketsBlock> blocks = new List<PacketAckPacket.PacketsBlock>();
- PacketAckPacket.PacketsBlock block = new PacketAckPacket.PacketsBlock();
- block.ID = ack;
- blocks.Add(block);
- while (udpClient.PendingAcks.Dequeue(out ack))
- {
- block = new PacketAckPacket.PacketsBlock();
- block.ID = ack;
- blocks.Add(block);
- }
- PacketAckPacket packet = new PacketAckPacket();
- packet.Header.Reliable = false;
- packet.Packets = blocks.ToArray();
- SendPacket(udpClient, packet, ThrottleOutPacketType.Unknown, true, null);
- }
- }
- public void SendPing(LLUDPClient udpClient)
- {
- StartPingCheckPacket pc = (StartPingCheckPacket)PacketPool.Instance.GetPacket(PacketType.StartPingCheck);
- pc.Header.Reliable = false;
- pc.PingID.PingID = (byte)udpClient.CurrentPingSequence++;
- // We *could* get OldestUnacked, but it would hurt performance and not provide any benefit
- pc.PingID.OldestUnacked = 0;
- SendPacket(udpClient, pc, ThrottleOutPacketType.Unknown, false, null);
- }
- public void CompletePing(LLUDPClient udpClient, byte pingID)
- {
- CompletePingCheckPacket completePing = new CompletePingCheckPacket();
- completePing.PingID.PingID = pingID;
- SendPacket(udpClient, completePing, ThrottleOutPacketType.Unknown, false, null);
- }
- public void HandleUnacked(LLUDPClient udpClient)
- {
- if (!udpClient.IsConnected)
- return;
- // Disconnect an agent if no packets are received for some time
- //FIXME: Make 60 an .ini setting
- if ((Environment.TickCount & Int32.MaxValue) - udpClient.TickLastPacketReceived > 1000 * 60)
- {
- m_log.Warn("[LLUDPSERVER]: Ack timeout, disconnecting " + udpClient.AgentID);
- RemoveClient(udpClient);
- return;
- }
- // Get a list of all of the packets that have been sitting unacked longer than udpClient.RTO
- List<OutgoingPacket> expiredPackets = udpClient.NeedAcks.GetExpiredPackets(udpClient.RTO);
- if (expiredPackets != null)
- {
- //m_log.Debug("[LLUDPSERVER]: Handling " + expiredPackets.Count + " packets to " + udpClient.AgentID + ", RTO=" + udpClient.RTO);
- // Exponential backoff of the retransmission timeout
- udpClient.BackoffRTO();
- for (int i = 0; i < expiredPackets.Count; ++i)
- expiredPackets[i].UnackedMethod(expiredPackets[i]);
- }
- }
- public void ResendUnacked(OutgoingPacket outgoingPacket)
- {
- //m_log.DebugFormat("[LLUDPSERVER]: Resending packet #{0} (attempt {1}), {2}ms have passed",
- // outgoingPacket.SequenceNumber, outgoingPacket.ResendCount, Environment.TickCount - outgoingPacket.TickCount);
- // Set the resent flag
- outgoingPacket.Buffer.Data[0] = (byte)(outgoingPacket.Buffer.Data[0] | Helpers.MSG_RESENT);
- outgoingPacket.Category = ThrottleOutPacketType.Resend;
- // Bump up the resend count on this packet
- Interlocked.Increment(ref outgoingPacket.ResendCount);
- // Requeue or resend the packet
- if (!outgoingPacket.Client.EnqueueOutgoing(outgoingPacket, false))
- SendPacketFinal(outgoingPacket);
- }
- public void Flush(LLUDPClient udpClient)
- {
- // FIXME: Implement?
- }
- /// <summary>
- /// Actually send a packet to a client.
- /// </summary>
- /// <param name="outgoingPacket"></param>
- internal void SendPacketFinal(OutgoingPacket outgoingPacket)
- {
- UDPPacketBuffer buffer = outgoingPacket.Buffer;
- byte flags = buffer.Data[0];
- bool isResend = (flags & Helpers.MSG_RESENT) != 0;
- bool isReliable = (flags & Helpers.MSG_RELIABLE) != 0;
- bool isZerocoded = (flags & Helpers.MSG_ZEROCODED) != 0;
- LLUDPClient udpClient = outgoingPacket.Client;
- if (!udpClient.IsConnected)
- return;
- #region ACK Appending
- int dataLength = buffer.DataLength;
- // NOTE: I'm seeing problems with some viewers when ACKs are appended to zerocoded packets so I've disabled that here
- if (!isZerocoded)
- {
- // Keep appending ACKs until there is no room left in the buffer or there are
- // no more ACKs to append
- uint ackCount = 0;
- uint ack;
- while (dataLength + 5 < buffer.Data.Length && udpClient.PendingAcks.Dequeue(out ack))
- {
- Utils.UIntToBytesBig(ack, buffer.Data, dataLength);
- dataLength += 4;
- ++ackCount;
- }
- if (ackCount > 0)
- {
- // Set the last byte of the packet equal to the number of appended ACKs
- buffer.Data[dataLength++] = (byte)ackCount;
- // Set the appended ACKs flag on this packet
- buffer.Data[0] = (byte)(buffer.Data[0] | Helpers.MSG_APPENDED_ACKS);
- }
- }
- buffer.DataLength = dataLength;
- #endregion ACK Appending
- #region Sequence Number Assignment
- if (!isResend)
- {
- // Not a resend, assign a new sequence number
- uint sequenceNumber = (uint)Interlocked.Increment(ref udpClient.CurrentSequence);
- Utils.UIntToBytesBig(sequenceNumber, buffer.Data, 1);
- outgoingPacket.SequenceNumber = sequenceNumber;
- if (isReliable)
- {
- // Add this packet to the list of ACK responses we are waiting on from the server
- udpClient.NeedAcks.Add(outgoingPacket);
- }
- }
- else
- {
- Interlocked.Increment(ref udpClient.PacketsResent);
- }
- #endregion Sequence Number Assignment
- // Stats tracking
- Interlocked.Increment(ref udpClient.PacketsSent);
- // Put the UDP payload on the wire
- AsyncBeginSend(buffer);
- // Keep track of when this packet was sent out (right now)
- outgoingPacket.TickCount = Environment.TickCount & Int32.MaxValue;
- }
- protected override void PacketReceived(UDPPacketBuffer buffer)
- {
- // Debugging/Profiling
- //try { Thread.CurrentThread.Name = "PacketReceived (" + m_scene.RegionInfo.RegionName + ")"; }
- //catch (Exception) { }
- LLUDPClient udpClient = null;
- Packet packet = null;
- int packetEnd = buffer.DataLength - 1;
- IPEndPoint address = (IPEndPoint)buffer.RemoteEndPoint;
- #region Decoding
- if (buffer.DataLength < 7)
- return; // Drop undersizd packet
- int headerLen = 7;
- if (buffer.Data[6] == 0xFF)
- {
- if (buffer.Data[7] == 0xFF)
- headerLen = 10;
- else
- headerLen = 8;
- }
- if (buffer.DataLength < headerLen)
- return; // Malformed header
- try
- {
- packet = Packet.BuildPacket(buffer.Data, ref packetEnd,
- // Only allocate a buffer for zerodecoding if the packet is zerocoded
- ((buffer.Data[0] & Helpers.MSG_ZEROCODED) != 0) ? new byte[4096] : null);
- }
- catch (MalformedDataException)
- {
- }
- catch (IndexOutOfRangeException)
- {
- return; // Drop short packet
- }
- catch(Exception e)
- {
- if (m_malformedCount < 100)
- m_log.DebugFormat("[LLUDPSERVER]: Dropped malformed packet: " + e.ToString());
- m_malformedCount++;
- if ((m_malformedCount % 100000) == 0)
- m_log.DebugFormat("[LLUDPSERVER]: Received {0} malformed packets so far, probable network attack.", m_malformedCount);
- }
- // Fail-safe check
- if (packet == null)
- {
- m_log.ErrorFormat("[LLUDPSERVER]: Malformed data, cannot parse {0} byte packet from {1}:",
- buffer.DataLength, buffer.RemoteEndPoint);
- m_log.Error(Utils.BytesToHexString(buffer.Data, buffer.DataLength, null));
- return;
- }
- #endregion Decoding
- #region Packet to Client Mapping
- // UseCircuitCode handling
- if (packet.Type == PacketType.UseCircuitCode)
- {
- object[] array = new object[] { buffer, packet };
- Util.FireAndForget(HandleUseCircuitCode, array);
- return;
- }
- // Determine which agent this packet came from
- IClientAPI client;
- if (!m_scene.TryGetClient(address, out client) || !(client is LLClientView))
- {
- //m_log.Debug("[LLUDPSERVER]: Received a " + packet.Type + " packet from an unrecognized source: " + address + " in " + m_scene.RegionInfo.RegionName);
- return;
- }
- udpClient = ((LLClientView)client).UDPClient;
- if (!udpClient.IsConnected)
- return;
- #endregion Packet to Client Mapping
- // Stats tracking
- Interlocked.Increment(ref udpClient.PacketsReceived);
- int now = Environment.TickCount & Int32.MaxValue;
- udpClient.TickLastPacketReceived = now;
- #region ACK Receiving
- // Handle appended ACKs
- if (packet.Header.AppendedAcks && packet.Header.AckList != null)
- {
- for (int i = 0; i < packet.Header.AckList.Length; i++)
- udpClient.NeedAcks.Acknowledge(packet.Header.AckList[i], now, packet.Header.Resent);
- }
- // Handle PacketAck packets
- if (packet.Type == PacketType.PacketAck)
- {
- PacketAckPacket ackPacket = (PacketAckPacket)packet;
- for (int i = 0; i < ackPacket.Packets.Length; i++)
- udpClient.NeedAcks.Acknowledge(ackPacket.Packets[i].ID, now, packet.Header.Resent);
- // We don't need to do anything else with PacketAck packets
- return;
- }
- #endregion ACK Receiving
- #region ACK Sending
- if (packet.Header.Reliable)
- {
- udpClient.PendingAcks.Enqueue(packet.Header.Sequence);
- // This is a somewhat odd sequence of steps to pull the client.BytesSinceLastACK value out,
- // add the current received bytes to it, test if 2*MTU bytes have been sent, if so remove
- // 2*MTU bytes from the value and send ACKs, and finally add the local value back to
- // client.BytesSinceLastACK. Lockless thread safety
- int bytesSinceLastACK = Interlocked.Exchange(ref udpClient.BytesSinceLastACK, 0);
- bytesSinceLastACK += buffer.DataLength;
- if (bytesSinceLastACK > LLUDPServer.MTU * 2)
- {
- bytesSinceLastACK -= LLUDPServer.MTU * 2;
- SendAcks(udpClient);
- }
- Interlocked.Add(ref udpClient.BytesSinceLastACK, bytesSinceLastACK);
- }
- #endregion ACK Sending
- #region Incoming Packet Accounting
- // Check the archive of received reliable packet IDs to see whether we already received this packet
- if (packet.Header.Reliable && !udpClient.PacketArchive.TryEnqueue(packet.Header.Sequence))
- {
- if (packet.Header.Resent)
- m_log.DebugFormat(
- "[LLUDPSERVER]: Received a resend of already processed packet #{0}, type {1} from {2}",
- packet.Header.Sequence, packet.Type, client.Name);
- else
- m_log.WarnFormat(
- "[LLUDPSERVER]: Received a duplicate (not marked as resend) of packet #{0}, type {1} from {2}",
- packet.Header.Sequence, packet.Type, client.Name);
- // Avoid firing a callback twice for the same packet
- return;
- }
- #endregion Incoming Packet Accounting
- #region BinaryStats
- LogPacketHeader(true, udpClient.CircuitCode, 0, packet.Type, (ushort)packet.Length);
- #endregion BinaryStats
- #region Ping Check Handling
- if (packet.Type == PacketType.StartPingCheck)
- {
- // We don't need to do anything else with ping checks
- StartPingCheckPacket startPing = (StartPingCheckPacket)packet;
- CompletePing(udpClient, startPing.PingID.PingID);
- if ((Environment.TickCount - m_elapsedMSSinceLastStatReport) >= 3000)
- {
- udpClient.SendPacketStats();
- m_elapsedMSSinceLastStatReport = Environment.TickCount;
- }
- return;
- }
- else if (packet.Type == PacketType.CompletePingCheck)
- {
- // We don't currently track client ping times
- return;
- }
- #endregion Ping Check Handling
- // Inbox insertion
- packetInbox.Enqueue(new IncomingPacket(udpClient, packet));
- }
- #region BinaryStats
- public class PacketLogger
- {
- public DateTime StartTime;
- public string Path = null;
- public System.IO.BinaryWriter Log = null;
- }
- public static PacketLogger PacketLog;
- protected static bool m_shouldCollectStats = false;
- // Number of seconds to log for
- static TimeSpan binStatsMaxFilesize = TimeSpan.FromSeconds(300);
- static object binStatsLogLock = new object();
- static string binStatsDir = "";
- public static void LogPacketHeader(bool incoming, uint circuit, byte flags, PacketType packetType, ushort size)
- {
- if (!m_shouldCollectStats) return;
- // Binary logging format is TTTTTTTTCCCCFPPPSS, T=Time, C=Circuit, F=Flags, P=PacketType, S=size
- // Put the incoming bit into the least significant bit of the flags byte
- if (incoming)
- flags |= 0x01;
- else
- flags &= 0xFE;
- // Put the flags byte into the most significant bits of the type integer
- uint type = (uint)packetType;
- type |= (uint)flags << 24;
- // m_log.Debug("1 LogPacketHeader(): Outside lock");
- lock (binStatsLogLock)
- {
- DateTime now = DateTime.Now;
- // m_log.Debug("2 LogPacketHeader(): Inside lock. now is " + now.Ticks);
- try
- {
- if (PacketLog == null || (now > PacketLog.StartTime + binStatsMaxFilesize))
- {
- if (PacketLog != null && PacketLog.Log != null)
- {
- PacketLog.Log.Close();
- }
- // First log file or time has expired, start writing to a new log file
- PacketLog = new PacketLogger();
- PacketLog.StartTime = now;
- PacketLog.Path = (binStatsDir.Length > 0 ? binStatsDir + System.IO.Path.DirectorySeparatorChar.ToString() : "")
- + String.Format("packets-{0}.log", now.ToString("yyyyMMddHHmmss"));
- PacketLog.Log = new BinaryWriter(File.Open(PacketLog.Path, FileMode.Append, FileAccess.Write));
- }
- // Serialize the data
- byte[] output = new byte[18];
- Buffer.BlockCopy(BitConverter.GetBytes(now.Ticks), 0, output, 0, 8);
- Buffer.BlockCopy(BitConverter.GetBytes(circuit), 0, output, 8, 4);
- Buffer.BlockCopy(BitConverter.GetBytes(type), 0, output, 12, 4);
- Buffer.BlockCopy(BitConverter.GetBytes(size), 0, output, 16, 2);
- // Write the serialized data to disk
- if (PacketLog != null && PacketLog.Log != null)
- PacketLog.Log.Write(output);
- }
- catch (Exception ex)
- {
- m_log.Error("Packet statistics gathering failed: " + ex.Message, ex);
- if (PacketLog.Log != null)
- {
- PacketLog.Log.Close();
- }
- PacketLog = null;
- }
- }
- }
- #endregion BinaryStats
- private void HandleUseCircuitCode(object o)
- {
- // DateTime startTime = DateTime.Now;
- object[] array = (object[])o;
- UDPPacketBuffer buffer = (UDPPacketBuffer)array[0];
- UseCircuitCodePacket packet = (UseCircuitCodePacket)array[1];
-
- m_log.DebugFormat("[LLUDPSERVER]: Handling UseCircuitCode request from {0}", buffer.RemoteEndPoint);
- IPEndPoint remoteEndPoint = (IPEndPoint)buffer.RemoteEndPoint;
- // Begin the process of adding the client to the simulator
- AddNewClient((UseCircuitCodePacket)packet, remoteEndPoint);
- // Send ack
- SendAckImmediate(remoteEndPoint, packet.Header.Sequence);
- // m_log.DebugFormat(
- // "[LLUDPSERVER]: Handling UseCircuitCode request from {0} took {1}ms",
- // buffer.RemoteEndPoint, (DateTime.Now - startTime).Milliseconds);
- }
- private void SendAckImmediate(IPEndPoint remoteEndpoint, uint sequenceNumber)
- {
- PacketAckPacket ack = new PacketAckPacket();
- ack.Header.Reliable = false;
- ack.Packets = new PacketAckPacket.PacketsBlock[1];
- ack.Packets[0] = new PacketAckPacket.PacketsBlock();
- ack.Packets[0].ID = sequenceNumber;
- byte[] packetData = ack.ToBytes();
- int length = packetData.Length;
- UDPPacketBuffer buffer = new UDPPacketBuffer(remoteEndpoint, length);
- buffer.DataLength = length;
- Buffer.BlockCopy(packetData, 0, buffer.Data, 0, length);
- AsyncBeginSend(buffer);
- }
- private bool IsClientAuthorized(UseCircuitCodePacket useCircuitCode, out AuthenticateResponse sessionInfo)
- {
- UUID agentID = useCircuitCode.CircuitCode.ID;
- UUID sessionID = useCircuitCode.CircuitCode.SessionID;
- uint circuitCode = useCircuitCode.CircuitCode.Code;
- sessionInfo = m_circuitManager.AuthenticateSession(sessionID, agentID, circuitCode);
- return sessionInfo.Authorised;
- }
- private void AddNewClient(UseCircuitCodePacket useCircuitCode, IPEndPoint remoteEndPoint)
- {
- UUID agentID = useCircuitCode.CircuitCode.ID;
- UUID sessionID = useCircuitCode.CircuitCode.SessionID;
- uint circuitCode = useCircuitCode.CircuitCode.Code;
- if (m_scene.RegionStatus != RegionStatus.SlaveScene)
- {
- AuthenticateResponse sessionInfo;
- if (IsClientAuthorized(useCircuitCode, out sessionInfo))
- {
- AddClient(circuitCode, agentID, sessionID, remoteEndPoint, sessionInfo);
- }
- else
- {
- // Don't create circuits for unauthorized clients
- m_log.WarnFormat(
- "[LLUDPSERVER]: Connection request for client {0} connecting with unnotified circuit code {1} from {2}",
- useCircuitCode.CircuitCode.ID, useCircuitCode.CircuitCode.Code, remoteEndPoint);
- }
- }
- else
- {
- // Slave regions don't accept new clients
- m_log.Debug("[LLUDPSERVER]: Slave region " + m_scene.RegionInfo.RegionName + " ignoring UseCircuitCode packet");
- }
- }
- protected virtual void AddClient(uint circuitCode, UUID agentID, UUID sessionID, IPEndPoint remoteEndPoint, AuthenticateResponse sessionInfo)
- {
- // In priciple there shouldn't be more than one thread here, ever.
- // But in case that happens, we need to synchronize this piece of code
- // because it's too important
- lock (this)
- {
- IClientAPI existingClient;
- if (!m_scene.TryGetClient(agentID, out existingClient))
- {
- // Create the LLUDPClient
- LLUDPClient udpClient = new LLUDPClient(this, ThrottleRates, m_throttle, circuitCode, agentID, remoteEndPoint, m_defaultRTO, m_maxRTO);
- // Create the LLClientView
- LLClientView client = new LLClientView(remoteEndPoint, m_scene, this, udpClient, sessionInfo, agentID, sessionID, circuitCode);
- client.OnLogout += LogoutHandler;
- client.DisableFacelights = m_disableFacelights;
- // Start the IClientAPI
- client.Start();
- }
- else
- {
- m_log.WarnFormat("[LLUDPSERVER]: Ignoring a repeated UseCircuitCode from {0} at {1} for circuit {2}",
- existingClient.AgentId, remoteEndPoint, circuitCode);
- }
- }
- }
- private void RemoveClient(LLUDPClient udpClient)
- {
- // Remove this client from the scene
- IClientAPI client;
- if (m_scene.TryGetClient(udpClient.AgentID, out client))
- {
- client.IsLoggingOut = true;
- client.Close();
- }
- }
- private void IncomingPacketHandler()
- {
- // Set this culture for the thread that incoming packets are received
- // on to en-US to avoid number parsing issues
- Culture.SetCurrentCulture();
- while (base.IsRunning)
- {
- try
- {
- IncomingPacket incomingPacket = null;
- // HACK: This is a test to try and rate limit packet handling on Mono.
- // If it works, a more elegant solution can be devised
- if (Util.FireAndForgetCount() < 2)
- {
- //m_log.Debug("[LLUDPSERVER]: Incoming packet handler is sleeping");
- Thread.Sleep(30);
- }
- if (packetInbox.Dequeue(100, ref incomingPacket))
- ProcessInPacket(incomingPacket);//, incomingPacket); Util.FireAndForget(ProcessInPacket, incomingPacket);
- }
- catch (Exception ex)
- {
- m_log.Error("[LLUDPSERVER]: Error in the incoming packet handler loop: " + ex.Message, ex);
- }
- Watchdog.UpdateThread();
- }
- if (packetInbox.Count > 0)
- m_log.Warn("[LLUDPSERVER]: IncomingPacketHandler is shutting down, dropping " + packetInbox.Count + " packets");
- packetInbox.Clear();
- Watchdog.RemoveThread();
- }
- private void OutgoingPacketHandler()
- {
- // Set this culture for the thread that outgoing packets are sent
- // on to en-US to avoid number parsing issues
- Culture.SetCurrentCulture();
- // Typecast the function to an Action<IClientAPI> once here to avoid allocating a new
- // Action generic every round
- Action<IClientAPI> clientPacketHandler = ClientOutgoingPacketHandler;
- while (base.IsRunning)
- {
- try
- {
- m_packetSent = false;
- #region Update Timers
- m_resendUnacked = false;
- m_sendAcks = false;
- m_sendPing = false;
- // Update elapsed time
- int thisTick = Environment.TickCount & Int32.MaxValue;
- if (m_tickLastOutgoingPacketHandler > thisTick)
- m_elapsedMSOutgoingPacketHandler += ((Int32.MaxValue - m_tickLastOutgoingPacketHandler) + thisTick);
- else
- m_elapsedMSOutgoingPacketHandler += (thisTick - m_tickLastOutgoingPacketHandler);
- m_tickLastOutgoingPacketHandler = thisTick;
- // Check for pending outgoing resends every 100ms
- if (m_elapsedMSOutgoingPacketHandler >= 100)
- {
- m_resendUnacked = true;
- m_elapsedMSOutgoingPacketHandler = 0;
- m_elapsed100MSOutgoingPacketHandler += 1;
- }
- // Check for pending outgoing ACKs every 500ms
- if (m_elapsed100MSOutgoingPacketHandler >= 5)
- {
- m_sendAcks = true;
- m_elapsed100MSOutgoingPacketHandler = 0;
- m_elapsed500MSOutgoingPacketHandler += 1;
- }
- // Send pings to clients every 5000ms
- if (m_elapsed500MSOutgoingPacketHandler >= 10)
- {
- m_sendPing = true;
- m_elapsed500MSOutgoingPacketHandler = 0;
- }
- #endregion Update Timers
- // Use this for emergency monitoring -- bug hunting
- //if (m_scene.EmergencyMonitoring)
- // clientPacketHandler = MonitoredClientOutgoingPacketHandler;
- //else
- // clientPacketHandler = ClientOutgoingPacketHandler;
- // Handle outgoing packets, resends, acknowledgements, and pings for each
- // client. m_packetSent will be set to true if a packet is sent
- m_scene.ForEachClient(clientPacketHandler);
- // If nothing was sent, sleep for the minimum amount of time before a
- // token bucket could get more tokens
- if (!m_packetSent)
- Thread.Sleep((int)TickCountResolution);
- Watchdog.UpdateThread();
- }
- catch (Exception ex)
- {
- m_log.Error("[LLUDPSERVER]: OutgoingPacketHandler loop threw an exception: " + ex.Message, ex);
- }
- }
- Watchdog.RemoveThread();
- }
- private void ClientOutgoingPacketHandler(IClientAPI client)
- {
- try
- {
- if (client is LLClientView)
- {
- LLUDPClient udpClient = ((LLClientView)client).UDPClient;
- if (udpClient.IsConnected)
- {
- if (m_resendUnacked)
- HandleUnacked(udpClient);
- if (m_sendAcks)
- SendAcks(udpClient);
- if (m_sendPing)
- SendPing(udpClient);
- // Dequeue any outgoing packets that are within the throttle limits
- if (udpClient.DequeueOutgoing())
- m_packetSent = true;
- }
- }
- }
- catch (Exception ex)
- {
- m_log.Error("[LLUDPSERVER]: OutgoingPacketHandler iteration for " + client.Name +
- " threw an exception: " + ex.Message, ex);
- }
- }
- #region Emergency Monitoring
- // Alternative packet handler fuull of instrumentation
- // Handy for hunting bugs
- private Stopwatch watch1 = new Stopwatch();
- private Stopwatch watch2 = new Stopwatch();
- private float avgProcessingTicks = 0;
- private float avgResendUnackedTicks = 0;
- private float avgSendAcksTicks = 0;
- private float avgSendPingTicks = 0;
- private float avgDequeueTicks = 0;
- private long nticks = 0;
- private long nticksUnack = 0;
- private long nticksAck = 0;
- private long nticksPing = 0;
- private int npacksSent = 0;
- private int npackNotSent = 0;
- private void MonitoredClientOutgoingPacketHandler(IClientAPI client)
- {
- nticks++;
- watch1.Start();
- try
- {
- if (client is LLClientView)
- {
- LLUDPClient udpClient = ((LLClientView)client).UDPClient;
- if (udpClient.IsConnected)
- {
- if (m_resendUnacked)
- {
- nticksUnack++;
- watch2.Start();
- HandleUnacked(udpClient);
- watch2.Stop();
- avgResendUnackedTicks = (nticksUnack - 1)/(float)nticksUnack * avgResendUnackedTicks + (watch2.ElapsedTicks / (float)nticksUnack);
- watch2.Reset();
- }
- if (m_sendAcks)
- {
- nticksAck++;
- watch2.Start();
-
- SendAcks(udpClient);
- watch2.Stop();
- avgSendAcksTicks = (nticksAck - 1) / (float)nticksAck * avgSendAcksTicks + (watch2.ElapsedTicks / (float)nticksAck);
- watch2.Reset();
- }
- if (m_sendPing)
- {
- nticksPing++;
- watch2.Start();
-
- SendPing(udpClient);
- watch2.Stop();
- avgSendPingTicks = (nticksPing - 1) / (float)nticksPing * avgSendPingTicks + (watch2.ElapsedTicks / (float)nticksPing);
- watch2.Reset();
- }
- watch2.Start();
- // Dequeue any outgoing packets that are within the throttle limits
- if (udpClient.DequeueOutgoing())
- {
- m_packetSent = true;
- npacksSent++;
- }
- else
- npackNotSent++;
- watch2.Stop();
- avgDequeueTicks = (nticks - 1) / (float)nticks * avgDequeueTicks + (watch2.ElapsedTicks / (float)nticks);
- watch2.Reset();
- }
- else
- m_log.WarnFormat("[LLUDPSERVER]: Client is not connected");
- }
- }
- catch (Exception ex)
- {
- m_log.Error("[LLUDPSERVER]: OutgoingPacketHandler iteration for " + client.Name +
- " threw an exception: " + ex.Message, ex);
- }
- watch1.Stop();
- avgProcessingTicks = (nticks - 1) / (float)nticks * avgProcessingTicks + (watch1.ElapsedTicks / (float)nticks);
- watch1.Reset();
- // reuse this -- it's every ~100ms
- if (m_scene.EmergencyMonitoring && nticks % 100 == 0)
- {
- m_log.InfoFormat("[LLUDPSERVER]: avg processing ticks: {0} avg unacked: {1} avg acks: {2} avg ping: {3} avg dequeue: {4} (TickCountRes: {5} sent: {6} notsent: {7})",
- avgProcessingTicks, avgResendUnackedTicks, avgSendAcksTicks, avgSendPingTicks, avgDequeueTicks, TickCountResolution, npacksSent, npackNotSent);
- npackNotSent = npacksSent = 0;
- }
- }
- #endregion
- private void ProcessInPacket(object state)
- {
- IncomingPacket incomingPacket = (IncomingPacket)state;
- Packet packet = incomingPacket.Packet;
- LLUDPClient udpClient = incomingPacket.Client;
- IClientAPI client;
- // Sanity check
- if (packet == null || udpClient == null)
- {
- m_log.WarnFormat("[LLUDPSERVER]: Processing a packet with incomplete state. Packet=\"{0}\", UDPClient=\"{1}\"",
- packet, udpClient);
- }
- // Make sure this client is still alive
- if (m_scene.TryGetClient(udpClient.AgentID, out client))
- {
- try
- {
- // Process this packet
- client.ProcessInPacket(packet);
- }
- catch (ThreadAbortException)
- {
- // If something is trying to abort the packet processing thread, take that as a hint that it's time to shut down
- m_log.Info("[LLUDPSERVER]: Caught a thread abort, shutting down the LLUDP server");
- Stop();
- }
- catch (Exception e)
- {
- // Don't let a failure in an individual client thread crash the whole sim.
- m_log.ErrorFormat("[LLUDPSERVER]: Client packet handler for {0} for packet {1} threw an exception", udpClient.AgentID, packet.Type);
- m_log.Error(e.Message, e);
- }
- }
- else
- {
- m_log.DebugFormat("[LLUDPSERVER]: Dropping incoming {0} packet for dead client {1}", packet.Type, udpClient.AgentID);
- }
- }
- protected void LogoutHandler(IClientAPI client)
- {
- client.SendLogoutPacket();
- if (client.IsActive)
- RemoveClient(((LLClientView)client).UDPClient);
- }
- }
- }
|