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


Python JournalLogger.begin_context方法代碼示例

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


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

示例1: verify_quota

# 需要導入模塊: from citest.base import JournalLogger [as 別名]
# 或者: from citest.base.JournalLogger import begin_context [as 別名]
def verify_quota(title, gcp_agent, project_quota, regions):
  """Verify that the observed GCP project has sufficient quota.

  Args:
    title: [string] What the quota is for, for logging purposes only.
    gcp_agent: [GcpAgent] Observation agent on the desired project.
    project_quota: [dict] Minimum desired values keyed by quota metric for
       the observed project.
    regions: [array of (name, dict) tuple]: A list of regions and their
       individual quotas to check.

  Returns:
    json_contract.ContractVerifyResult against the quota check.
  """
  execution_context = ExecutionContext()
  contract = make_quota_contract(gcp_agent, project_quota, regions)
  verify_results = None
  context_relation = 'ERROR'

  try:
    JournalLogger.begin_context(title)
    verify_results = contract.verify(execution_context)
    context_relation = 'VALID' if verify_results else 'INVALID'
  finally:
    if verify_results is not None:
      journal = get_global_journal()
      if journal is not None:
        journal.store(verify_results)
    JournalLogger.end_context(relation=context_relation)

  return verify_results
開發者ID:duftler,項目名稱:citest,代碼行數:33,代碼來源:quota_predicate.py

示例2: verify

# 需要導入模塊: from citest.base import JournalLogger [as 別名]
# 或者: from citest.base.JournalLogger import begin_context [as 別名]
  def verify(self, context):
    """Attempt to make an observation and verify it.

    This call will repeatedly attempt to observe new data and verify it
    until either the verification passes, or it times out base on
    the retryable_for_secs specified in the constructor.

    Args:
      context: Runtime citest execution context may contain operation status
         and other testing parameters used by downstream verifiers.

    Returns:
      ContractClauseVerifyResult with details.
    """
    JournalLogger.begin_context(
        'Verifying ContractClause: {0}'.format(self.__title))

    context_relation = 'ERROR'
    try:
      JournalLogger.delegate("store", self, _title='Clause Specification')

      result = self.__do_verify(context)
      context_relation = 'VALID' if result else 'INVALID'
    finally:
      JournalLogger.end_context(relation=context_relation)
    return result
開發者ID:duftler,項目名稱:citest,代碼行數:28,代碼來源:contract.py

示例3: wait

# 需要導入模塊: from citest.base import JournalLogger [as 別名]
# 或者: from citest.base.JournalLogger import begin_context [as 別名]
  def wait(self, poll_every_secs=None, max_secs=None):
    """Wait until the status reaches a final state.

    Args:
      poll_every_secs: [float] Interval to refresh() from the proxy.
         This could also be a function taking an attempt number and
         returning number of seconds for that attempt.
         The default is default_wait_time_func.

      max_secs: [float] Most seconds to wait before giving up.
          0 is a poll, None is unbounded. Otherwise, number of seconds.
    """
    if self.finished:
      return

    if max_secs is None:
      max_secs = self.operation.max_wait_secs
    if max_secs is not None and max_secs < 0:
      raise ValueError()

    message = 'Wait on id={0}, max_secs={1}'.format(self.id, max_secs)
    JournalLogger.begin_context(message)
    context_relation = 'ERROR'
    try:
      self.refresh()
      self.__wait_helper(poll_every_secs, max_secs)
      context_relation = 'VALID' if self.finished_ok else 'INVALID'
    finally:
      JournalLogger.end_context(relation=context_relation)
開發者ID:ewiseblatt,項目名稱:citest,代碼行數:31,代碼來源:base_agent.py

示例4: new_gce_instance_from_bindings

# 需要導入模塊: from citest.base import JournalLogger [as 別名]
# 或者: from citest.base.JournalLogger import begin_context [as 別名]
  def new_gce_instance_from_bindings(
      cls, name, status_factory, bindings, port):
    """Create a new Spinnaker HttpAgent talking to the specified server port.

    Args:
      name: [string] The name of agent we are creating for reporting only.
      status_factory: [SpinnakerStatus (SpinnakerAgent, HttpResponseType)]
         Factory method for creating specialized SpinnakerStatus instances.
      bindings: [dict] List of bindings to configure the endpoint
          GCE_PROJECT: The GCE project ID that the endpoint is in.
          GCE_ZONE: The GCE zone that the endpoint is in.
          GCE_INSTANCE: The GCE instance that the endpoint is in.
          GCE_SSH_PASSPHRASE_FILE: If not empty, the SSH passphrase key
              for tunneling if needed to connect through a GCE firewall.
          GCE_SERVICE_ACCOUNT: If not empty, the GCE service account to use
              when interacting with the GCE instance.
      port: [int] The port of the endpoint we want to connect to.
    Returns:
      A SpinnakerAgent connected to the specified instance port.
    """
    project = bindings['GCE_PROJECT']
    zone = bindings['GCE_ZONE']
    instance = bindings['GCE_INSTANCE']
    ssh_passphrase_file = bindings.get('GCE_SSH_PASSPHRASE_FILE', None)
    service_account = bindings.get('GCE_SERVICE_ACCOUNT', None)

    logger = logging.getLogger(__name__)
    JournalLogger.begin_context('Locating {0}...'.format(name))
    context_relation = 'ERROR'
    try:
      gcloud = gcp.GCloudAgent(
          project=project, zone=zone, service_account=service_account,
          ssh_passphrase_file=ssh_passphrase_file)
      netloc = gce_util.establish_network_connectivity(
          gcloud=gcloud, instance=instance, target_port=port)
      if not netloc:
        error = 'Could not locate {0}.'.format(name)
        logger.error(error)
        context_relation = 'INVALID'
        raise RuntimeError(error)

      protocol = bindings['NETWORK_PROTOCOL']
      base_url = '{protocol}://{netloc}'.format(protocol=protocol,
                                                netloc=netloc)
      logger.info('%s is available at %s. Using %s', name, netloc, base_url)
      deployed_config = scrape_spring_config(
          os.path.join(base_url, 'resolvedEnv'))
      JournalLogger.journal_or_log_detail(
          '{0} configuration'.format(name), deployed_config)
      spinnaker_agent = cls(base_url, status_factory)
      spinnaker_agent.__deployed_config = deployed_config
      context_relation = 'VALID'
    except:
      logger.exception('Failed to create spinnaker agent.')
      raise
    finally:
      JournalLogger.end_context(relation=context_relation)

    return spinnaker_agent
開發者ID:PioTi,項目名稱:spinnaker,代碼行數:61,代碼來源:spinnaker.py

示例5: run_test_case

# 需要導入模塊: from citest.base import JournalLogger [as 別名]
# 或者: from citest.base.JournalLogger import begin_context [as 別名]
  def run_test_case(self, test_case, context=None, **kwargs):
    """Run the specified test operation from start to finish.

    Args:
      test_case: [OperationContract] To test.
      context: [ExecutionContext] The citest execution context to run in.
      timeout_ok: [bool] Whether an AgentOperationStatus timeout implies
          a test failure. If it is ok to timeout, then we'll still verify the
          contracts, but skip the final status check if there is no final
          status yet.
      max_retries: [int] Number of independent retries permitted on
          individual operations if the operation status fails. A value of 0
          indicates that a test should only be given a single attempt.
      retry_interval_secs: [int] The number of seconds to wait between retries.
      max_wait_secs: [int] How long to wait for status completion.
          Default=Determined by operation in the test case.
    """
    if context is None:
      context = ExecutionContext()

    # This is complicated because of all the individual parts
    # that we want to ensure excute, so we'll break it up into
    # helper functions based on scope and use the context to
    # pass back some shared state variables since they make sense
    # to communicate in the context anyway.
    #
    # This particular method is responsible for the logging context
    # and the post-execution cleanup, if any.
    #
    # It will delegate to a helper function for the execution and
    # pre/post hooks
    #
    # To get the context relation, we'll peek inside the execution
    # context to see how the status and validation turned out.
    JournalLogger.begin_context('Test "{0}"'.format(test_case.title))
    try:
      self._do_run_test_case_with_hooks(test_case, context, **kwargs)
    finally:
      try:
        if test_case.cleanup:
          attempt_info = context.get(self.CONTEXT_KEY_ATTEMPT_INFO, None)
          if attempt_info is None or attempt_info.status is None:
            self.logger.info('Skipping operation cleanup because'
                             ' operation could not be performed at all.')
          else:
            self.logger.info('Invoking injected operation cleanup.')
            test_case.cleanup(context)
      finally:
        verify_results = context.get(
            self.CONTEXT_KEY_CONTRACT_VERIFY_RESULTS, None)
        if verify_results is None:
          context_relation = 'ERROR'
        else:
          final_status_ok = context.get(self.CONTEXT_KEY_FINAL_STATUS_OK, False)
          context_relation = ('VALID' if (final_status_ok and verify_results)
                              else 'INVALID')
        JournalLogger.end_context(relation=context_relation)
開發者ID:ewiseblatt,項目名稱:citest,代碼行數:59,代碼來源:agent_test_case.py

示例6: new_gce_instance_from_bindings

# 需要導入模塊: from citest.base import JournalLogger [as 別名]
# 或者: from citest.base.JournalLogger import begin_context [as 別名]
    def new_gce_instance_from_bindings(cls, name, status_factory, bindings, port):
        """Create a new Spinnaker HttpAgent talking to the specified server port.

    Args:
      name: [string] The name of agent we are creating for reporting only.
      status_factory: [SpinnakerStatus (SpinnakerAgent, HttpResponseType)]
         Factory method for creating specialized SpinnakerStatus instances.
      bindings: [dict] List of bindings to configure the endpoint
          GCE_PROJECT: The GCE project ID that the endpoint is in.
          GCE_ZONE: The GCE zone that the endpoint is in.
          GCE_INSTANCE: The GCE instance that the endpoint is in.
          GCE_SSH_PASSPHRASE_FILE: If not empty, the SSH passphrase key
              for tunneling if needed to connect through a GCE firewall.
          GCE_SERVICE_ACCOUNT: If not empty, the GCE service account to use
              when interacting with the GCE instance.
      port: [int] The port of the endpoint we want to connect to.
    Returns:
      A SpinnakerAgent connected to the specified instance port.
    """
        project = bindings["GCE_PROJECT"]
        zone = bindings["GCE_ZONE"]
        instance = bindings["GCE_INSTANCE"]
        ssh_passphrase_file = bindings.get("GCE_SSH_PASSPHRASE_FILE", None)
        service_account = bindings.get("GCE_SERVICE_ACCOUNT", None)

        logger = logging.getLogger(__name__)
        JournalLogger.begin_context("Locating {0}...".format(name))
        context_relation = "ERROR"
        try:
            gcloud = gcp.GCloudAgent(
                project=project, zone=zone, service_account=service_account, ssh_passphrase_file=ssh_passphrase_file
            )
            netloc = gce_util.establish_network_connectivity(gcloud=gcloud, instance=instance, target_port=port)
            if not netloc:
                error = "Could not locate {0}.".format(name)
                logger.error(error)
                context_relation = "INVALID"
                raise RuntimeError(error)

            approx_config = cls.__get_deployed_local_yaml_bindings(gcloud, instance)
            protocol = approx_config.get("services.default.protocol", "http")
            base_url = "{protocol}://{netloc}".format(protocol=protocol, netloc=netloc)
            logger.info("%s is available at %s", name, base_url)
            deployed_config = scrape_spring_config(os.path.join(base_url, "env"))
            spinnaker_agent = cls(base_url, status_factory)
            spinnaker_agent.__deployed_config = deployed_config
            context_relation = "VALID"
        except:
            logger.exception("Failed to create spinnaker agent.")
            raise
        finally:
            JournalLogger.end_context(relation=context_relation)

        return spinnaker_agent
開發者ID:stitchfix,項目名稱:spinnaker,代碼行數:56,代碼來源:spinnaker.py

示例7: post_run_hook

# 需要導入模塊: from citest.base import JournalLogger [as 別名]
# 或者: from citest.base.JournalLogger import begin_context [as 別名]
  def post_run_hook(self, info, test_case, context):
    if not info:
      return

    scanner, before_usage = info
    analyzer = self.__google_resource_analyzer
    JournalLogger.begin_context('Capturing final quota usage')
    try:
      after_usage = analyzer.collect_resource_usage(self.gcp_observer, scanner)
    finally:
      JournalLogger.end_context()
    analyzer.log_delta_resource_usage(
        test_case, scanner, before_usage, after_usage)
開發者ID:spinnaker,項目名稱:spinnaker,代碼行數:15,代碼來源:spinnaker_test_scenario.py

示例8: list_available_images

# 需要導入模塊: from citest.base import JournalLogger [as 別名]
# 或者: from citest.base.JournalLogger import begin_context [as 別名]
  def list_available_images(self):
    """Creates a test that confirms expected available images.

    Returns:
      st.OperationContract
    """
    logger = logging.getLogger(__name__)

    # Get the list of images available (to the service account we are using).
    context = citest.base.ExecutionContext()
    gcp_agent = self.gcp_observer
    JournalLogger.begin_context('Collecting expected available images')
    relation_context = 'ERROR'
    try:
      logger.debug('Looking up available images.')

      json_doc = gcp_agent.list_resource(context, 'images')
      for project in GCP_STANDARD_IMAGES.keys():
        logger.info('Looking for images from project=%s', project)
        found = gcp_agent.list_resource(context, 'images', project=project)
        for image in found:
          if not image.get('deprecated', None):
            json_doc.append(image)

      # Produce the list of images that we expect to receive from spinnaker
      # (visible to the primary service account).
      spinnaker_account = self.bindings['SPINNAKER_GOOGLE_ACCOUNT']

      logger.debug('Configured with Spinnaker account "%s"', spinnaker_account)
      expect_images = [{'account': spinnaker_account, 'imageName': image['name']}
                       for image in json_doc]
      expect_images = sorted(expect_images, key=lambda k: k['imageName'])
      relation_context = 'VALID'
    finally:
      JournalLogger.end_context(relation=relation_context)

    # pylint: disable=bad-continuation
    builder = HttpContractBuilder(self.agent)
    (builder.new_clause_builder('Has Expected Images')
       .get_url_path('/gce/images/find')
       .EXPECT(
           ov_factory.value_list_matches(
               [jp.DICT_SUBSET(image_entry) for image_entry in expect_images],
               strict=True,
               unique=True)))

    return st.OperationContract(
        NoOpOperation('List Available Images'),
        contract=builder.build())
開發者ID:PioTi,項目名稱:spinnaker,代碼行數:51,代碼來源:google_kato_test.py

示例9: list_available_images

# 需要導入模塊: from citest.base import JournalLogger [as 別名]
# 或者: from citest.base.JournalLogger import begin_context [as 別名]
  def list_available_images(self):
    """Creates a test that confirms expected available images.

    Returns:
      st.OperationContract
    """
    logger = logging.getLogger(__name__)

    # Get the list of images available (to the service account we are using).
    context = citest.base.ExecutionContext()
    gcp_agent = self.gcp_observer
    JournalLogger.begin_context('Collecting expected available images')
    relation_context = 'ERROR'
    try:
      logger.debug('Looking up available images.')

      json_doc = gcp_agent.list_resource(context, 'images')
      for project in GCP_STANDARD_IMAGES.keys():
        logger.info('Looking for images from project=%s', project)
        found = gcp_agent.list_resource(context, 'images', project=project)
        for image in found:
          if not image.get('deprecated', None):
            json_doc.append(image)

      # Produce the list of images that we expect to receive from spinnaker
      # (visible to the primary service account).
      spinnaker_account = self.agent.deployed_config.get(
          'providers.google.primaryCredentials.name')

      logger.debug('Configured with Spinnaker account "%s"', spinnaker_account)
      expect_images = [{'account': spinnaker_account, 'imageName': image['name']}
                       for image in json_doc]
      expect_images = sorted(expect_images, key=lambda k: k['imageName'])
      relation_context = 'VALID'
    finally:
      JournalLogger.end_context(relation=relation_context)

    # pylint: disable=bad-continuation
    builder = HttpContractBuilder(self.agent)
    (builder.new_clause_builder('Has Expected Images')
       .get_url_path('/gce/images/find')
       .add_constraint(jp.PathPredicate(jp.DONT_ENUMERATE_TERMINAL,
                                        jp.EQUIVALENT(expect_images))))

    return st.OperationContract(
        NoOpOperation('List Available Images'),
        contract=builder.build())
開發者ID:gkuchta,項目名稱:spinnaker,代碼行數:49,代碼來源:google_kato_test.py

示例10: __init__

# 需要導入模塊: from citest.base import JournalLogger [as 別名]
# 或者: from citest.base.JournalLogger import begin_context [as 別名]
  def __init__(self, bindings, agent=None):
    """Constructor

    Args:
      bindings: [dict] The parameter bindings for overriding the test
         scenario configuration.
      agent: [SpinnakerAgent] The Spinnaker agent to bind to the scenario.
    """
    super(SpinnakerTestScenario, self).__init__(bindings, agent)
    agent = self.agent
    self.__update_bindings_with_subsystem_configuration(agent)
    JournalLogger.begin_context('Configure Cloud Bindings')
    try:
      self.__init_google_bindings()
      self.__init_aws_bindings()
      self.__init_kubernetes_bindings()
    finally:
      JournalLogger.end_context()
開發者ID:jtk54,項目名稱:citest,代碼行數:20,代碼來源:spinnaker_test_scenario.py

示例11: __init__

# 需要導入模塊: from citest.base import JournalLogger [as 別名]
# 或者: from citest.base.JournalLogger import begin_context [as 別名]
  def __init__(self, bindings, agent=None):
    """Constructor

    Args:
      bindings: [dict] The parameter bindings for overriding the test
         scenario configuration.
      agent: [SpinnakerAgent] The Spinnaker agent to bind to the scenario.
    """
    super(SpinnakerTestScenario, self).__init__(bindings, agent)
    self.__google_resource_analyzer = None
    agent = self.agent
    bindings = self.bindings

    # For read-only tests that don't make mutating calls to Spinnaker,
    # there is nothing to update in the bindings, e.g. GCP quota test.
    if agent is not None:
      for key, value in agent.runtime_config.items():
        try:
          if bindings[key]:
            continue  # keep existing value already set within citest
        except KeyError:
          pass
        bindings[key] = value  # use value from agent's configuration

    JournalLogger.begin_context('Configure Scenario Bindings')
    self.__platform_support = {}
    for klas in PLATFORM_SUPPORT_CLASSES:
      try:
        support = klas(self)
        self.__platform_support[support.platform_name] = support
      except:
        logger = logging.getLogger(__name__)

        logger.exception('Failed to initialize support class %s:\n%s',
                         str(klas), traceback.format_exc())

    try:
      self._do_init_bindings()
    except:
      logger = logging.getLogger(__name__)
      logger.exception('Failed to initialize spinnaker agent.')
      raise
    finally:
      JournalLogger.end_context()
開發者ID:spinnaker,項目名稱:spinnaker,代碼行數:46,代碼來源:spinnaker_test_scenario.py

示例12: pre_run_hook

# 需要導入模塊: from citest.base import JournalLogger [as 別名]
# 或者: from citest.base.JournalLogger import begin_context [as 別名]
  def pre_run_hook(self, test_case, context):
    if not self.bindings.get('RECORD_GCP_RESOURCE_USAGE'):
      return None

    if self.__google_resource_analyzer is None:
      from google_scenario_support import GcpResourceUsageAnalyzer
      self.__google_resource_analyzer = GcpResourceUsageAnalyzer(self)
    analyzer = self.__google_resource_analyzer

    scanner = analyzer.make_gcp_api_scanner(
        self.bindings.get('GOOGLE_ACCOUNT_PROJECT'),
        self.bindings.get('GOOGLE_CREDENTIALS_PATH'),
        include_apis=['compute'],
        exclude_apis=['compute.*Operations'])
    JournalLogger.begin_context('Capturing initial quota usage')
    try:
      usage = analyzer.collect_resource_usage(self.gcp_observer, scanner)
    finally:
      JournalLogger.end_context()
    return (scanner, usage)
開發者ID:spinnaker,項目名稱:spinnaker,代碼行數:22,代碼來源:spinnaker_test_scenario.py

示例13: run_test_case

# 需要導入模塊: from citest.base import JournalLogger [as 別名]
# 或者: from citest.base.JournalLogger import begin_context [as 別名]
  def run_test_case(self, test_case, context=None, **kwargs):
    """Run the specified test operation from start to finish.

    Args:
      test_case: [OperationContract] To test.
      context: [ExecutionContext] The citest execution context to run in.
      timeout_ok: [bool] Whether an AgentOperationStatus timeout implies
          a test failure. If it is ok to timeout, then we'll still verify the
          contracts, but skip the final status check if there is no final
          status yet.
      max_retries: [int] Number of independent retries permitted on
          individual operations if the operation status fails. A value of 0
          indicates that a test should only be given a single attempt.
      retry_interval_secs: [int] The number of seconds to wait between retries.
      poll_every_secs: [int] Number of seconds between wait polls. Default=1.
    """
    if context is None:
      context = ExecutionContext()
    timeout_ok = kwargs.pop('timeout_ok', False)
    max_retries = kwargs.pop('max_retries', 0)
    retry_interval_secs = kwargs.pop('retry_interval_secs', 5)
    poll_every_secs = kwargs.pop('poll_every_secs', 1)
    full_trace = kwargs.pop('full_trace', False)  # Deprecated
    if kwargs:
      raise TypeError('Unrecognized arguments {0}'.format(kwargs.keys()))

    self.log_start_test(test_case.title)
    if max_retries < 0:
      raise ValueError(
          'max_retries={max} cannot be negative'.format(max=max_retries))
    if retry_interval_secs < 0:
      raise ValueError(
          'retry_interval_secs={secs} cannot be negative'.format(
              secs=retry_interval_secs))

    execution_trace = OperationContractExecutionTrace(test_case)
    verify_results = None
    final_status_ok = None
    context_relation = None
    attempt_info = None
    status = None
    try:
      JournalLogger.begin_context('Test "{0}"'.format(test_case.title))
      JournalLogger.delegate(
          "store", test_case.operation,
          _title='Operation "{0}" Specification'.format(
              test_case.operation.title))
      max_tries = 1 + max_retries

      # We attempt the operation on the agent multiple times until the agent
      # thinks that it succeeded. But we will only verify once the agent thinks
      # it succeeded. We do not give multiple chances to satisfy the
      # verification.
      for i in range(max_tries):
        context.clear_key('OperationStatus')
        context.clear_key('AttemptInfo')
        attempt_info = execution_trace.new_attempt()
        status = None
        status = test_case.operation.execute(agent=self.testing_agent)
        status.wait(poll_every_secs=poll_every_secs)

        summary = status.error or ('Operation status OK' if status.finished_ok
                                   else 'Operation status Unknown')
        # Write the status (and attempt_info) into the execution_context
        # to make it available to contract verifiers. For example, to
        # make specific details in the status (e.g. new resource names)
        # available to downstream validators for their consideration.
        context.set_internal('AttemptInfo', attempt_info)
        context.set_internal('OperationStatus', status)

        attempt_info.set_status(status, summary)
        if test_case.status_extractor:
          test_case.status_extractor(status, context)

        if not status.exception_details:
          execution_trace.set_operation_summary('Completed test.')
          break
        if max_tries - i > 1:
          self.logger.warning(
              'Got an exception: %s.\nTrying again in %r secs...',
              status.exception_details, retry_interval_secs)
          time.sleep(retry_interval_secs)
        elif max_tries > 1:
          execution_trace.set_operation_summary('Gave up retrying operation.')
          self.logger.error('Giving up retrying test.')

      # We're always going to verify the contract, even if the request itself
      # failed. We set the verification on the attempt here, but do not assert
      # anything. We'll assert below outside this try/catch handler.
      verify_results = test_case.contract.verify(context)
      execution_trace.set_verify_results(verify_results)
      final_status_ok = self.verify_final_status_ok(
          status, timeout_ok=timeout_ok,
          final_attempt=attempt_info,
          execution_trace=execution_trace)
      context_relation = ('VALID' if (final_status_ok and verify_results)
                          else 'INVALID')
    except BaseException as ex:
      context_relation = 'ERROR'
      execution_trace.set_exception(ex)
#.........這裏部分代碼省略.........
開發者ID:duftler,項目名稱:citest,代碼行數:103,代碼來源:agent_test_case.py


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