コード例 #1
0
 public QueueService_should()
 {
     _repositories = CommonHelper.GetService<EndowmentRepositories>();
     _handlers = CommonHelper.GetService<EndowmentHandlers>();
     _moderatorLevelService = CommonHelper.GetService<IModeratorLevelService>();
     _queueService = CommonHelper.GetService<IQueueService>();
 }
コード例 #2
0
 public QueryTopicConsumeInfoRequestHandler()
 {
     _binarySerializer = ObjectContainer.Resolve<IBinarySerializer>();
     _offsetManager = ObjectContainer.Resolve<IOffsetManager>();
     _queueService = ObjectContainer.Resolve<IQueueService>();
     _consumerManager = ObjectContainer.Resolve<ConsumerManager>();
 }
コード例 #3
0
 public DirectoryService(IDirectoryRepository directoryRepository, IQueueService queueService, IQueueRepository queueRepository, ILogger logger)
 {
     _directoryRepository = directoryRepository;
     _queueService = queueService;
     _queueRepository = queueRepository;
     _logger = logger;
 }
コード例 #4
0
 public ConfigureConnectionViewModel(QueueConnectionContext queueConnectionContext, IQueueService queueService, IDialogService dialogService)
 {
     _queueConnectionContext = queueConnectionContext;
     _queueService = queueService;
     _dialogService = dialogService;
     ComputerName = _queueConnectionContext.ComputerName;
 }
コード例 #5
0
ファイル: AdminController.cs プロジェクト: kamlys/Game
 public AdminController(IAdminService adminService,
     IUserService userService,
     IBanService banService,
     IBuildingService buildingService,
     IQueueService queueService,
     IUserBuildingService userBuildingService,
     IUserProductService userProductService,
     IMapService mapService,
     IMarketService marketService,
     IDolarService dolarService,
     IDealService dealService,
     INotificationService notificationService,
     IProductService productService,
     IMessageService messageService,
     IProductRequirementsService productRService)
 {
     _adminService = adminService;
     _userService = userService;
     _banService = banService;
     _buildingService = buildingService;
     _queueService = queueService;
     _userBuildingService = userBuildingService;
     _userProductService = userProductService;
     _mapService = mapService;
     _marketService = marketService;
     _dolarService = dolarService;
     _dealService = dealService;
     _notificationService = notificationService;
     _productService = productService;
     _messageService = messageService;
     _productRService = productRService;
 }
コード例 #6
0
ファイル: MessageService.cs プロジェクト: wangjiepower/equeue
 public MessageService(IQueueService queueService, IMessageStore messageStore, IOffsetManager offsetManager)
 {
     _queueService = queueService;
     _messageStore = messageStore;
     _offsetManager = offsetManager;
     _logger = ObjectContainer.Resolve<ILoggerFactory>().Create(GetType().FullName);
 }
コード例 #7
0
ファイル: TwilioHub.cs プロジェクト: letmeproperty/callcentre
 public TwilioHub(IQueueStateHandler queueStateHandler, IQueueService queueService, IQueueProvider queueProvider, IAgentService agentService)
 {
     _queueStateHandler = queueStateHandler;
     _queueService = queueService;
     _queueProvider = queueProvider;
     _agentService = agentService;
 }
コード例 #8
0
ファイル: MessageProcessor.cs プロジェクト: gobixm/learn
 public MessageProcessor(IMessageProcessorConfiguration messageProcessorConfiguration, IQueueService queueService,
                         IMessageSerializationService messageSerializationService)
 {
     _messageProcessorConfiguration = messageProcessorConfiguration;
     _queueService = queueService;
     _messageSerializationService = messageSerializationService;
     _queueService.RegisterConsumer(HandleMessageFromQueue);
 }
コード例 #9
0
 public CallStatsService(ICallRepository callRepository, IQueueService queueService, IAgentService agentService, IQueueProvider queueProvider, IQueueStateHandler queueStateHandler)
 {
     _callRepository = callRepository;
     _queueService = queueService;
     _agentService = agentService;
     _queueProvider = queueProvider;
     _queueStateHandler = queueStateHandler;
 }
コード例 #10
0
ファイル: QueueSpecification.cs プロジェクト: Djohnnie/Sonarr
 public QueueSpecification(IQueueService queueService,
                                QualityUpgradableSpecification qualityUpgradableSpecification,
                                Logger logger)
 {
     _queueService = queueService;
     _qualityUpgradableSpecification = qualityUpgradableSpecification;
     _logger = logger;
 }
コード例 #11
0
 public ProjectEditService(
     EndowmentRepositories endowmentRepositories,
     EndowmentHandlers endowmentHandlers,
     IQueueService queueService)
 {
     _endowmentRepositories = endowmentRepositories;
     _endowmentHandlers = endowmentHandlers;
     _queueService = queueService;
 }
コード例 #12
0
        public InteractionManager(Session session, IQueueService queueService, ITraceContext traceContext)
        {
            _traceContext = traceContext;
            _interactionManager = InteractionsManager.GetInstance(session);
            _queueService = queueService;

            //We could use icelib to get the queue and interactions, but the AddIn API wraps things up to be a little simpler to use.
            _myInteractionsQueue = _queueService.GetMyInteractions(new[] { InteractionAttributes.State });
        }
コード例 #13
0
ファイル: Program.cs プロジェクト: eleks/FloatingQueuePoC
        static void DoGet(IQueueService proxy, string[] args)
        {
            try
            {
                bool getAll = false;
                if (args[0] == "all")
                {
                    getAll = true;
                    args = args.Skip(1).ToArray();
                }

                var aggregateId = args[0];
                int version;
                if (args.Length > 1)
                    version = int.Parse(args[1]);
                else
                {
                    if (getAll)
                        version = -1;
                    else
                        throw new ArgumentException("Version must be specified if exact version is requested");
                }

                if (getAll)
                {
                    var results = proxy.GetAllNext(aggregateId, version);
                    if (results.Count() == 0)
                    {
                        Logger.Instance.Warn("There's no objects in aggregate '{0}' with version > {1}",
                            aggregateId, version);
                    }
                    else
                    {
                        foreach (var result in results)
                            Logger.Instance.Info(result.ToString());
                    }
                }
                else
                {
                    object obj;
                    if (proxy.TryGetNext(aggregateId,version, out obj))
                    {
                        Logger.Instance.Info(obj.ToString());
                    }
                    else
                    {
                        Logger.Instance.Warn("Theres' no object in aggregate '{0}' with version {1}",aggregateId, version);
                    }
                }
            }
            catch (Exception ex)
            {
                Logger.Instance.Error("Unhandled Exception", ex);
                ShowUsage();
            }
        }
コード例 #14
0
 public TwilioVoiceController(IQueueStateHandler queueStateHandler, IAccountSettings accountSettings, ILogger logger, ICallService callService, IQueueService queueService, IQueueProvider queueProvider, IAgentService agentService)
 {
     _queueStateHandler = queueStateHandler;
     _accountSettings = accountSettings;
     _logger = logger;
     _callService = callService;
     _queueService = queueService;
     _queueProvider = queueProvider;
     _agentService = agentService;
 }
コード例 #15
0
 public PullMessageRequestHandler()
 {
     _consumerManager = ObjectContainer.Resolve<ConsumerManager>();
     _suspendedPullRequestManager = ObjectContainer.Resolve<SuspendedPullRequestManager>();
     _messageService = ObjectContainer.Resolve<IMessageService>();
     _queueService = ObjectContainer.Resolve<IQueueService>();
     _offsetManager = ObjectContainer.Resolve<IOffsetManager>();
     _binarySerializer = ObjectContainer.Resolve<IBinarySerializer>();
     _logger = ObjectContainer.Resolve<ILoggerFactory>().Create(GetType().FullName);
     EmptyResponseData = new byte[0];
 }
コード例 #16
0
ファイル: ProjectService.cs プロジェクト: Apostol59/Endowment
 public ProjectService(
     IQueueService queueService,
     IProjectEditService projectEditService,
     EndowmentHandlers endowmentHandlers,
     EndowmentRepositories repositories)
 {
     _queueService = queueService;
     _projectEditService = projectEditService;
     _endowmentHandlers = endowmentHandlers;
     _repositories = repositories;
 }
コード例 #17
0
 private BrokerController(BrokerSetting setting)
 {
     Setting = setting ?? new BrokerSetting();
     _consumerManager = ObjectContainer.Resolve<ConsumerManager>();
     _messageStore = ObjectContainer.Resolve<IMessageStore>();
     _offsetManager = ObjectContainer.Resolve<IOffsetManager>();
     _queueService = ObjectContainer.Resolve<IQueueService>();
     _messageService = ObjectContainer.Resolve<IMessageService>();
     _suspendedPullRequestManager = ObjectContainer.Resolve<SuspendedPullRequestManager>();
     _producerSocketRemotingServer = new SocketRemotingServer("EQueue.Broker.ProducerRemotingServer", Setting.ProducerIPEndPoint);
     _consumerSocketRemotingServer = new SocketRemotingServer("EQueue.Broker.ConsumerRemotingServer", Setting.ConsumerIPEndPoint, this);
     _adminSocketRemotingServer = new SocketRemotingServer("EQueue.Broker.AdminRemotingServer", Setting.AdminIPEndPoint);
     _logger = ObjectContainer.Resolve<ILoggerFactory>().Create(GetType().FullName);
     RegisterRequestHandlers();
 }
コード例 #18
0
        public InteractionSyncManager(IInteractionManager interactionManager, IDeviceManager deviceManager, IQueueService queueService, ITraceContext traceContext, IConnection connection)
        {
            _interactionManager = interactionManager;
            _deviceManager = deviceManager;
            _traceContext = traceContext;

            _connection = connection;
            _connection.UpChanged += OnConnectionUpChanged;

            _deviceManager.CallAnsweredByDevice += OnCallAnsweredByDevice;
            _deviceManager.CallEndedByDevice += OnCallEndedByDevice;
            _deviceManager.MuteChanged += OnMuteChangedByDevice;
            _deviceManager.OnCall += OnOnCall;
            //    _deviceManager.TalkButtonPressed += OnTalkButtonPressed;
            _deviceManager.TalkButtonHeld += OnTalkButtonHeld;

            _myInteractions = queueService.GetMyInteractions(new[] { InteractionAttributes.State, InteractionAttributes.Muted });
            _myInteractions.InteractionAdded += OnInteractionAdded;
            _myInteractions.InteractionChanged += OnInteractionChanged;
            _myInteractions.InteractionRemoved += OnInteractionRemoved;
        }
コード例 #19
0
        public TestSaveContact()
        {
            var contacts = new[]
            {
                new Contact
                {
                    Id = 1,
                    FirstName = "First",
                    LastName = "Last",
                    Email = "*****@*****.**",
                    PhoneNumber = "555-1212"
                },
            }.ToDbSet();

            _db = A.Fake<ContactDb>();
            A.CallTo(() => _db.Contacts).Returns(contacts);

            _appContext = A.Fake<AppContext>();
            _queue = A.Fake<IQueueService>();
            _mediator = A.Fake<IMediator>();

            _handler = new SaveContact.Handler(_db, _appContext, _queue, _mediator);
        }
コード例 #20
0
ファイル: LogsController.cs プロジェクト: mrpastewart/Core
 public LogsController(IDepartmentsService departmentsService, IUsersService usersService, ICallsService callsService,
                       IDepartmentGroupsService departmentGroupsService, ICommunicationService communicationService, IQueueService queueService,
                       Model.Services.IAuthorizationService authorizationService, IWorkLogsService workLogsService, IEventAggregator eventAggregator)
 {
     _departmentsService      = departmentsService;
     _usersService            = usersService;
     _callsService            = callsService;
     _departmentGroupsService = departmentGroupsService;
     _communicationService    = communicationService;
     _queueService            = queueService;
     _authorizationService    = authorizationService;
     _workLogsService         = workLogsService;
     _eventAggregator         = eventAggregator;
 }
コード例 #21
0
ファイル: Program.cs プロジェクト: eleks/FloatingQueuePoC
 static void DoPush(IQueueService proxy, string[] args)
 {
     try
     {
         proxy.Push(args[0], int.Parse(args[1]), args[2]);
     }
     catch (Exception ex)
     {
         Logger.Instance.Error("Unhandled Exception", ex);
         ShowUsage();
     }
 }
コード例 #22
0
 public HoroscopeController(IHoroscopeGateway horoscopeGateway, IQueueService queueService)
 {
     _horoscopeGateway = horoscopeGateway;
     _queueService     = queueService;
 }
コード例 #23
0
 public Handler(
     IQueueService queueService)
 {
     _queueService = queueService;
 }
コード例 #24
0
 public DataTransferController(IFileStorageServiceCommon fileStorageService,
                               IQueueService queueService)
 {
     this.fileStorageService = fileStorageService;
     this.queueService       = queueService;
 }
コード例 #25
0
 public LogViewModel(IErrorService errorService, ILogInstanceManager logInstanceManager, IQueueService queueService)
 {
     this.errorService       = errorService;
     this.logInstanceManager = logInstanceManager;
     this.queueService       = queueService;
     this.Title = Resources.LogViewModel_Title;
 }
コード例 #26
0
 public CsvImporterService(IJobsService jobsService, ICloudStorageService cloudStorageService, IQueueService queueService)
 {
     _jobsService         = jobsService;
     _cloudStorageService = cloudStorageService;
     _queueService        = queueService;
 }
コード例 #27
0
 public QueryTopicQueueInfoRequestHandler()
 {
     _binarySerializer = ObjectContainer.Resolve <IBinarySerializer>();
     _queueService     = ObjectContainer.Resolve <IQueueService>();
     _offsetManager    = ObjectContainer.Resolve <IOffsetManager>();
 }
コード例 #28
0
 public ImportMessageBodyViewModel(IQueueService queueService, IDialogService dialogService)
 {
     _queueService      = queueService;
     _dialogService     = dialogService;
     UseDeadLetterQueue = true;
 }
コード例 #29
0
 public NotInQueueSpecification(IQueueService queueService, Logger logger)
 {
     _queueService = queueService;
     _logger = logger;
 }
コード例 #30
0
 public CallStatsController(ICallStatsService callStatsService, IQueueStateHandler queueStateHandler, IQueueService queueService)
 {
     _callStatsService = callStatsService;
     _queueStateHandler = queueStateHandler;
     _queueService = queueService;
 }
コード例 #31
0
ファイル: QueueModule.cs プロジェクト: scottrice/NzbDrone
 public QueueModule(ICommandExecutor commandExecutor, IQueueService queueService)
     : base(commandExecutor)
 {
     _queueService  = queueService;
     GetResourceAll = GetQueue;
 }
コード例 #32
0
        public async Task <Tuple <bool, string> > Process(CallEmailQueueItem item)
        {
            bool   success = true;
            string result  = "";

            _callEmailProvider = Bootstrapper.GetKernel().Resolve <ICallEmailProvider>();

            if (!String.IsNullOrWhiteSpace(item?.EmailSettings?.Hostname))
            {
                CallEmailsResult emailResult = _callEmailProvider.GetAllCallEmailsFromServer(item.EmailSettings);

                if (emailResult?.Emails != null && emailResult.Emails.Count > 0)
                {
                    var calls = new List <Call>();

                    _callsService              = Bootstrapper.GetKernel().Resolve <ICallsService>();
                    _queueService              = Bootstrapper.GetKernel().Resolve <IQueueService>();
                    _departmentsService        = Bootstrapper.GetKernel().Resolve <IDepartmentsService>();
                    _userProfileService        = Bootstrapper.GetKernel().Resolve <IUserProfileService>();
                    _departmentSettingsService = Bootstrapper.GetKernel().Resolve <IDepartmentSettingsService>();
                    _unitsService              = Bootstrapper.GetKernel().Resolve <IUnitsService>();

                    // Ran into an issue where the department users didn't come back. We can't put the email back in the POP
                    // email box so just added some simple retry logic here.
                    List <IdentityUser> departmentUsers = await _departmentsService.GetAllUsersForDepartmentAsync(item.EmailSettings.DepartmentId, true);

                    var profiles = await _userProfileService.GetAllProfilesForDepartmentAsync(item.EmailSettings.DepartmentId);

                    int retry = 0;
                    while (retry < 3 && departmentUsers == null)
                    {
                        Thread.Sleep(150);
                        departmentUsers = await _departmentsService.GetAllUsersForDepartmentAsync(item.EmailSettings.DepartmentId, true);

                        retry++;
                    }

                    foreach (var email in emailResult.Emails)
                    {
                        var activeCalls = await _callsService.GetActiveCallsByDepartmentAsync(item.EmailSettings.Department.DepartmentId);

                        var units = await _unitsService.GetUnitsForDepartmentAsync(item.EmailSettings.Department.DepartmentId);

                        var priorities = await _callsService.GetActiveCallPrioritiesForDepartmentAsync(item.EmailSettings.Department.DepartmentId);

                        int defaultPriority = (int)CallPriority.High;

                        if (priorities != null && priorities.Any())
                        {
                            var defaultPrio = priorities.FirstOrDefault(x => x.IsDefault && x.IsDeleted == false);

                            if (defaultPrio != null)
                            {
                                defaultPriority = defaultPrio.DepartmentCallPriorityId;
                            }
                        }

                        var call = _callsService.GenerateCallFromEmail(item.EmailSettings.FormatType, email,
                                                                       item.EmailSettings.Department.ManagingUserId, departmentUsers, item.EmailSettings.Department, activeCalls, units, defaultPriority, priorities);

                        if (call != null)
                        {
                            call.DepartmentId = item.EmailSettings.DepartmentId;

                            if (!calls.Any(x => x.Name == call.Name && x.NatureOfCall == call.NatureOfCall))
                            {
                                calls.Add(call);
                            }
                        }
                    }

                    if (calls.Any())
                    {
                        var departmentTextNumber = await _departmentSettingsService.GetTextToCallNumberForDepartmentAsync(item.EmailSettings.DepartmentId);

                        foreach (var call in calls)
                        {
                            try
                            {
                                // Adding this in here to try and fix the error below with ObjectContext issues.
                                var newCall = CreateNewCallFromCall(call);

                                if (newCall.Dispatches != null && newCall.Dispatches.Any())
                                {
                                    // We've been having this error here:
                                    //      The relationship between the two objects cannot be defined because they are attached to different ObjectContext objects.
                                    // So I'm wrapping this in a try catch to prevent all calls form being dropped.
                                    var savedCall = await _callsService.SaveCallAsync(newCall);

                                    var cqi = new CallQueueItem();
                                    cqi.Call = savedCall;

                                    cqi.Profiles             = profiles.Values.ToList();
                                    cqi.DepartmentTextNumber = departmentTextNumber;

                                    await _queueService.EnqueueCallBroadcastAsync(cqi);
                                }
                            }
                            catch (Exception ex)
                            {
                                result = ex.ToString();
                                Logging.LogException(ex);
                            }
                        }
                    }

                    await _departmentsService.SaveDepartmentEmailSettingsAsync(emailResult.EmailSettings);

                    _callsService              = null;
                    _queueService              = null;
                    _departmentsService        = null;
                    _callEmailProvider         = null;
                    _userProfileService        = null;
                    _departmentSettingsService = null;
                }
            }

            return(new Tuple <bool, string>(success, result));
        }
コード例 #33
0
 public PaymentController(IQueueService queueService, ITransactionAppService transactionAppService, ICashFlowService cashFlowService)
 {
     _transactionAppService = transactionAppService;
     _cashFlowService       = cashFlowService;
 }
コード例 #34
0
 public TwilioController(IDepartmentSettingsService departmentSettingsService, INumbersService numbersService,
                         ILimitsService limitsService, ICallsService callsService, IQueueService queueService, IDepartmentsService departmentsService,
                         IUserProfileService userProfileService, ITextCommandService textCommandService, IActionLogsService actionLogsService,
                         IUserStateService userStateService, ICommunicationService communicationService, IGeoLocationProvider geoLocationProvider,
                         IDepartmentGroupsService departmentGroupsService, ICustomStateService customStateService, IUnitsService unitsService)
 {
     _departmentSettingsService = departmentSettingsService;
     _numbersService            = numbersService;
     _limitsService             = limitsService;
     _callsService            = callsService;
     _queueService            = queueService;
     _departmentsService      = departmentsService;
     _userProfileService      = userProfileService;
     _textCommandService      = textCommandService;
     _actionLogsService       = actionLogsService;
     _userStateService        = userStateService;
     _communicationService    = communicationService;
     _geoLocationProvider     = geoLocationProvider;
     _departmentGroupsService = departmentGroupsService;
     _customStateService      = customStateService;
     _unitsService            = unitsService;
 }
コード例 #35
0
 public BuildingQueueController(IQueueService queueTable)
 {
     _queueTable = queueTable;
 }
コード例 #36
0
 public SitesController(ISiteService siteService, IQueueService queueService)
 {
     this.siteService  = siteService;
     this.queueService = queueService;
 }
コード例 #37
0
 public FascicleController(IFascicleService service, IDataUnitOfWork unitOfWork, ILogger logger, ICurrentIdentity currentIdentity, IQueueService queueService, ICQRSMessageMapper CQRSMapper,
                           IResolutionModelMapper mapper, IMapperUnitOfWork mapperUnitOfWork, IParameterEnvService parameterEnvService)
     : base(service, unitOfWork, logger)
 {
     _unitOfWork          = unitOfWork;
     _currentIdentity     = currentIdentity;
     _cqrsMapper          = CQRSMapper;
     _queueService        = queueService;
     _logger              = logger;
     _mapper              = mapper;
     _mapperUnitOfwork    = mapperUnitOfWork;
     _parameterEnvService = parameterEnvService;
 }
コード例 #38
0
 public JournalQueueTreeNodeViewModel(IEventAggregator eventAggregator, MessageQueue journalQueue, IQueueService queueService, IDialogService dialogService)
 {
     _eventAggregator = eventAggregator;
     _journalQueue    = journalQueue;
     _queueService    = queueService;
     _dialogService   = dialogService;
     _eventAggregator.Subscribe(this);
 }
コード例 #39
0
 public HomeController(IQueueService queueService)
 {
     _queueService = queueService;
 }
コード例 #40
0
 public OrdersController(IOrdersProvider ordersProvider, IQueueService queueService, ILogger <OrdersController> logger)
 {
     this.ordersProvider = ordersProvider;
     this.queueService   = queueService;
     this.logger         = logger;
 }
コード例 #41
0
 public SystemService(IUserSettingService userSettingService, ILog logService, IQueueService queueService)
 {
     this.log                = logService;
     this.queueService       = queueService;
     this.userSettingService = userSettingService;
 }
コード例 #42
0
 public ConfigureConnectionViewModel(QueueConnectionContext queueConnectionContext, IQueueService queueService, IDialogService dialogService)
 {
     _queueConnectionContext = queueConnectionContext;
     _queueService           = queueService;
     _dialogService          = dialogService;
     ComputerName            = _queueConnectionContext.ComputerName;
 }
コード例 #43
0
 public ProcessDepartmentDepartment_delete_others_normal(IRepositoryFactory departmentRepository, Func <string, IRepositoryFactory> repositoryAccessor, IQueueService queueService)
 {
     _repositoryAccessor = repositoryAccessor;
     _repository         = _repositoryAccessor("EF");
 }
コード例 #44
0
 public CreateNewMessageViewModel(IQueueService queueService, IDialogService dialogService)
 {
     _queueService = queueService;
     _dialogService = dialogService;
 }
コード例 #45
0
 public ImagesController(IBlobService service, IQueueService queueService)
 {
     this.service      = service;
     this.queueService = queueService;
 }
コード例 #46
0
 public GetTopicQueueIdsForProducerRequestHandler()
 {
     _queueService = ObjectContainer.Resolve<IQueueService>();
 }
コード例 #47
0
 public ConsumingService(IQueueService queueService,
                         ILogger <ConsumingService> logger)
 {
     this.logger       = logger;
     this.queueService = queueService;
 }
コード例 #48
0
 public SuspendedPullRequestManager()
 {
     _scheduleService = ObjectContainer.Resolve<IScheduleService>();
     _queueService = ObjectContainer.Resolve<IQueueService>();
     _logger = ObjectContainer.Resolve<ILoggerFactory>().Create(GetType().FullName);
 }
コード例 #49
0
        public async Task <ActionResult> Log(object request, [FromServices] IQueueService queue)
        {
            await queue.Send(request);

            return(Ok());
        }
コード例 #50
0
 public ImportMessageBodyViewModel(IQueueService queueService, IDialogService dialogService)
 {
     _queueService = queueService;
     _dialogService = dialogService;
     UseDeadLetterQueue = true;
 }
コード例 #51
0
 public DownloadHub(IQueueService <DownloadRequestBM> queue, IFilenameDatabase filenameDatabase, IDownloadManagementService downloaderService)
 {
     this.downloadServiceQueue = queue;
     this.filenameDatabase     = filenameDatabase;
     this.downloaderService    = downloaderService;
 }
コード例 #52
0
 public ServiceBusQueueServiceTests()
 {
     _serviceBusFactoryMock = new Mock <IServiceBusFactory>();
     _queueService          = new ServiceBusQueueService(_serviceBusFactoryMock.Object);
 }
コード例 #53
0
 public ProxyService(IQueueService queueService)
 {
     this._queueService = queueService;
     InitializeComponent();
 }
コード例 #54
0
 public QueueManagerService(IQueueService queueService, DiscordSocketClient discordClient)
 {
     _queueService  = queueService;
     _discordClient = discordClient;
 }
コード例 #55
0
 public NotInQueueSpecification(IQueueService queueService, Logger logger)
 {
     _queueService = queueService;
     _logger       = logger;
 }
コード例 #56
0
ファイル: HomeController.cs プロジェクト: r2musings/AzureBits
 public HomeController(IImageService imageService,  IQueueService<UploadedImage> queueService)
 {
     _imageService = imageService;
     _queueService = queueService;
 }
コード例 #57
0
 public AddQueueRequestHandler()
 {
     _binarySerializer = ObjectContainer.Resolve<IBinarySerializer>();
     _queueService = ObjectContainer.Resolve<IQueueService>();
 }
コード例 #58
0
 public EmailController(IDepartmentSettingsService departmentSettingsService, INumbersService numbersService,
                        ILimitsService limitsService, ICallsService callsService, IQueueService queueService, IDepartmentsService departmentsService,
                        IUserProfileService userProfileService, ITextCommandService textCommandService, IActionLogsService actionLogsService,
                        IUserStateService userStateService, ICommunicationService communicationService, IDistributionListsService distributionListsService,
                        IUsersService usersService, IEmailService emailService, IDepartmentGroupsService departmentGroupsService, IMessageService messageService,
                        IFileService fileService, IUnitsService unitsService)
 {
     _departmentSettingsService = departmentSettingsService;
     _numbersService            = numbersService;
     _limitsService             = limitsService;
     _callsService             = callsService;
     _queueService             = queueService;
     _departmentsService       = departmentsService;
     _userProfileService       = userProfileService;
     _textCommandService       = textCommandService;
     _actionLogsService        = actionLogsService;
     _userStateService         = userStateService;
     _communicationService     = communicationService;
     _distributionListsService = distributionListsService;
     _usersService             = usersService;
     _emailService             = emailService;
     _departmentGroupsService  = departmentGroupsService;
     _messageService           = messageService;
     _fileService  = fileService;
     _unitsService = unitsService;
 }
コード例 #59
0
 public QueueStateHandler(IQueueService queueService, ILogger logger, IQueueProvider queueProvider)
 {
     _queueService = queueService;
     _logger = logger;
     _queueProvider = queueProvider;
 }
コード例 #60
0
 public OrderController(ILogger <OrderController> logger, IQueueService queueService, ITableService tableService)
 {
     _qService = queueService;
     _tService = tableService;
     _logger   = logger;
 }