• 设为首页
  • 点击收藏
  • 手机版
    手机扫一扫访问
    迪恩网络手机版
  • 关注官方公众号
    微信扫一扫关注
    迪恩网络公众号

C# ConcurrentQueue类代码示例

原作者: [db:作者] 来自: [db:来源] 收藏 邀请

本文整理汇总了C#中ConcurrentQueue的典型用法代码示例。如果您正苦于以下问题:C# ConcurrentQueue类的具体用法?C# ConcurrentQueue怎么用?C# ConcurrentQueue使用的例子?那么恭喜您, 这里精选的类代码示例或许可以为您提供帮助。



ConcurrentQueue类属于命名空间,在下文中一共展示了ConcurrentQueue类的20个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于我们的系统推荐出更棒的C#代码示例。

示例1: FillOne

 public static byte[] FillOne(ConcurrentQueue<Operation> writeQueue, ConcurrentQueue<Operation> readQueue)
 {
     Operation op;
     if (!writeQueue.TryDequeue(out op)) return new byte[0];
     readQueue.Enqueue(op);
     return op.Packet;
 }
开发者ID:sdether,项目名称:Ketchup,代码行数:7,代码来源:Buffer.cs


示例2: SolarLogMonitoringThread

		public SolarLogMonitoringThread(String _URL, ConsoleOutputLogger COL, ConcurrentQueue<SolarLogDataSet> EventQueue, Int32 UpdateTime = 10000)
		{
			URL = _URL;
			SolarLogUpdateTime = UpdateTime;
			ConsoleOutputLogger = COL;
			iQueue = EventQueue;
		}
开发者ID:pereritob,项目名称:hacs,代码行数:7,代码来源:SolarLogMonitoringThread.cs


示例3: LogTextWriter

 public LogTextWriter(string filePath, string prefix = null, string suffix = null, string newline = "\n")
 {
     _outputQueue = new ConcurrentQueue<string>();
     _outputRun = 1;
     _outputThread = new Thread(() =>
     {
         string o;
             using (FileStream _fs = File.Open(filePath, FileMode.Create, FileAccess.ReadWrite, FileShare.Read))
             {
         _innerWriter = new StreamWriter(_fs);
         _innerWriter.NewLine = newline;
         while (Thread.VolatileRead(ref _outputRun) == 1 || _outputQueue.Count > 0)
         {
             if (_outputQueue.Count > 0)
             {
                 while (_outputQueue.TryDequeue(out o))
                     _innerWriter.Write(o);
                 _innerWriter.Flush();
             }
             else
                 Thread.Sleep(_outputThreadDelay);
         }
     //				_fs.Close();
         _innerWriter.Close();
             }
     });
     _outputThread.Priority = ThreadPriority.BelowNormal;
     _outputThread.Start();
     _prefix = prefix;
     _suffix = suffix;
 }
开发者ID:jbowwww,项目名称:ArtefactService,代码行数:31,代码来源:LogTextWriter.cs


示例4: Playlist

 public Playlist(int maxPlayed = 4, int lowCount = 1)
 {
     MaxPlayed = maxPlayed;
     LowPlaylistCount = lowCount;
     _nextSongs = new ConcurrentQueue<Song>();
     _playedSongs = new ConcurrentQueue<Song>();
 }
开发者ID:TingPing,项目名称:elpis,代码行数:7,代码来源:Playlist.cs


示例5: ConsumerQueue

 public void ConsumerQueue()
 {
     ConcurrentQueue<User> consumerQueue;
     User user;
     int allcount = 0;
     Stopwatch watch = Stopwatch.StartNew();
     while (true)
     {
         _dataEvent.WaitOne();
         if (!_currentQueue.IsEmpty)
         {
             _currentQueue = (_currentQueue == _writeQueue) ? _readQueue : _writeQueue;
             consumerQueue = (_currentQueue == _writeQueue) ? _readQueue : _writeQueue;
             while (!consumerQueue.IsEmpty)
             {
                 while (!consumerQueue.IsEmpty)
                 {
                     if (consumerQueue.TryDequeue(out user))
                     {
                         FluentConsole.White.Background.Red.Line(user.ToString());
                         allcount++;
                     }
                 }
                 FluentConsole.White.Background.Red.Line($"当前个数{allcount.ToString()},花费了{watch.ElapsedMilliseconds.ToString()}ms;");
                 System.Threading.Thread.Sleep(20);
             }
         }
     }
 }
开发者ID:yjqGitHub,项目名称:DoubleQueueTest,代码行数:29,代码来源:DoubleQueue.cs


示例6: CheckinScript

		public void CheckinScript(ScriptedPatchRequest request, Jint.JintEngine context)
		{
			CachedResult value;
			if (cacheDic.TryGetValue(request, out value))
			{
				if (value.Queue.Count > 20)
					return;
				value.Queue.Enqueue(context);
				return;
			}
			cacheDic.AddOrUpdate(request, patchRequest =>
			{
				var queue = new ConcurrentQueue<Jint.JintEngine>();
				queue.Enqueue(context);
				return new CachedResult
				{
					Queue = queue,
					Timestamp = SystemTime.UtcNow,
					Usage = 1
				};
			}, (patchRequest, result) =>
			{
				result.Queue.Enqueue(context);
				return result;
			});
		}
开发者ID:nberardi,项目名称:ravendb,代码行数:26,代码来源:ScriptsCache.cs


示例7: SpawnerManager

 public SpawnerManager()
 {
     this._sceneManager = null; // post init
     this._spawnRequestConcurrentQueue = new ConcurrentQueue<GameObjectSpawnRequest>();
     this._removeGameObjectRequestConcurrentQueue = new ConcurrentQueue<IGameObject>();
     this._firstTime = true;
 }
开发者ID:ErPanfi,项目名称:ProjectHCI,代码行数:7,代码来源:SpawnerManager.cs


示例8: SetUp

        protected override void SetUp()
        {
            _activator = Using(new BuiltinHandlerActivator());

            _waitedSeconds = new ConcurrentQueue<double>();

            _rebusConfigurer = Configure.With(_activator)
                .Transport(t => t.UseInMemoryTransport(new InMemNetwork(), "test backoff"))
                .Options(o =>
                {
                    o.SetBackoffTimes(TimeSpan.FromSeconds(0.2), TimeSpan.FromSeconds(0.5), TimeSpan.FromSeconds(1));

                    o.Decorate<ITransport>(c =>
                    {
                        var transport = c.Get<ITransport>();
                        var transportTap = new TransportTap(transport);

                        transportTap.NoMessageReceived += () =>
                        {
                            var elapsedSinceStart = DateTime.UtcNow - _busStartTime;
                            var elapsedSeconds = Math.Round(elapsedSinceStart.TotalSeconds, 1);
                            _waitedSeconds.Enqueue(elapsedSeconds);
                        };

                        return transportTap;
                    });

                    o.SetMaxParallelism(10);
                    o.SetNumberOfWorkers(1);
                });
        }
开发者ID:xenoputtss,项目名称:Rebus,代码行数:31,代码来源:TestCustomizedBackoffTime.cs


示例9: WSSharpWebSocketEngine

		internal WSSharpWebSocketEngine(WebSocket parent, string userAgent, int sendInterval)
		{
			_parent = parent;
			_userAgent = userAgent;
			_sendInterval = sendInterval;
			_sendQueue = new ConcurrentQueue<string>();
		}
开发者ID:Goobles,项目名称:Discord.Net,代码行数:7,代码来源:WebSocket.WebSocketSharp.cs


示例10: ExSocket

 /// <summary>
 /// Initializes a new instance of the <see cref="ZyGames.Framework.RPC.Sockets.ExSocket"/> class.
 /// </summary>
 /// <param name="socket">Socket.</param>
 public ExSocket(Socket socket)
 {
     HashCode = Guid.NewGuid();
     sendQueue = new ConcurrentQueue<SocketAsyncResult>();
     this.socket = socket;
     InitData();
 }
开发者ID:GamesDesignArt,项目名称:UniversalCommon,代码行数:11,代码来源:ExSocket.cs


示例11: LogFileSearch

        public LogFileSearch(ITaskScheduler taskScheduler, ILogFile logFile, string searchTerm, TimeSpan maximumWaitTime)
        {
            if (taskScheduler == null)
                throw new ArgumentNullException("taskScheduler");
            if (logFile == null)
                throw new ArgumentNullException("logFile");
            if (string.IsNullOrEmpty(searchTerm))
                throw new ArgumentException("searchTerm may not be empty");

            _logFile = logFile;
            _filter = new SubstringFilter(searchTerm, true);
            _matches = new List<LogMatch>();
            _syncRoot = new object();
            _listeners = new LogFileSearchListenerCollection(this);
            _pendingModifications = new ConcurrentQueue<LogFileSection>();
            _scheduler = taskScheduler;

            const int maximumLineCount = 1000;
            _maximumWaitTime = maximumWaitTime;
            _logLinesBuffer = new LogLine[maximumLineCount];
            _matchesBuffer = new List<LogLineMatch>();
            _logFile.AddListener(this, _maximumWaitTime, maximumLineCount);

            _task = _scheduler.StartPeriodic(FilterAllPending,
                                             TimeSpan.FromMilliseconds(100),
                                             string.Format("Search {0}", logFile));
        }
开发者ID:Kittyfisto,项目名称:Tailviewer,代码行数:27,代码来源:LogFileSearch.cs


示例12: createPersonsLots

        public Tuple<Dictionary<int, int>, Dictionary<string, int>, Dictionary<int, JObject>> createPersonsLots(Dictionary<string, Dictionary<string, NomValue>> noms)
        {
            Stopwatch timer = new Stopwatch();
            timer.Start();

            CancellationTokenSource cts = new CancellationTokenSource();
            CancellationToken ct = cts.Token;

            ConcurrentQueue<int> personIds = new ConcurrentQueue<int>(this.getPersonIds());

            ConcurrentDictionary<int, int> personIdToLotId = new ConcurrentDictionary<int, int>();
            ConcurrentDictionary<string, int> personEgnToLotId = new ConcurrentDictionary<string, int>();
            ConcurrentDictionary<int, JObject> personLotIdToPersonNom = new ConcurrentDictionary<int, JObject>();

            Utils.RunParallel("ParallelMigrations", ct,
                () => this.personLotCreatorFactory().Value,
                (personLotCreator) =>
                {
                    using (personLotCreator)
                    {
                        personLotCreator.StartCreating(noms, personIds, personIdToLotId, personEgnToLotId, personLotIdToPersonNom, cts, ct);
                    }
                })
                .Wait();

            timer.Stop();
            Console.WriteLine("Person lot creation time - {0}", timer.Elapsed.TotalMinutes);

            return Tuple.Create(
                personIdToLotId.ToDictionary(kvp => kvp.Key, kvp => kvp.Value),
                personEgnToLotId.ToDictionary(kvp => kvp.Key, kvp => kvp.Value),
                personLotIdToPersonNom.ToDictionary(kvp => kvp.Key, kvp => kvp.Value));
        }
开发者ID:MartinBG,项目名称:Gva,代码行数:33,代码来源:Person.cs


示例13: Iterate

 private static Map Iterate(ConcurrentQueue<Tuple<Map, char>> queue, Tree tree)
 {
     Tuple<Map, char> var;
     while (!queue.TryDequeue(out var)) System.Threading.Thread.Sleep(5);
     var currentMap = var.Item1;
     var cars = currentMap.Parse();
       //Console.WriteLine("Checking:\n" + currentMap);
     if (cars.ContainsKey(Globals.TargetCar) && cars[Globals.TargetCar].Item1.Equals(targetLocation))
         return currentMap;
     foreach (var kvp in cars)
         if (kvp.Key != var.Item2) {
             Map move;
             bool horizontal = kvp.Value.Item3 == Direction.Right;
             for (int i = 1; i <= (horizontal ? kvp.Value.Item1.X : kvp.Value.Item1.Y); i++) {
                 move = currentMap.makeMove(kvp.Key, kvp.Value.Item1, kvp.Value.Item3.Invert(), kvp.Value.Item2, i);
                 if (move != null) {
                     NewMethod(queue, tree, currentMap, kvp, move);
                 }
                 else break;
             }
             for (int i = 1; i < (horizontal ? map.map.GetLength(0) - kvp.Value.Item1.X : map.map.GetLength(1) - kvp.Value.Item1.Y); i++) {
                 move = currentMap.makeMove(kvp.Key, kvp.Value.Item1, kvp.Value.Item3, kvp.Value.Item2, i);
                 if (move != null) {
                     NewMethod(queue, tree, currentMap, kvp, move);
                 }
                 else break;
             }
         }
     if (queue.Count == 0) return Globals.NoSolutions; // We don't have anything to add
     return null; // no solution found yet
 }
开发者ID:kutagh,项目名称:RushHour,代码行数:31,代码来源:Program.cs


示例14: Fill

        private static List<byte> Fill(List<byte> buffer, ConcurrentQueue<Operation> writeQueue, ConcurrentQueue<Operation> readQueue)
        {
            Operation op;

            //at this point there should never be nothing in the queue, but just in case
            if (!writeQueue.TryPeek(out op))
                return buffer;

            //check if adding the next item in the queue would overflow the buffer
            if (op.Packet.Length + buffer.Count > _bufferLength)
                return buffer;

            //again, if you peeked at it, it should still be here, so you should never hit this
            if (!writeQueue.TryDequeue(out op))
                return buffer;

            //make sure these two operations happen as transaction
            var currentIndex = buffer.Count;
            try
            {
                buffer.AddRange(op.Packet);
                readQueue.Enqueue(op);
            }
            catch
            {
                //roll it back
                buffer.RemoveRange(currentIndex, op.Packet.Length);
                writeQueue.Enqueue(op);
            }

            //continue filling the buffer until it's full
            return Fill(buffer, writeQueue, readQueue);
        }
开发者ID:sdether,项目名称:Ketchup,代码行数:33,代码来源:Buffer.cs


示例15: RunProcess

        public void RunProcess(Action<Action<StringDictionary>> process, string[] servicePrincipal)
        {
            var key = Guid.NewGuid().GetHashCode().ToString("X");
            string @namespace = servicePrincipal.Any() ? "Global" : "Local";

            _memoryManager.Initialise(@namespace, key, servicePrincipal);
            _messageQueue = new ConcurrentQueue<byte[]>();

            using (_mcb = new MemoryManager.ManagedCommunicationBlock(@namespace, key, MaxMsgSize, -1, servicePrincipal))
            using (var processMgmt = new AutoResetEvent(false))
            using (var queueMgmt = new AutoResetEvent(false))
            using (var environmentKeyRead = new AutoResetEvent(false))
            {
                var handles = new List<WaitHandle> { processMgmt, _mcb.ProfilerRequestsInformation };

                ThreadPool.QueueUserWorkItem(
                    SetProfilerAttributes(process, key, @namespace, environmentKeyRead, processMgmt));
                ThreadPool.QueueUserWorkItem(SaveVisitData(queueMgmt));

                // wait for the environment key to be read
                if (WaitHandle.WaitAny(new WaitHandle[] {environmentKeyRead}, new TimeSpan(0, 0, 0, 10)) != -1)
                {
                    ProcessMessages(handles.ToArray());
                    queueMgmt.WaitOne();
                }
            }
        }
开发者ID:jayrowe,项目名称:opencover,代码行数:27,代码来源:ProfilerManager.cs


示例16: ComunicationItem

 public ComunicationItem(IConnection argConnection)
 {
     connection = argConnection;
     comunicatsToSend = new ConcurrentQueue<Comunicat>();
     readedData = new StringBuilder();
     readedDatabracketLevel = openBrackets;
 }
开发者ID:Deremius,项目名称:Uraban-Phase-Space,代码行数:7,代码来源:ComunicationItem.cs


示例17: Setup

		public void Setup()
		{
			queue = new ConcurrentQueue<int>();
			for (int i = 0; i < 10; i++) {
				queue.Enqueue(i);
			}
		}
开发者ID:GirlD,项目名称:mono,代码行数:7,代码来源:ConcurrentQueueTests.cs


示例18: VideoPacketDecoderWorker

 public VideoPacketDecoderWorker(PixelFormat pixelFormat, bool skipFrames, Action<VideoFrame> onFrameDecoded)
 {
   _pixelFormat = pixelFormat;
   _skipFrames = skipFrames;
   _onFrameDecoded = onFrameDecoded;
   _packetQueue = new ConcurrentQueue<VideoPacket>();
 }
开发者ID:guozanhua,项目名称:OculusArDroneKinect,代码行数:7,代码来源:VideoPacketDecoderWorker.cs


示例19: PacketManager

        public PacketManager()
        {
            m_vIncomingPackets = new ConcurrentQueue<Message>();
            m_vOutgoingPackets = new ConcurrentQueue<Message>();

            m_vIsRunning = false;
        }
开发者ID:KaskidFoundations,项目名称:ucs,代码行数:7,代码来源:PacketManager.cs


示例20: OnHandlerExecuting

        public IHandlerResult OnHandlerExecuting(Type messageType, object message)
        {
            // First message? Init the bucket and refill timer
            if (this.tokenBucket == null)
            {
                this.tokenBucket = new ConcurrentQueue<byte>(Enumerable.Range(0, this.RatePerSecond).Select(i => (byte)1));
                this.delayInterval = TimeSpan.FromMilliseconds(1000 / this.RatePerSecond);

                this.refillTimer = new Timer((s) =>
                {
                    if (this.tokenBucket.Count < this.RatePerSecond)
                    {
                        this.tokenBucket.Enqueue((byte)1);
                    }
                }, null, 0, (long)this.delayInterval.TotalMilliseconds);
            }

            // Attempt to retrieve a token, if there are none available, delay the message
            byte token;
            if (this.tokenBucket.TryDequeue(out token))
            {
                return this.Success();
            }
            else
            {
                this.log.Value.InfoFormat("Delivery rate limit exceeded - Redelivering message {0} in {1}ms", message.ToString(), this.delayInterval.TotalMilliseconds);
                return this.Delay(this.delayInterval);
            }
        }
开发者ID:WaveServiceBus,项目名称:WaveServiceBus,代码行数:29,代码来源:ThrottleMessages.cs



注:本文中的ConcurrentQueue类示例整理自Github/MSDocs等源码及文档管理平台,相关代码片段筛选自各路编程大神贡献的开源项目,源码版权归原作者所有,传播和使用请参考对应项目的License;未经允许,请勿转载。


鲜花

握手

雷人

路过

鸡蛋
该文章已有0人参与评论

请发表评论

全部评论

专题导读
上一篇:
C# ConcurrentSet类代码示例发布时间:2022-05-24
下一篇:
C# ConcurrentBag类代码示例发布时间:2022-05-24
热门推荐
阅读排行榜

扫描微信二维码

查看手机版网站

随时了解更新最新资讯

139-2527-9053

在线客服(服务时间 9:00~18:00)

在线QQ客服
地址:深圳市南山区西丽大学城创智工业园
电邮:jeky_zhao#qq.com
移动电话:139-2527-9053

Powered by 互联科技 X3.4© 2001-2213 极客世界.|Sitemap