当前位置: 首页>>代码示例>>C#>>正文


C# IScheduleService类代码示例

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


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

示例1: DefaultCleanAggregateService

 public DefaultCleanAggregateService(IMemoryCache memoryCache, IScheduleService scheduleService)
 {
     TimeoutSeconds = ENodeConfiguration.Instance.Setting.AggregateRootMaxInactiveSeconds;
     _memoryCache = memoryCache;
     _scheduleService = scheduleService;
     _scheduleService.StartTask("CleanAggregates", Clean, 1000, ENodeConfiguration.Instance.Setting.ScanExpiredAggregateIntervalMilliseconds);
 }
开发者ID:ulswww,项目名称:enode,代码行数:7,代码来源:DefaultCleanAggregateService.cs

示例2: MessageHandler

 public MessageHandler()
 {
     _scheduleService = ObjectContainer.Resolve<IScheduleService>();
     _scheduleService.StartTask("PrintThroughput", PrintThroughput, 1000, 1000);
     _logger = ObjectContainer.Resolve<ILoggerFactory>().Create(typeof(Program).Name);
     _throughputLogger = ObjectContainer.Resolve<ILoggerFactory>().Create("throughput");
 }
开发者ID:uliian,项目名称:equeue,代码行数:7,代码来源:Program.cs

示例3: DisplayLunchViewModel

 public DisplayLunchViewModel(IScheduleService service)
 {
     this.Service = service;
     this.Week = new ObservableCollection<LunchTimeDto>();
     this.WeekView = CollectionViewSource.GetDefaultView(Week);
     this.WeekView.GroupDescriptions.Add(new PropertyGroupDescription("DayOfWeek"));
 }
开发者ID:jibedoubleve,项目名称:geho,代码行数:7,代码来源:DisplayLunchViewModel.cs

示例4: DefaultEventService

 public DefaultEventService(
     IJsonSerializer jsonSerializer,
     IScheduleService scheduleService,
     ITypeNameProvider typeNameProvider,
     IMemoryCache memoryCache,
     IAggregateRootFactory aggregateRootFactory,
     IAggregateStorage aggregateStorage,
     IEventStore eventStore,
     IMessagePublisher<DomainEventStreamMessage> domainEventPublisher,
     IOHelper ioHelper,
     ILoggerFactory loggerFactory)
 {
     _eventMailboxDict = new ConcurrentDictionary<string, EventMailBox>();
     _ioHelper = ioHelper;
     _jsonSerializer = jsonSerializer;
     _scheduleService = scheduleService;
     _typeNameProvider = typeNameProvider;
     _memoryCache = memoryCache;
     _aggregateRootFactory = aggregateRootFactory;
     _aggregateStorage = aggregateStorage;
     _eventStore = eventStore;
     _domainEventPublisher = domainEventPublisher;
     _logger = loggerFactory.Create(GetType().FullName);
     _batchSize = ENodeConfiguration.Instance.Setting.EventMailBoxPersistenceMaxBatchSize;
 }
开发者ID:ulswww,项目名称:enode,代码行数:25,代码来源:DefaultEventService.cs

示例5: ClientService

        public ClientService(ClientSetting setting, Producer producer, Consumer consumer)
        {
            Ensure.NotNull(setting, "setting");
            if (producer == null && consumer == null)
            {
                throw new ArgumentException("producer or consumer must set at least one of them.");
            }
            else if (producer != null && consumer != null)
            {
                throw new ArgumentException("producer or consumer cannot set both of them.");
            }

            Interlocked.Increment(ref _instanceNumber);

            _producer = producer;
            _consumer = consumer;
            _setting = setting;
            _clientId = BuildClientId(setting.ClientName);
            _brokerConnectionDict = new ConcurrentDictionary<string, BrokerConnection>();
            _topicMessageQueueDict = new ConcurrentDictionary<string, IList<MessageQueue>>();
            _binarySerializer = ObjectContainer.Resolve<IBinarySerializer>();
            _jsonSerializer = ObjectContainer.Resolve<IJsonSerializer>();
            _scheduleService = ObjectContainer.Resolve<IScheduleService>();
            _logger = ObjectContainer.Resolve<ILoggerFactory>().Create(GetType().FullName);
            _nameServerRemotingClientList = RemotingClientUtils.CreateRemotingClientList(_setting.NameServerList, _setting.SocketSetting).ToList();
        }
开发者ID:Aaron-Liu,项目名称:equeue,代码行数:26,代码来源:ClientService.cs

示例6: MessageService

 public MessageService(IMessageStore messageStore, IOffsetManager offsetManager, IScheduleService scheduleService)
 {
     _messageStore = messageStore;
     _offsetManager = offsetManager;
     _scheduleService = scheduleService;
     _logger = ObjectContainer.Resolve<ILoggerFactory>().Create(GetType().FullName);
 }
开发者ID:edgevagrant,项目名称:equeue,代码行数:7,代码来源:MessageService.cs

示例7: ChunkWriter

        public ChunkWriter(ChunkManager chunkManager)
        {
            Ensure.NotNull(chunkManager, "chunkManager");

            _chunkManager = chunkManager;
            _scheduleService = ObjectContainer.Resolve<IScheduleService>();
        }
开发者ID:a407121393,项目名称:equeue,代码行数:7,代码来源:ChunkWriter.cs

示例8: ScheduleController

 public ScheduleController(IRepository repository, IScheduleService schedService, ITruckService truckService, IMappingEngine mapper)
 {
     this.repository = repository;
     this.schedService = schedService;
     this.truckService = truckService;
     this.mapper = mapper;
 }
开发者ID:hhorne,项目名称:FoodR,代码行数:7,代码来源:ScheduleController.cs

示例9: ActivityGridViewModel

 public ActivityGridViewModel(IScheduleService service)
 {
     this.Service = service;
     this.Activities = new ObservableCollection<ActivityModel>();
     this.ActivitiesView = CollectionViewSource.GetDefaultView(Activities);
     this.ActivitiesView.GroupDescriptions.Add(new PropertyGroupDescription("DayOfWeek"));
 }
开发者ID:jibedoubleve,项目名称:geho,代码行数:7,代码来源:ActivityGirdViewModel.cs

示例10: Consumer

        public Consumer(string groupName, ConsumerSetting setting)
        {
            if (groupName == null)
            {
                throw new ArgumentNullException("groupName");
            }
            GroupName = groupName;
            Setting = setting ?? new ConsumerSetting();

            _lockObject = new object();
            _subscriptionTopics = new Dictionary<string, HashSet<string>>();
            _topicQueuesDict = new ConcurrentDictionary<string, IList<MessageQueue>>();
            _pullRequestDict = new ConcurrentDictionary<string, PullRequest>();
            _remotingClient = new SocketRemotingClient(Setting.BrokerAddress, Setting.SocketSetting, Setting.LocalAddress);
            _adminRemotingClient = new SocketRemotingClient(Setting.BrokerAdminAddress, Setting.SocketSetting, Setting.LocalAdminAddress);
            _binarySerializer = ObjectContainer.Resolve<IBinarySerializer>();
            _scheduleService = ObjectContainer.Resolve<IScheduleService>();
            _allocateMessageQueueStragegy = ObjectContainer.Resolve<IAllocateMessageQueueStrategy>();
            _logger = ObjectContainer.Resolve<ILoggerFactory>().Create(GetType().FullName);

            _remotingClient.RegisterConnectionEventListener(new ConnectionEventListener(this));

            if (Setting.MessageHandleMode == MessageHandleMode.Sequential)
            {
                _consumingMessageQueue = new BlockingCollection<ConsumingMessage>();
                _consumeMessageWorker = new Worker("ConsumeMessage", () => HandleMessage(_consumingMessageQueue.Take()));
            }
            _messageRetryQueue = new BlockingCollection<ConsumingMessage>();
        }
开发者ID:uliian,项目名称:equeue,代码行数:29,代码来源:Consumer.cs

示例11: Consumer

        public Consumer(string id, string groupName, ConsumerSetting setting)
        {
            if (id == null)
            {
                throw new ArgumentNullException("id");
            }
            if (groupName == null)
            {
                throw new ArgumentNullException("groupName");
            }
            Id = id;
            GroupName = groupName;
            Setting = setting ?? new ConsumerSetting();

            _lockObject = new object();
            _subscriptionTopics = new List<string>();
            _topicQueuesDict = new ConcurrentDictionary<string, IList<MessageQueue>>();
            _pullRequestQueue = new BlockingCollection<PullRequest>(new ConcurrentQueue<PullRequest>());
            _pullRequestDict = new ConcurrentDictionary<string, PullRequest>();
            _consumingMessageQueue = new BlockingCollection<ConsumingMessage>(new ConcurrentQueue<ConsumingMessage>());
            _messageRetryQueue = new BlockingCollection<ConsumingMessage>(new ConcurrentQueue<ConsumingMessage>());
            _handlingMessageDict = new ConcurrentDictionary<long, ConsumingMessage>();
            _taskIds = new List<int>();
            _remotingClient = new SocketRemotingClient(Setting.BrokerAddress, Setting.BrokerPort);
            _binarySerializer = ObjectContainer.Resolve<IBinarySerializer>();
            _scheduleService = ObjectContainer.Resolve<IScheduleService>();
            _allocateMessageQueueStragegy = ObjectContainer.Resolve<IAllocateMessageQueueStrategy>();
            _executePullRequestWorker = new Worker("Consumer.ExecutePullRequest", ExecutePullRequest);
            _handleMessageWorker = new Worker("Consumer.HandleMessage", HandleMessage);
            _logger = ObjectContainer.Resolve<ILoggerFactory>().Create(GetType().FullName);
        }
开发者ID:edgevagrant,项目名称:equeue,代码行数:31,代码来源:Consumer.cs

示例12: Consumer

        public Consumer(string groupName, ConsumerSetting setting)
        {
            if (groupName == null)
            {
                throw new ArgumentNullException("groupName");
            }
            GroupName = groupName;
            Setting = setting ?? new ConsumerSetting();

            _lockObject = new object();
            _subscriptionTopics = new Dictionary<string, HashSet<string>>();
            _topicQueuesDict = new ConcurrentDictionary<string, IList<MessageQueue>>();
            _pullRequestQueue = new BlockingCollection<PullRequest>(new ConcurrentQueue<PullRequest>());
            _pullRequestDict = new ConcurrentDictionary<string, PullRequest>();
            _messageRetryQueue = new BlockingCollection<ConsumingMessage>(new ConcurrentQueue<ConsumingMessage>());
            _taskFactory = new TaskFactory(new LimitedConcurrencyLevelTaskScheduler(Setting.ConsumeThreadMaxCount));
            _remotingClient = new SocketRemotingClient(Setting.BrokerAddress, Setting.SocketSetting, Setting.LocalAddress);
            _adminRemotingClient = new SocketRemotingClient(Setting.BrokerAdminAddress, Setting.SocketSetting, Setting.LocalAdminAddress);
            _binarySerializer = ObjectContainer.Resolve<IBinarySerializer>();
            _scheduleService = ObjectContainer.Resolve<IScheduleService>();
            _allocateMessageQueueStragegy = ObjectContainer.Resolve<IAllocateMessageQueueStrategy>();
            _executePullRequestWorker = new Worker("ExecutePullRequest", ExecutePullRequest);
            _logger = ObjectContainer.Resolve<ILoggerFactory>().Create(GetType().FullName);

            _remotingClient.RegisterConnectionEventListener(new ConnectionEventListener(this));
        }
开发者ID:riiiqpl,项目名称:equeue,代码行数:26,代码来源:Consumer.cs

示例13: ScheduleDisplayViewModel

        public ScheduleDisplayViewModel(IScheduleService service)
        {
            this.RefreshDatesCommand = new RelayCommand(RefreshDates);

            this.Mondays = new ObservableCollection<DateTime>();
            this.Service = service;
        }
开发者ID:jibedoubleve,项目名称:geho,代码行数:7,代码来源:ScheduleDisplayViewModel.cs

示例14: ExaminationDatasheetsController

 public ExaminationDatasheetsController(IGroupService gs, ICourseService cs, IAcademicProgressService aps,
     IScheduleService scs)
 {
     groupService = gs;
     courseService = cs;
     academicProgressService = aps;
     scheduleService = scs;
 }
开发者ID:Firyuza,项目名称:University,代码行数:8,代码来源:ExaminationDatasheetsController.cs

示例15: SendReplyService

 public SendReplyService()
 {
     _clientWrapperDict = new ConcurrentDictionary<string, SocketRemotingClientWrapper>();
     _jsonSerializer = ObjectContainer.Resolve<IJsonSerializer>();
     _scheduleService = ObjectContainer.Resolve<IScheduleService>();
     _ioHelper = ObjectContainer.Resolve<IOHelper>();
     _logger = ObjectContainer.Resolve<ILoggerFactory>().Create(GetType().FullName);
 }
开发者ID:liuxx001,项目名称:BEnode,代码行数:8,代码来源:SendReplyService.cs


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