Ejemplo n.º 1
0
        public async Task Send(string message)
        {
            var config = service.LoadConfig();

            this.currentContext = config.EventHubContexts[config.CurrentEventHubContext];

            //await RunAsync(currentContext.ConnectionString, currentContext.EventHubName);
            try
            {
                await using (var producerClient = new EventHubProducerClient(currentContext.ConnectionString, currentContext.EventHubName))
                {
                    // Create a batch of events
                    using EventDataBatch eventBatch = await producerClient.CreateBatchAsync();

                    // Add events to the batch. An event is a represented by a collection of bytes and metadata.
                    eventBatch.TryAdd(new EventData(Encoding.UTF8.GetBytes(message)));
                    //eventBatch.TryAdd(new EventData(Encoding.UTF8.GetBytes("Second event")));
                    //eventBatch.TryAdd(new EventData(Encoding.UTF8.GetBytes("Third event")));

                    // Use the producer client to send the batch of events to the event hub
                    await producerClient.SendAsync(eventBatch);

                    Console.WriteLine("Message sent");
                }
            } catch (Exception ex)
            {
                Console.WriteLine($"Error: {ex.Message}");
            }
        }
Ejemplo n.º 2
0
        public void SetContext(string name, string connectionString, string eventHubName)
        {
            Console.WriteLine($"Setting context {name} with connection {connectionString} and hub {eventHubName}");
            var             config = service.LoadConfig();
            EventHubContext ctxt   = null;

            if (!config.EventHubContexts.TryGetValue(name, out ctxt))
            {
                ctxt = new EventHubContext();
            }

            if (connectionString != null)
            {
                ctxt.ConnectionString = connectionString;
            }

            if (eventHubName != null)
            {
                ctxt.EventHubName = eventHubName;
            }

            config.EventHubContexts[name.ToLower()] = ctxt;

            service.UpdateConfig(config);
        }
        public async Task <EvaluationResult> VerifyEvents(DeviceWebAPIParameters parms)
        {
            parms.Fix(Config);
            var context = new EventHubContext(parms);
            var result  = await context.ReceiveEvents();

            return(result);
        }
        public async Task <EvaluationResult> Endpoint(DeviceWebAPIParameters parms)
        {
            parms.Fix(Config);
            var context = new EventHubContext(parms);
            var result  = await context.TestEndpoint();

            return(result);
        }
Ejemplo n.º 5
0
 public CateringController(EventHubContext context, IMapper mapper)
 {
     this.mapper  = mapper;
     this.context = context;
 }
Ejemplo n.º 6
0
 public HallController(EventHubContext context, IMapper mapper)
 {
     this.mapper  = mapper;
     this.context = context;
 }