當前位置: 首頁>>代碼示例>>Python>>正文


Python CarbonClientManager.startClient方法代碼示例

本文整理匯總了Python中carbon.client.CarbonClientManager.startClient方法的典型用法代碼示例。如果您正苦於以下問題:Python CarbonClientManager.startClient方法的具體用法?Python CarbonClientManager.startClient怎麽用?Python CarbonClientManager.startClient使用的例子?那麽, 這裏精選的方法代碼示例或許可以為您提供幫助。您也可以進一步了解該方法所在carbon.client.CarbonClientManager的用法示例。


在下文中一共展示了CarbonClientManager.startClient方法的5個代碼示例,這些例子默認根據受歡迎程度排序。您可以為喜歡或者感覺有用的代碼點讚,您的評價將有助於係統推薦出更棒的Python代碼示例。

示例1: createRelayService

# 需要導入模塊: from carbon.client import CarbonClientManager [as 別名]
# 或者: from carbon.client.CarbonClientManager import startClient [as 別名]
def createRelayService(config):
    from carbon.routers import RelayRulesRouter, ConsistentHashingRouter, AggregatedConsistentHashingRouter
    from carbon.client import CarbonClientManager
    from carbon.conf import settings
    from carbon import events

    root_service = createBaseService(config)

    # Configure application components
    if settings.RELAY_METHOD == 'rules':
      router = RelayRulesRouter(settings["relay-rules"])
    elif settings.RELAY_METHOD == 'consistent-hashing':
      router = ConsistentHashingRouter(settings.REPLICATION_FACTOR)
    elif settings.RELAY_METHOD == 'aggregated-consistent-hashing':
      from carbon.aggregator.rules import RuleManager
      RuleManager.read_from(settings["aggregation-rules"])
      router = AggregatedConsistentHashingRouter(RuleManager, settings.REPLICATION_FACTOR)

    client_manager = CarbonClientManager(router)
    client_manager.setServiceParent(root_service)

    events.metricReceived.addHandler(client_manager.sendDatapoint)
    events.metricGenerated.addHandler(client_manager.sendDatapoint)
    events.specialMetricReceived.addHandler(client_manager.sendHighPriorityDatapoint)
    events.specialMetricGenerated.addHandler(client_manager.sendHighPriorityDatapoint)

    if not settings.DESTINATIONS:
      raise CarbonConfigException("Required setting DESTINATIONS is missing from carbon.conf")

    for destination in util.parseDestinations(settings.DESTINATIONS):
      client_manager.startClient(destination)

    return root_service
開發者ID:laiwei,項目名稱:carbon,代碼行數:35,代碼來源:service.py

示例2: createAggregatorService

# 需要導入模塊: from carbon.client import CarbonClientManager [as 別名]
# 或者: from carbon.client.CarbonClientManager import startClient [as 別名]
def createAggregatorService(config):
    from carbon.aggregator import receiver
    from carbon.aggregator.rules import RuleManager
    from carbon.routers import ConsistentHashingRouter
    from carbon.client import CarbonClientManager
    from carbon.rewrite import RewriteRuleManager
    from carbon.conf import settings
    from carbon import events

    root_service = createBaseService(config)

    # Configure application components
    router = ConsistentHashingRouter()
    client_manager = CarbonClientManager(router)
    client_manager.setServiceParent(root_service)

    events.metricReceived.addHandler(receiver.process)
    events.metricGenerated.addHandler(client_manager.sendDatapoint)

    RuleManager.read_from(settings["aggregation-rules"])
    if exists(settings["rewrite-rules"]):
        RewriteRuleManager.read_from(settings["rewrite-rules"])

    if not settings.DESTINATIONS:
      raise CarbonConfigException("Required setting DESTINATIONS is missing from carbon.conf")

    for destination in util.parseDestinations(settings.DESTINATIONS):
      client_manager.startClient(destination)

    return root_service
開發者ID:laiwei,項目名稱:carbon,代碼行數:32,代碼來源:service.py

示例3: CarbonClientManagerTest

# 需要導入模塊: from carbon.client import CarbonClientManager [as 別名]
# 或者: from carbon.client.CarbonClientManager import startClient [as 別名]
class CarbonClientManagerTest(TestCase):
    timeout = 1.0

    def setUp(self):
        self.router_mock = Mock(spec=DatapointRouter)
        self.factory_mock = Mock(spec=CarbonClientFactory)
        self.factory_patch = patch("carbon.client.CarbonClientFactory", new=self.factory_mock)
        self.factory_patch.start()
        self.client_mgr = CarbonClientManager(self.router_mock)

    def tearDown(self):
        self.factory_patch.stop()

    @patch("signal.signal", new=Mock())
    def test_start_service_installs_sig_ignore(self, signal_mock):
        from signal import SIGHUP, SIG_IGN

        self.client_mgr.startService()
        signal_mock.assert_called_once_with(SIGHUP, SIG_IGN)

    def test_start_service_starts_factory_connect(self):
        factory_mock = Mock(spec=CarbonClientFactory)
        factory_mock.started = False
        self.client_mgr.client_factories[("127.0.0.1", 2003, "a")] = factory_mock
        self.client_mgr.startService()
        factory_mock.startConnecting.assert_called_once_with()

    def test_stop_service_waits_for_clients_to_disconnect(self):
        dest = ("127.0.0.1", 2003, "a")
        self.client_mgr.startService()
        self.client_mgr.startClient(dest)

        disconnect_deferred = Deferred()
        reactor.callLater(0.1, disconnect_deferred.callback, 0)
        self.factory_mock.return_value.disconnect.return_value = disconnect_deferred
        return self.client_mgr.stopService()

    def test_start_client_instantiates_client_factory(self):
        dest = ("127.0.0.1", 2003, "a")
        self.client_mgr.startClient(dest)
        self.factory_mock.assert_called_once_with(dest)

    def test_start_client_ignores_duplicate(self):
        dest = ("127.0.0.1", 2003, "a")
        self.client_mgr.startClient(dest)
        self.client_mgr.startClient(dest)
        self.factory_mock.assert_called_once_with(dest)

    def test_start_client_starts_factory_if_running(self):
        dest = ("127.0.0.1", 2003, "a")
        self.client_mgr.startService()
        self.client_mgr.startClient(dest)
        self.factory_mock.return_value.startConnecting.assert_called_once_with()

    def test_start_client_adds_destination_to_router(self):
        dest = ("127.0.0.1", 2003, "a")
        self.client_mgr.startClient(dest)
        self.router_mock.addDestination.assert_called_once_with(dest)

    def test_stop_client_removes_destination_from_router(self):
        dest = ("127.0.0.1", 2003, "a")
        self.client_mgr.startClient(dest)
        self.client_mgr.stopClient(dest)
        self.router_mock.removeDestination.assert_called_once_with(dest)
開發者ID:iksaif,項目名稱:carbon,代碼行數:66,代碼來源:test_client.py

示例4: createService

# 需要導入模塊: from carbon.client import CarbonClientManager [as 別名]
# 或者: from carbon.client.CarbonClientManager import startClient [as 別名]
def createService(options):
    """Create a txStatsD service."""
    from carbon.routers import ConsistentHashingRouter
    from carbon.client import CarbonClientManager
    from carbon.conf import settings

    settings.MAX_QUEUE_SIZE = options["max-queue-size"]
    settings.MAX_DATAPOINTS_PER_MESSAGE = options["max-datapoints-per-message"]

    root_service = MultiService()
    root_service.setName("statsd")

    prefix = options["prefix"]
    if prefix is None:
        prefix = "statsd"

    instance_name = options["instance-name"]
    if not instance_name:
        instance_name = platform.node()

    # initialize plugins
    plugin_metrics = []
    for plugin in getPlugins(IMetricFactory):
        plugin.configure(options)
        plugin_metrics.append(plugin)

    processor = None
    if options["dump-mode"]:
        # LoggingMessageProcessor supersedes
        #  any other processor class in "dump-mode"
        assert not hasattr(log, 'info')
        log.info = log.msg  # for compatibility with LMP logger interface
        processor = functools.partial(LoggingMessageProcessor, logger=log)

    if options["statsd-compliance"]:
        processor = (processor or MessageProcessor)(plugins=plugin_metrics)
        input_router = Router(processor, options['routing'], root_service)
        connection = InternalClient(input_router)
        metrics = Metrics(connection)
    else:
        processor = (processor or ConfigurableMessageProcessor)(
            message_prefix=prefix,
            internal_metrics_prefix=prefix + "." + instance_name + ".",
            plugins=plugin_metrics)
        input_router = Router(processor, options['routing'], root_service)
        connection = InternalClient(input_router)
        metrics = ExtendedMetrics(connection)

    if not options["carbon-cache-host"]:
        options["carbon-cache-host"].append("127.0.0.1")
    if not options["carbon-cache-port"]:
        options["carbon-cache-port"].append(2004)
    if not options["carbon-cache-name"]:
        options["carbon-cache-name"].append(None)

    reporting = ReportingService(instance_name)
    reporting.setServiceParent(root_service)

    reporting.schedule(report_client_manager_stats,
                       options["flush-interval"] / 1000,
                       metrics.gauge)

    if options["report"] is not None:
        from txstatsd import process
        from twisted.internet import reactor

        reporting.schedule(
            process.report_reactor_stats(reactor), 60, metrics.gauge)
        reports = [name.strip() for name in options["report"].split(",")]
        for report_name in reports:
            if report_name == "reactor":
                inspector = ReactorInspectorService(reactor, metrics,
                                                    loop_time=0.05)
                inspector.setServiceParent(root_service)

            for reporter in getattr(process, "%s_STATS" %
                                    report_name.upper(), ()):
                reporting.schedule(reporter, 60, metrics.gauge)

    # XXX Make this configurable.
    router = ConsistentHashingRouter()
    carbon_client = CarbonClientManager(router)
    carbon_client.setServiceParent(root_service)

    for host, port, name in zip(options["carbon-cache-host"],
                                options["carbon-cache-port"],
                                options["carbon-cache-name"]):
        carbon_client.startClient((host, port, name))

    statsd_service = StatsDService(carbon_client, input_router,
                                   options["flush-interval"])
    statsd_service.setServiceParent(root_service)

    statsd_server_protocol = StatsDServerProtocol(
        input_router,
        monitor_message=options["monitor-message"],
        monitor_response=options["monitor-response"])

    listener = UDPServer(options["listen-port"], statsd_server_protocol)
    listener.setServiceParent(root_service)
#.........這裏部分代碼省略.........
開發者ID:Weasyl,項目名稱:txstatsd,代碼行數:103,代碼來源:service.py

示例5: ConsistentHashingRouter

# 需要導入模塊: from carbon.client import CarbonClientManager [as 別名]
# 或者: from carbon.client.CarbonClientManager import startClient [as 別名]
if options.routing == 'consistent-hashing':
  router = ConsistentHashingRouter(options.replication, diverse_replicas=options.diverse_replicas)
elif options.routing == 'relay':
  if exists(options.relayrules):
    router = RelayRulesRouter(options.relayrules)
  else:
    print("relay rules file %s does not exist" % options.relayrules)
    raise SystemExit(1)

client_manager = CarbonClientManager(router)
reactor.callWhenRunning(client_manager.startService)

if options.keyfunc:
  router.setKeyFunctionFromModule(options.keyfunc)

firstConnectAttempts = [client_manager.startClient(dest) for dest in destinations]
firstConnectsAttempted = defer.DeferredList(firstConnectAttempts)


class StdinMetricsReader(LineReceiver):
  delimiter = '\n'

  def lineReceived(self, line):
    # log.msg("[DEBUG] lineReceived(): %s" % line)
    try:
      (metric, value, timestamp) = line.split()
      datapoint = (float(timestamp), float(value))
      assert datapoint[1] == datapoint[1]  # filter out NaNs
      client_manager.sendDatapoint(metric, datapoint)
    except ValueError:
      log.err(None, 'Dropping invalid line: %s' % line)
開發者ID:graphite-project,項目名稱:carbon,代碼行數:33,代碼來源:carbon-client.py


注:本文中的carbon.client.CarbonClientManager.startClient方法示例由純淨天空整理自Github/MSDocs等開源代碼及文檔管理平台,相關代碼片段篩選自各路編程大神貢獻的開源項目,源碼版權歸原作者所有,傳播和使用請參考對應項目的License;未經允許,請勿轉載。