diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/_schema/component.py b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/_schema/component.py index 175f18919a44..eb278301f99e 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/_schema/component.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/_schema/component.py @@ -2,7 +2,7 @@ # Copyright (c) Microsoft Corporation. All rights reserved. # --------------------------------------------------------- -from marshmallow import fields, post_dump +from marshmallow import fields, post_dump, INCLUDE, EXCLUDE from azure.ai.ml._schema import NestedField, StringTransformedEnum, UnionField from azure.ai.ml._schema.component.component import ComponentSchema @@ -15,6 +15,7 @@ InternalInputPortSchema, InternalOutputPortSchema, InternalParameterSchema, + InternalPrimitiveOutputSchema, ) @@ -42,6 +43,8 @@ def all_values(cls): class InternalBaseComponentSchema(ComponentSchema): + class Meta: + unknown = INCLUDE # override name as 1p components allow . in name, which is not allowed in v2 components name = fields.Str() @@ -60,7 +63,16 @@ class InternalBaseComponentSchema(ComponentSchema): ] ), ) - outputs = fields.Dict(keys=fields.Str(), values=NestedField(InternalOutputPortSchema)) + # support primitive output for all internal components for now + outputs = fields.Dict( + keys=fields.Str(), + values=UnionField( + [ + NestedField(InternalPrimitiveOutputSchema, unknown=EXCLUDE), + NestedField(InternalOutputPortSchema, unknown=EXCLUDE), + ] + ), + ) # type field is required for registration type = StringTransformedEnum( diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/_schema/input_output.py b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/_schema/input_output.py index b2c54ab0c836..a71e354e8e27 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/_schema/input_output.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/_schema/input_output.py @@ -4,11 +4,22 @@ from marshmallow import fields, post_dump, post_load -from azure.ai.ml._schema import StringTransformedEnum, UnionField -from azure.ai.ml._schema.component.input_output import InputPortSchema, OutputPortSchema, ParameterSchema -from azure.ai.ml._schema.core.fields import DumpableFloatField, DumpableIntegerField +from azure.ai.ml._schema import StringTransformedEnum, UnionField, PatchedSchemaMeta +from azure.ai.ml._schema.component.input_output import InputPortSchema, ParameterSchema +from azure.ai.ml._schema.core.fields import DumpableFloatField, DumpableIntegerField, DumpableEnumField +SUPPORTED_INTERNAL_PARAM_TYPES = [ + "integer", + "Integer", + "boolean", + "Boolean", + "string", + "String", + "float", + "Float", +] + class InternalInputPortSchema(InputPortSchema): # skip client-side validate for type enum & support list type = UnionField( @@ -29,29 +40,29 @@ def resolve_list_type(self, data, original_data, **kwargs): # pylint: disable=u return data -class InternalOutputPortSchema(OutputPortSchema): +class InternalOutputPortSchema(metaclass=PatchedSchemaMeta): # skip client-side validate for type enum type = fields.Str( required=True, data_key="type", ) + description = fields.Str() is_link_mode = fields.Bool() datastore_mode = fields.Str() +class InternalPrimitiveOutputSchema(metaclass=PatchedSchemaMeta): + type = DumpableEnumField( + allowed_values=SUPPORTED_INTERNAL_PARAM_TYPES, + required=True, + ) + description = fields.Str() + is_control = fields.Bool() + + class InternalParameterSchema(ParameterSchema): - type = StringTransformedEnum( - allowed_values=[ - "integer", - "Integer", - "boolean", - "Boolean", - "string", - "String", - "float", - "Float", - ], - casing_transform=lambda x: x, + type = DumpableEnumField( + allowed_values=SUPPORTED_INTERNAL_PARAM_TYPES, required=True, data_key="type", ) diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/_schema/node.py b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/_schema/node.py index ee39e2ba7ddf..7cba9af5c709 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/_schema/node.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/_schema/node.py @@ -12,6 +12,8 @@ class InternalBaseNodeSchema(BaseNodeSchema): + class Meta: + unknown = INCLUDE component = UnionField( [ # for registry type assets @@ -56,6 +58,7 @@ class ScopeSchema(InternalBaseNodeSchema): class HDInsightSchema(InternalBaseNodeSchema): type = StringTransformedEnum(allowed_values=[NodeType.HDI], casing_transform=lambda x: x) + compute_name = fields.Str() queue = fields.Str() driver_memory = fields.Str() driver_cores = fields.Int() diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/_util.py b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/_util.py index 076e4af36d7a..214ca2d8e2f9 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/_util.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/_util.py @@ -17,6 +17,9 @@ InternalComponent, Parallel, Scope, + DataTransfer, + Hemera, + Starlite, ) from azure.ai.ml._schema import NestedField from azure.ai.ml.entities._component.component_factory import component_factory @@ -57,6 +60,9 @@ def enable_internal_components_in_pipeline(): _register_node(_type, InternalBaseNode, InternalBaseNodeSchema) # redo the registration for those with specific runsettings + _register_node(NodeType.DATA_TRANSFER, DataTransfer, InternalBaseNodeSchema) + _register_node(NodeType.HEMERA, Hemera, InternalBaseNodeSchema) + _register_node(NodeType.STARLITE, Starlite, InternalBaseNodeSchema) _register_node(NodeType.COMMAND, Command, CommandSchema) _register_node(NodeType.DISTRIBUTED, Distributed, DistributedSchema) _register_node(NodeType.SCOPE, Scope, ScopeSchema) diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/_additional_includes.py b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/_additional_includes.py index dcbd8ffeec36..0d2e180b738d 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/_additional_includes.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/_additional_includes.py @@ -16,19 +16,34 @@ class _AdditionalIncludes: def __init__(self, code_path: Union[None, str], yaml_path: str): - self._yaml_path = Path(yaml_path) - self._yaml_name = self._yaml_path.name - self._code_path = self._yaml_path.parent - if code_path is not None: - self._code_path = (self._code_path / code_path).resolve() + self.__yaml_path = Path(yaml_path) + self.__code_path = code_path + self._tmp_code_path = None - self._additional_includes_file_path = self._yaml_path.with_suffix(f".{ADDITIONAL_INCLUDES_SUFFIX}") self._includes = None if self._additional_includes_file_path.is_file(): with open(self._additional_includes_file_path, "r") as f: lines = f.readlines() self._includes = [line.strip() for line in lines if len(line.strip()) > 0] + @property + def _yaml_path(self) -> Path: + return self.__yaml_path + + @property + def _code_path(self) -> Path: + if self.__code_path is not None: + return (self._yaml_path.parent / self.__code_path).resolve() + return self._yaml_path.parent + + @property + def _yaml_name(self) -> str: + return self._yaml_path.name + + @property + def _additional_includes_file_path(self) -> Path: + return self._yaml_path.with_suffix(f".{ADDITIONAL_INCLUDES_SUFFIX}") + @property def code(self) -> Path: return self._tmp_code_path if self._tmp_code_path else self._code_path diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/command.py b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/command.py index 7deed4feae4f..23d0302ff27d 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/command.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/command.py @@ -42,8 +42,6 @@ def compute(self) -> str: @compute.setter def compute(self, value: str): """Set the compute definition for the command.""" - if value is not None and not isinstance(value, str): - raise ValueError(f"Failed in setting compute: only string is supported in DPv2 but got {type(value)}") self._compute = value @property @@ -54,8 +52,6 @@ def environment(self) -> str: @environment.setter def environment(self, value: str): """Set the environment definition for the command.""" - if value is not None and not isinstance(value, str): - raise ValueError(f"Failed in setting environment: only string is supported in DPv2 but got {type(value)}") self._environment = value @property diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/component.py b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/component.py index 12b7f66fe1af..599f5a84db35 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/component.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/component.py @@ -5,6 +5,7 @@ # disable redefined-builtin to use id/type as argument name from contextlib import contextmanager from typing import Dict, Union +import os from marshmallow import INCLUDE, Schema @@ -176,6 +177,21 @@ def _additional_includes(self): def _create_schema_for_validation(cls, context) -> Union[PathAwareSchema, Schema]: return InternalBaseComponentSchema(context=context) + def _validate(self, raise_error=False) -> MutableValidationResult: + if self._additional_includes is not None and self._additional_includes._validate().passed: + # update source path in case dependency file is in additional_includes + with self._resolve_local_code() as tmp_base_path: + origin_base_path, origin_source_path = self._base_path, self._source_path + + try: + self._base_path, self._source_path = \ + tmp_base_path, tmp_base_path / os.path.basename(self._source_path) + return super()._validate(raise_error=raise_error) + finally: + self._base_path, self._source_path = origin_base_path, origin_source_path + + return super()._validate(raise_error=raise_error) + def _customized_validate(self) -> MutableValidationResult: validation_result = super(InternalComponent, self)._customized_validate() if isinstance(self.environment, InternalEnvironment): @@ -228,14 +244,3 @@ def _resolve_local_code(self): def __call__(self, *args, **kwargs) -> InternalBaseNode: # pylint: disable=useless-super-delegation return super(InternalComponent, self).__call__(*args, **kwargs) - - def _schema_validate(self) -> MutableValidationResult: - """Validate the resource with the schema. - - return type: ValidationResult - """ - result = super(InternalComponent, self)._schema_validate() - # skip unknown field warnings for internal components - # TODO: move this logic into base class - result._warnings = list(filter(lambda x: x.message != "Unknown field.", result._warnings)) - return result diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/node.py b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/node.py index 15a6ab580288..33c0e0ccf766 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/node.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/node.py @@ -16,7 +16,6 @@ from azure.ai.ml.entities._job.pipeline._io import NodeInput, NodeOutput, PipelineInput from azure.ai.ml.entities._util import convert_ordered_dict_to_dict -from ...entities._validation import MutableValidationResult from .._schema.component import NodeType from ._input_outputs import InternalInput @@ -95,17 +94,6 @@ def _to_job(self) -> Job: def _load_from_dict(cls, data: Dict, context: Dict, additional_message: str, **kwargs) -> "Job": raise RuntimeError("Internal components doesn't support load from dict") - def _schema_validate(self) -> MutableValidationResult: - """Validate the resource with the schema. - - return type: ValidationResult - """ - result = super(InternalBaseNode, self)._schema_validate() - # skip unknown field warnings for internal components - # TODO: move this logic into base class? - result._warnings = list(filter(lambda x: x.message != "Unknown field.", result._warnings)) - return result - @classmethod def _create_schema_for_validation(cls, context) -> Union[PathAwareSchema, Schema]: from .._schema.node import InternalBaseNodeSchema @@ -176,6 +164,7 @@ def __init__(self, **kwargs): kwargs.pop("type", None) super(HDInsight, self).__init__(type=NodeType.HDI, **kwargs) self._init = True + self._compute_name: str = kwargs.pop("compute_name", None) self._queue: str = kwargs.pop("queue", None) self._driver_memory: str = kwargs.pop("driver_memory", None) self._driver_cores: int = kwargs.pop("driver_cores", None) @@ -186,6 +175,15 @@ def __init__(self, **kwargs): self._hdinsight_spark_job_name: str = kwargs.pop("hdinsight_spark_job_name", None) self._init = False + @property + def compute_name(self) -> str: + """Name of the compute to be used.""" + return self._compute_name + + @compute_name.setter + def compute_name(self, value: str): + self._compute_name = value + @property def queue(self) -> str: """The name of the YARN queue to which submitted.""" @@ -267,6 +265,7 @@ def hdinsight_spark_job_name(self, value: str): @classmethod def _picked_fields_from_dict_to_rest_object(cls) -> List[str]: return [ + "compute_name", "queue", "driver_cores", "executor_memory", diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/component/command_component.py b/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/component/command_component.py index b529f69e52e6..b06451d98c7b 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/component/command_component.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/component/command_component.py @@ -38,7 +38,7 @@ class Meta: ], metadata={"description": "Provides the configuration for a distributed run."}, ) - # primitive output is only supported for command component + # primitive output is only supported for command component & pipeline component outputs = fields.Dict( keys=fields.Str(), values=UnionField( diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/component/input_output.py b/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/component/input_output.py index 227f9d94f50b..78c1c6095486 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/component/input_output.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/component/input_output.py @@ -51,16 +51,12 @@ class OutputPortSchema(metaclass=PatchedSchemaMeta): ) -class PrimitiveOutputSchema(metaclass=PatchedSchemaMeta): +class PrimitiveOutputSchema(OutputPortSchema): type = DumpableEnumField( allowed_values=SUPPORTED_PARAM_TYPES, required=True, ) - description = fields.Str() is_control = fields.Bool() - mode = DumpableEnumField( - allowed_values=SUPPORTED_INPUT_OUTPUT_MODES, - ) class ParameterSchema(metaclass=PatchedSchemaMeta): diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/core/schema_meta.py b/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/core/schema_meta.py index 816efd4752c3..b8e91f42ee72 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/core/schema_meta.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/core/schema_meta.py @@ -44,8 +44,10 @@ def __new__(cls, name, bases, dct): if meta is None: dct["Meta"] = PatchedMeta else: - dct["Meta"].unknown = RAISE - dct["Meta"].ordered = True + if not hasattr(meta, "unknown"): + dct["Meta"].unknown = RAISE + if not hasattr(meta, "ordered"): + dct["Meta"].ordered = True bases = bases + (PatchedBaseSchema,) klass = super().__new__(cls, name, bases, dct) diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/pipeline/pipeline_component.py b/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/pipeline/pipeline_component.py index 95597e10360d..240e477dc755 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/pipeline/pipeline_component.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/pipeline/pipeline_component.py @@ -136,7 +136,7 @@ class PipelineComponentSchema(ComponentSchema): type = StringTransformedEnum(allowed_values=[NodeType.PIPELINE]) jobs = PipelineJobsField() - # primitive output is only supported for command component + # primitive output is only supported for command component & pipeline component outputs = fields.Dict( keys=fields.Str(), values=UnionField( diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_load_functions.py b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_load_functions.py index 189145069c14..6e130326dac7 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_load_functions.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_load_functions.py @@ -89,7 +89,7 @@ def load_common( return _load_common_raising_marshmallow_error(cls, yaml_dict, relative_origin, params_override, **kwargs) except ValidationError as e: if issubclass(cls, SchemaValidatableMixin): - validation_result = _ValidationResultBuilder.from_validation_error(e, relative_origin) + validation_result = _ValidationResultBuilder.from_validation_error(e, source_path=relative_origin) validation_result.try_raise( # pylint: disable=protected-access error_target=cls._get_validation_error_target(), @@ -102,8 +102,7 @@ def load_common( f"of type {type_str}, please specify the correct " f"type in the 'type' property.", ) - else: - raise e + raise e def _try_load_yaml_dict(source: Union[str, PathLike, IO[AnyStr]]) -> dict: diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_validate_funcs.py b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_validate_funcs.py index 10c3db3f5cf5..ad4782dc0188 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_validate_funcs.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_validate_funcs.py @@ -30,7 +30,7 @@ def validate_common(cls, path, validate_func, params_override=None) -> Validatio except ValidationException as err: return _ValidationResultBuilder.from_single_message(err.message) except ValidationError as err: - return _ValidationResultBuilder.from_validation_error(err, path) + return _ValidationResultBuilder.from_validation_error(err, source_path=path) def validate_component(path, ml_client=None, params_override=None) -> ValidationResult: diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_validation.py b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_validation.py index 6d74ec4a16c7..c701ceb60f65 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_validation.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_validation.py @@ -420,7 +420,7 @@ def _validate(self, raise_error=False) -> MutableValidationResult: :type raise_error: bool return type: ValidationResult """ - result = self._schema_validate() + result = self.__schema_validate() result.merge_with(self._customized_validate()) return result.try_raise( raise_error=raise_error, error_target=self._get_validation_error_target() @@ -443,7 +443,7 @@ def _get_skip_fields_in_schema_validation( """ return [] - def _schema_validate(self) -> MutableValidationResult: + def __schema_validate(self) -> MutableValidationResult: """Validate the resource with the schema. return type: ValidationResult @@ -483,35 +483,65 @@ def from_single_message( return obj @classmethod - def from_validation_error(cls, error: ValidationError, source_path: str = None): + def from_validation_error( + cls, + error: ValidationError, + *, + source_path: str = None, + error_on_unknown_field=False + ): """Create a validation result from a ValidationError, which will be raised in marshmallow.Schema.load. Please use this function only for exception in loading file. param error: ValidationError raised by marshmallow.Schema.load. + type error: ValidationError + param error_on_unknown_field: whether to raise error if there + are unknown field diagnostics. + type error_on_unknown_field: bool """ - obj = cls.from_validation_messages(error.messages, data=error.data) + obj = cls.from_validation_messages( + error.messages, data=error.data, + error_on_unknown_field=error_on_unknown_field + ) if source_path: obj.resolve_location_for_diagnostics(source_path, resolve_value=True) return obj @classmethod - def from_validation_messages(cls, errors: typing.Dict, data: typing.Dict): + def from_validation_messages( + cls, + errors: typing.Dict, + data: typing.Dict, + *, + error_on_unknown_field: bool = False + ): """Create a validation result from error messages, which will be returned by marshmallow.Schema.validate. param errors: error message returned by - marshmallow.Schema.validate. param data: serialized data to - validate + marshmallow.Schema.validate. + type errors: dict + param data: serialized data to validate + type data: dict + param error_on_unknown_field: whether to raise error if there + are unknown field diagnostics. + type error_on_unknown_field: bool """ instance = MutableValidationResult(target_obj=data) errors = copy.deepcopy(errors) - cls._from_validation_messages_recursively(errors, [], instance) + cls._from_validation_messages_recursively( + errors, [], instance, error_on_unknown_field=error_on_unknown_field + ) return instance @classmethod def _from_validation_messages_recursively( - cls, errors, path_stack, instance: MutableValidationResult + cls, + errors: typing.Union[typing.Dict, typing.List, str], + path_stack: typing.List[str], + instance: MutableValidationResult, + error_on_unknown_field: bool, ): cur_path = ".".join(path_stack) if path_stack else "*" # single error message @@ -526,17 +556,17 @@ def _from_validation_messages_recursively( # fields.Dict if field in ["key", "value"]: cls._from_validation_messages_recursively( - msgs, path_stack, instance + msgs, path_stack, instance, error_on_unknown_field ) else: path_stack.append(field) cls._from_validation_messages_recursively( - msgs, path_stack, instance + msgs, path_stack, instance, error_on_unknown_field ) path_stack.pop() # detailed error message elif isinstance(errors, list) and all(isinstance(msg, str) for msg in errors): - if cls.UNKNOWN_MESSAGE in errors: + if cls.UNKNOWN_MESSAGE in errors and not error_on_unknown_field: # Unknown field is not a real error, so we should remove it and append a warning. errors.remove(cls.UNKNOWN_MESSAGE) instance.append_warning(message=cls.UNKNOWN_MESSAGE, yaml_path=cur_path) diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/operations/_component_operations.py b/sdk/ml/azure-ai-ml/azure/ai/ml/operations/_component_operations.py index ad2534749a49..059dd87731c2 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/operations/_component_operations.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/operations/_component_operations.py @@ -42,6 +42,7 @@ from ._code_operations import CodeOperations from ._environment_operations import EnvironmentOperations from ._operation_orchestrator import OperationOrchestrator +from ..entities._job.pipeline._attr_dict import has_attr_safe ops_logger = OpsLogger(__name__) module_logger = ops_logger.module_logger @@ -488,14 +489,14 @@ def _resolve_arm_id_for_pipeline_component_jobs(self, jobs, resolver: Callable): def preprocess_job(node): """Resolve all PipelineInput(binding from sdk) on supported fields to string.""" # compute binding to pipeline input is supported on node. - supported_fields = ["compute"] + supported_fields = ["compute", "compute_name"] for field_name in supported_fields: val = try_get_non_arbitrary_attr_for_potential_attr_dict(node, field_name) if isinstance(val, PipelineInput): # Put binding string to field setattr(node, field_name, val._data_binding()) - def resolve_base_node(name, node): + def resolve_base_node(name, node: BaseNode): """Resolve node name, compute and component for base node.""" # Set display name as node name if ( @@ -513,6 +514,8 @@ def resolve_base_node(name, node): if not is_data_binding_expression(node.compute): # Get compute for each job node.compute = resolver(node.compute, azureml_type=AzureMLResourceType.COMPUTE) + if has_attr_safe(node, "compute_name") and not is_data_binding_expression(node.compute_name): + node.compute_name = resolver(node.compute_name, azureml_type=AzureMLResourceType.COMPUTE) # Get the component id for each job's component # Note: do not use node.component as Sweep don't have that node._component = resolver( diff --git a/sdk/ml/azure-ai-ml/tests/internal/_utils.py b/sdk/ml/azure-ai-ml/tests/internal/_utils.py index 0d83af118b5a..874d6de06f69 100644 --- a/sdk/ml/azure-ai-ml/tests/internal/_utils.py +++ b/sdk/ml/azure-ai-ml/tests/internal/_utils.py @@ -11,7 +11,7 @@ PARAMETERS_TO_TEST = [ # which of them are available for other components? ( - "tests/test_configs/internal/ls_command_component.yaml", + "tests/test_configs/internal/command-component-ls/ls_command_component.yaml", {}, { "compute": "cpu-cluster", # runsettings.target @@ -106,6 +106,7 @@ "input_path": Input(type=AssetTypes.MLTABLE, path="mltable_imdb_reviews_train@latest"), }, { + "compute_name": "cpu-cluster", # runsettings.hdinsight.compute_name "queue": "default", # runsettings.hdinsight.queue "driver_memory": "1g", # runsettings.hdinsight.driver_memory "driver_cores": 2, # runsettings.hdinsight.driver_cores diff --git a/sdk/ml/azure-ai-ml/tests/internal/e2etests/test_component.py b/sdk/ml/azure-ai-ml/tests/internal/e2etests/test_component.py index 3e727374479d..bed39a769351 100644 --- a/sdk/ml/azure-ai-ml/tests/internal/e2etests/test_component.py +++ b/sdk/ml/azure-ai-ml/tests/internal/e2etests/test_component.py @@ -87,7 +87,10 @@ def test_component_load( component_resource = create_component(client, component_name, path=yaml_path) loaded_dict = load_registered_component(client, component_name, component_resource.version, omit_fields) - json_path = yaml_path.rsplit(".", 1)[0] + ".loaded_from_rest.json" + base_dir = "./tests/test_configs/internal" + json_path = (yaml_path.rsplit(".", 1)[0] + ".json") + json_path = os.path.join(base_dir, "loaded_from_rest", os.path.relpath(json_path, base_dir)) + os.makedirs(os.path.dirname(json_path), exist_ok=True) if not os.path.isfile(json_path): with open(json_path, "w") as f: json.dump(loaded_dict, f, indent=2) diff --git a/sdk/ml/azure-ai-ml/tests/internal/e2etests/test_pipeline_job.py b/sdk/ml/azure-ai-ml/tests/internal/e2etests/test_pipeline_job.py index ca52d7d603b7..f923641f454c 100644 --- a/sdk/ml/azure-ai-ml/tests/internal/e2etests/test_pipeline_job.py +++ b/sdk/ml/azure-ai-ml/tests/internal/e2etests/test_pipeline_job.py @@ -64,7 +64,7 @@ def create_internal_sample_dependent_datasets(client: MLClient): @pytest.mark.e2etest class TestPipelineJob(AzureRecordedTestCase): @classmethod - def _test_component(cls, node_func, inputs, runsettings_dict, pipeline_runsettings_dict, client): + def _test_component(cls, node_func, inputs, runsettings_dict, pipeline_runsettings_dict, client: MLClient): @pipeline() def pipeline_func(): node = node_func(**inputs) @@ -94,6 +94,14 @@ def pipeline_func(): # hack: timeout will be transformed into str if dot_key == "limits.timeout": expected_value = "PT5M" + # hack: compute_name for hdinsight will be transformed into arm str + if dot_key == "compute_name": + expected_value = f"/subscriptions/{client.subscription_id}/" \ + f"resourceGroups/{client.resource_group_name}/" \ + f"providers/Microsoft.MachineLearningServices/" \ + f"workspaces/{client.workspace_name}/" \ + f"computes/{expected_value}" + value = pydash.get(node_rest_dict, dot_key) if value != expected_value: mismatched_runsettings[dot_key] = (value, expected_value) @@ -105,7 +113,7 @@ def pipeline_func(): "yaml_path,inputs,runsettings_dict,pipeline_runsettings_dict", PARAMETERS_TO_TEST, ) - def test_anonymous_internal_component_in_pipeline( + def test_pipeline_anonymous( self, client: MLClient, yaml_path, inputs, runsettings_dict, pipeline_runsettings_dict ): # curated env with name & version diff --git a/sdk/ml/azure-ai-ml/tests/internal/unittests/test_component.py b/sdk/ml/azure-ai-ml/tests/internal/unittests/test_component.py index 34158c40139e..54b6730ea01b 100644 --- a/sdk/ml/azure-ai-ml/tests/internal/unittests/test_component.py +++ b/sdk/ml/azure-ai-ml/tests/internal/unittests/test_component.py @@ -31,7 +31,7 @@ def test_load_v2_component(self): def test_specific_error_message_on_load_from_dict(self): os.environ[AZUREML_INTERNAL_COMPONENTS_ENV_VAR] = "false" - yaml_path = "./tests/test_configs/internal/helloworld_component_command.yml" + yaml_path = "./tests/test_configs/internal/helloworld/helloworld_component_command.yml" with pytest.raises( ValidationException, match="Internal components is a private feature in v2, " "please set environment variable", @@ -319,7 +319,7 @@ def test_additional_includes(self) -> None: "./tests/test_configs/internal/component_with_additional_includes/helloworld_additional_includes.yml" ) component: InternalComponent = load_component(source=yaml_path) - assert component._validate().passed, component._validate()._to_dict() + assert component._validate().passed, repr(component._validate()) # resolve with component._resolve_local_code() as code_path: assert code_path.is_dir() @@ -340,7 +340,7 @@ def test_additional_includes(self) -> None: def test_additional_includes_with_code_specified(self, yaml_path: str, has_additional_includes: bool) -> None: yaml_path = os.path.join("./tests/test_configs/internal/component_with_additional_includes/", yaml_path) component: InternalComponent = load_component(source=yaml_path) - assert component._validate().passed, component._validate()._to_dict() + assert component._validate().passed, repr(component._validate()) # resolve with component._resolve_local_code() as code_path: assert code_path.is_dir() @@ -355,6 +355,12 @@ def test_additional_includes_with_code_specified(self, yaml_path: str, has_addit specified_code_path = Path(yaml_path).parent / yaml_dict.get("code", "./") assert code_path.resolve() == specified_code_path.resolve() + def test_docker_file_in_additional_includes(self): + yaml_path = "./tests/test_configs/internal/component_with_docker_file_" \ + "in_additional_includes/helloworld_additional_includes.yml" + component: InternalComponent = load_component(source=yaml_path) + assert component._validate().passed, repr(component._validate()) + @pytest.mark.parametrize( "yaml_path,expected_error_msg_prefix", [ @@ -377,7 +383,7 @@ def test_invalid_additional_includes(self, yaml_path: str, expected_error_msg_pr assert validation_result.error_messages["*"].startswith(expected_error_msg_prefix) def test_component_input_types(self) -> None: - yaml_path = "./tests/test_configs/internal/component_with_input_types/component_spec.yaml" + yaml_path = "./tests/test_configs/internal/component_with_input_outputs/component_spec.yaml" component: InternalComponent = load_component(yaml_path) component.code = "scope:1" @@ -403,7 +409,7 @@ def test_component_input_types(self) -> None: assert component._validate().passed is True, repr(component._validate()) def test_component_input_with_attrs(self) -> None: - yaml_path = "./tests/test_configs/internal/component_with_input_types/component_spec_with_attrs.yaml" + yaml_path = "./tests/test_configs/internal/component_with_input_outputs/component_spec_with_attrs.yaml" component: InternalComponent = load_component(source=yaml_path) expected_inputs = { @@ -433,6 +439,28 @@ def test_component_input_with_attrs(self) -> None: assert regenerated_component._to_rest_object().properties.component_spec["inputs"] == expected_inputs["inputs"] assert component._validate().passed is True, repr(component._validate()) + def test_component_output_with_attrs(self) -> None: + yaml_path = "./tests/test_configs/internal/component_with_input_outputs/component_spec_with_outputs.yaml" + component: InternalComponent = load_component(source=yaml_path) + assert component + + expected_outputs = { + "path_with_optional": { + # unknown field optional will be ignored + "type": 'AnyDirectory', + }, + "primitive_is_control": { + "is_control": True, + "type": "boolean", + } + } + assert component._to_rest_object().properties.component_spec["outputs"] == expected_outputs + assert component._validate().passed is True, repr(component._validate()) + + regenerated_component = Component._from_rest_object(component._to_rest_object()) + assert regenerated_component._to_rest_object().properties.component_spec["outputs"] == expected_outputs + assert component._validate().passed is True, repr(component._validate()) + def test_component_input_list_type(self) -> None: yaml_path = "./tests/test_configs/internal/scope-component/component_spec.yaml" component: InternalComponent = load_component(yaml_path) @@ -446,7 +474,7 @@ def test_loop_node_is_internal_components(self): from azure.ai.ml.constants._common import AZUREML_INTERNAL_COMPONENTS_ENV_VAR from azure.ai.ml.dsl._utils import environment_variable_overwrite - yaml_path = "./tests/test_configs/internal/helloworld_component_command.yml" + yaml_path = "./tests/test_configs/internal/helloworld/helloworld_component_command.yml" component_func = load_component(source=yaml_path) loop_node = LoopNode(body=component_func()) loop_node.body._referenced_control_flow_node_instance_id = loop_node._instance_id diff --git a/sdk/ml/azure-ai-ml/tests/internal/unittests/test_pipeline_job.py b/sdk/ml/azure-ai-ml/tests/internal/unittests/test_pipeline_job.py index 9a3869c00338..c4d954ee3769 100644 --- a/sdk/ml/azure-ai-ml/tests/internal/unittests/test_pipeline_job.py +++ b/sdk/ml/azure-ai-ml/tests/internal/unittests/test_pipeline_job.py @@ -19,6 +19,16 @@ ITPResourceConfiguration, ITPRetrySettings, TargetSelector, + Command, + Scope, + HDInsight, + Parallel, + Distributed, + DataTransfer, + Starlite, + Pipeline, + Hemera, + Ae365exepool, ) from azure.ai.ml._internal.entities import InternalBaseNode, InternalComponent, Scope from azure.ai.ml.constants._common import AssetTypes @@ -58,6 +68,30 @@ def pipeline_func(): result = dsl_pipeline._validate() assert result._to_dict() == {"result": "Succeeded"} + # check if node type is correct + node_in_pipeline = dsl_pipeline.jobs["node"] + if node_func.type == "CommandComponent": + assert isinstance(node_in_pipeline, Command) + elif node_func.type == "ScopeComponent": + assert isinstance(node_in_pipeline, Scope) + elif node_func.type == "HDInsightComponent": + assert isinstance(node_in_pipeline, HDInsight) + elif node_func.type == "ParallelComponent": + assert isinstance(node_in_pipeline, Parallel) + elif node_func.type == "DistributedComponent": + assert isinstance(node_in_pipeline, Distributed) + elif node_func.type == "DataTransferComponent": + assert isinstance(node_in_pipeline, DataTransfer) + elif node_func.type == "StarliteComponent": + assert isinstance(node_in_pipeline, Starlite) + elif node_func.type == "PipelineComponent": + assert isinstance(node_in_pipeline, Pipeline) + elif node_func.type == "HemeraComponent": + assert isinstance(node_in_pipeline, Hemera) + elif node_func.type == "Ae365exepoolComponent": + assert isinstance(node_in_pipeline, Ae365exepool) + + # check if node's runsettings are set correctly node_rest_dict = dsl_pipeline._to_rest_object().properties.jobs["node"] del node_rest_dict["componentId"] # delete component spec to make it a pure dict mismatched_runsettings = {} @@ -164,7 +198,7 @@ def pipeline_func(pipeline_input): @pytest.mark.usefixtures("enable_pipeline_private_preview_features") def test_internal_component_output_as_pipeline_component_output(self): - yaml_path = "./tests/test_configs/internal/component_with_input_types/component_spec.yaml" + yaml_path = "./tests/test_configs/internal/component_with_input_outputs/component_spec.yaml" component_func = load_component(yaml_path, params_override=[{"inputs": {}}]) @pipeline() @@ -220,7 +254,7 @@ def pipeline_func(): assert result._to_dict() == {"result": "Succeeded"} def test_gjd_internal_component_in_pipeline(self): - yaml_path = "./tests/test_configs/internal/ls_command_component.yaml" # GJD is based on CommandComponent + yaml_path = "./tests/test_configs/internal/command-component-ls/ls_command_component.yaml" # GJD is based on CommandComponent node_func: CommandComponent = load_component(yaml_path) node = node_func() @@ -246,7 +280,7 @@ def test_gjd_internal_component_in_pipeline(self): def test_elastic_component_in_pipeline(self): yaml_path = ( - "./tests/test_configs/internal/ls_command_component.yaml" # itp & elastic are based on CommandComponent + "./tests/test_configs/internal/command-component-ls/ls_command_component.yaml" # itp & elastic are based on CommandComponent ) node_func: CommandComponent = load_component(yaml_path) node = node_func() @@ -303,7 +337,7 @@ def test_elastic_component_in_pipeline(self): def test_singularity_component_in_pipeline(self): yaml_path = ( - "./tests/test_configs/internal/ls_command_component.yaml" # singularity is based on CommandComponent + "./tests/test_configs/internal/command-component-ls/ls_command_component.yaml" # singularity is based on CommandComponent ) node_func: CommandComponent = load_component(yaml_path) node = node_func() @@ -366,7 +400,7 @@ def test_singularity_component_in_pipeline(self): } def test_load_pipeline_job_with_internal_components_as_node(self): - yaml_path = Path("./tests/test_configs/internal/helloworld_component_scope.yml") + yaml_path = Path("./tests/test_configs/internal/helloworld/helloworld_component_scope.yml") scope_internal_func = load_component(source=yaml_path) with open(yaml_path, encoding="utf-8") as yaml_file: yaml_dict = yaml.safe_load(yaml_file) @@ -472,7 +506,7 @@ def pipeline_func(): assert dsl_pipeline._to_dict() == regenerated_pipeline_job._to_dict() def test_components_input_output(self): - yaml_path = "./tests/test_configs/internal/component_with_input_types/component_spec.yaml" + yaml_path = "./tests/test_configs/internal/component_with_input_outputs/component_spec.yaml" component: InternalComponent = load_component(yaml_path) fake_input = Input(type=AssetTypes.MLTABLE, path="azureml:scope_tsv:1") @@ -528,6 +562,24 @@ def pipeline_func(): expected_inputs[key] = {"job_input_type": "mltable", "uri": "azureml:scope_tsv:1"} assert rest_obj.properties.jobs["node"]["inputs"] == expected_inputs + def test_data_binding_on_node_runsettings(self): + test_path = "./tests/test_configs/internal/helloworld/helloworld_component_command.yml" + component: InternalComponent = load_component(test_path) + + @pipeline() + def pipeline_func(compute_name: str = "cpu-cluster", environment_name: str = "AzureML-PyTorch-1.6-GPU:1"): + node = component( + training_data=Input(path="./tests/test_configs/data"), + max_epochs=1, + ) + node.compute = compute_name + node.environment = environment_name + pipeline_job = pipeline_func() + assert pipeline_job._validate().passed, repr(pipeline_job._validate()) + rest_object = pipeline_job._to_rest_object().properties.jobs["node"] + assert str(rest_object["computeId"]) == "${{parent.inputs.compute_name}}" + assert str(rest_object["environment"]) == "${{parent.inputs.environment_name}}" + def test_pipeline_with_setting_node_output_directly(self) -> None: component_dir = Path(__file__).parent.parent.parent / "test_configs" / "internal" / "command-component" copy_func = load_component(component_dir / "command-linux/copy/component.yaml") diff --git a/sdk/ml/azure-ai-ml/tests/internal_utils/unittests/test_validation.py b/sdk/ml/azure-ai-ml/tests/internal_utils/unittests/test_validation.py index cc92335b9b95..333ca98ec4e8 100644 --- a/sdk/ml/azure-ai-ml/tests/internal_utils/unittests/test_validation.py +++ b/sdk/ml/azure-ai-ml/tests/internal_utils/unittests/test_validation.py @@ -30,6 +30,43 @@ def test_from_validation_error_dict(self) -> None: "result": "Failed", } + def test_from_validation_error_2(self): + validation_error = ValidationError( + field="_schema", + message={ + "outputs": { + "primitive_is_control": { + "value": { + "is_control": ["Unknown field."], + } + } + } + }, + ) + result = _ValidationResultBuilder.from_validation_error(validation_error, error_on_unknown_field=True) + assert result._to_dict() == { + "errors": [ + { + "message": "Unknown field.", + "path": "outputs.primitive_is_control.is_control", + "value": None, + }, + ], + "result": "Failed", + } + + result = _ValidationResultBuilder.from_validation_error(validation_error) + assert result._to_dict() == { + "warnings": [ + { + "message": "Unknown field.", + "path": "outputs.primitive_is_control.is_control", + "value": None, + }, + ], + "result": "Succeeded", + } + def test_from_validation_error_union_field(self): validation_error = ValidationError( field="_schema", diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/ae365exepool-component/component_spec.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/ae365exepool-component/component_spec.yaml].json index 63da1123a79c..0a0a9802d95c 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/ae365exepool-component/component_spec.yaml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/ae365exepool-component/component_spec.yaml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:15:06 GMT", + "Date": "Mon, 10 Oct 2022 08:22:35 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-eceb535d559191b93ab38d022d0b0516-15b34de39484adcd-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-5812b230b0394f0c86fe9d3a332a7484-2318530b33264855-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "23292f10-3fff-4334-b646-66c64409deb4", + "x-ms-correlation-request-id": "423e1ab4-7d62-4b84-885e-9bc44e7da3af", "x-ms-ratelimit-remaining-subscription-reads": "11983", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151506Z:23292f10-3fff-4334-b646-66c64409deb4", - "x-request-time": "0.122" + "x-ms-routing-request-id": "JAPANEAST:20221010T082235Z:423e1ab4-7d62-4b84-885e-9bc44e7da3af", + "x-request-time": "0.091" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sawcdivl5vo3cem", - "containerName": "azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-19T00:10:19.4497254\u002B00:00", + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-19T00:10:20.0957203\u002B00:00", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:15:07 GMT", + "Date": "Mon, 10 Oct 2022 08:22:35 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-4a7f624be41da247b9d630aa8a1e402d-a2a283681fe55d83-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-11009e4320eb3f71fbab6c83db2e4200-6972fdd0534b00ea-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "aadc3dd7-258b-4439-b668-1166a9d42195", + "x-ms-correlation-request-id": "25d89b6d-63d6-4967-9e3f-d8c5b6d90310", "x-ms-ratelimit-remaining-subscription-writes": "1191", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151507Z:aadc3dd7-258b-4439-b668-1166a9d42195", - "x-request-time": "0.096" + "x-ms-routing-request-id": "JAPANEAST:20221010T082236Z:25d89b6d-63d6-4967-9e3f-d8c5b6d90310", + "x-request-time": "0.094" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,26 +101,26 @@ } }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/ae365exepool-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/ae365exepool-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:15:07 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 08:22:36 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Accept-Ranges": "bytes", - "Content-Length": "3535", - "Content-MD5": "QqW25JGnycTHblw25UymFQ==", + "Content-Length": "3037", + "Content-MD5": "BJNWwWLteiyAJHIsUtiV1g==", "Content-Type": "application/octet-stream", - "Date": "Mon, 19 Sep 2022 15:15:07 GMT", - "ETag": "\u00220x8DA99D3774A7925\u0022", - "Last-Modified": "Mon, 19 Sep 2022 00:11:14 GMT", + "Date": "Mon, 10 Oct 2022 08:22:36 GMT", + "ETag": "\u00220x8DAAA6F10D672F5\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:25:22 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 19 Sep 2022 00:11:14 GMT", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:25:22 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "16c2bd31-0d3e-4f21-9349-1d46c3e16c4c", + "x-ms-meta-name": "c9319d9f-12c0-4f61-8318-7186e19eb493", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/az-ml-artifacts/00000000000000000000000000000000/ae365exepool-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/ae365exepool-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:15:07 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 08:22:36 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 19 Sep 2022 15:15:07 GMT", + "Date": "Mon, 10 Oct 2022 08:22:36 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/16c2bd31-0d3e-4f21-9349-1d46c3e16c4c/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/c9319d9f-12c0-4f61-8318-7186e19eb493/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "311", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/ae365exepool-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/ae365exepool-component" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:15:08 GMT", + "Date": "Mon, 10 Oct 2022 08:22:36 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-862300c055fa5a35de86cfec9d6d2d24-03ddf6f73f0b3724-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-1bcf0b07e87e17726b8360465cd0bbc2-3a8fcd66a36ec925-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "f1e928e4-e065-46b3-aca8-6deb64df42d7", + "x-ms-correlation-request-id": "4087ac3b-d6be-4c37-b04c-cf95ba9ed982", "x-ms-ratelimit-remaining-subscription-writes": "1183", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151508Z:f1e928e4-e065-46b3-aca8-6deb64df42d7", - "x-request-time": "0.064" + "x-ms-routing-request-id": "JAPANEAST:20221010T082237Z:4087ac3b-d6be-4c37-b04c-cf95ba9ed982", + "x-request-time": "0.253" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/16c2bd31-0d3e-4f21-9349-1d46c3e16c4c/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/c9319d9f-12c0-4f61-8318-7186e19eb493/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,20 +225,20 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/ae365exepool-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/ae365exepool-component" }, "systemData": { - "createdAt": "2022-09-19T00:11:15.2254943\u002B00:00", - "createdBy": "10832f61-6ea1-44eb-9622-85f30271eec4", - "createdByType": "Application", - "lastModifiedAt": "2022-09-19T15:15:08.5542952\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:25:23.2533498\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T08:22:36.9844465\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_785600726739/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_699982597219/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "3431", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -259,7 +259,7 @@ "isAnonymous": false, "isArchived": false, "componentSpec": { - "name": "test_785600726739", + "name": "test_699982597219", "description": "Use this auto-approved module to download data on EyesOn machine and interact with it for Compliant Annotation purpose.", "tags": { "category": "Component Tutorial", @@ -365,7 +365,7 @@ } }, "type": "AE365ExePoolComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/16c2bd31-0d3e-4f21-9349-1d46c3e16c4c/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/c9319d9f-12c0-4f61-8318-7186e19eb493/versions/1", "command": "cax.eyesonmodule.exe input={inputs.DataToLookAt} inputGoldHitRta=[{inputs.GoldHitRTAData}] localoutputfolderEnc=[{inputs.localoutputfolderEnc}] localoutputfolderDec=[{inputs.localoutputfolderDec}] timeoutSeconds=[{inputs.TimeoutSeconds}] hitappid=[{inputs.hitappid}] projectname=[{inputs.projectname}] judges=[{inputs.judges}] outputfolderEnc={outputs.outputfolderEnc} outputfolderDec={outputs.outputfolderDec} annotationsMayIncludeCustomerContent=[{inputs.annotationsMayIncludeCustomerContent}] taskGroupId=[{inputs.TaskGroupId}] goldHitRTADataType=[{inputs.GoldHitRTADataType}] outputfolderForOriginalHitData={outputs.OriginalHitData} taskFileTimestamp=[{inputs.taskFileTimestamp}]", "ae365exepool": { "ref_id": "654ec0ba-bed3-48eb-a594-efd0e9275e0d" @@ -376,25 +376,25 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "5004", + "Content-Length": "5003", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:15:09 GMT", + "Date": "Mon, 10 Oct 2022 08:22:39 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_785600726739/versions/0.0.1?api-version=2022-05-01", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_699982597219/versions/0.0.1?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-ae4b667529cd2facad8eebefe697651f-f43fe205df5c4b8e-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-e932e5b8e29e0a1538c387fdd90a5e82-19adc5f62d890040-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "d3dea765-e469-4b08-a6fc-54f57281254c", + "x-ms-correlation-request-id": "ad119968-9a8f-40e7-bf86-9fd7841e02c8", "x-ms-ratelimit-remaining-subscription-writes": "1182", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151509Z:d3dea765-e469-4b08-a6fc-54f57281254c", - "x-request-time": "0.746" + "x-ms-routing-request-id": "JAPANEAST:20221010T082239Z:ad119968-9a8f-40e7-bf86-9fd7841e02c8", + "x-request-time": "2.167" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_785600726739/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_699982597219/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -408,7 +408,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/AE365ExePoolComponent.json", - "name": "test_785600726739", + "name": "test_699982597219", "version": "0.0.1", "display_name": "CAX EyesOn Module [ND] v1.6", "is_deterministic": "True", @@ -517,27 +517,27 @@ "ae365exepool": { "ref_id": "654ec0ba-bed3-48eb-a594-efd0e9275e0d" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/16c2bd31-0d3e-4f21-9349-1d46c3e16c4c/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/c9319d9f-12c0-4f61-8318-7186e19eb493/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:15:09.108508\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T08:22:38.0996441\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:15:09.3418456\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T08:22:38.8139954\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_785600726739/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_699982597219/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "GET", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -545,27 +545,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:15:09 GMT", + "Date": "Mon, 10 Oct 2022 08:22:39 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-e5b35a041a3354ee71a26a94422eb69b-66f59b27d5a43095-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-3b3c829c19e1a2d02a4d745a09907cb8-4ccb3649f076df98-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "49e91dcc-0b01-45ea-8156-75b90e8c9602", + "x-ms-correlation-request-id": "9139a6a0-6194-48ef-b01a-14667a745c64", "x-ms-ratelimit-remaining-subscription-reads": "11982", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151509Z:49e91dcc-0b01-45ea-8156-75b90e8c9602", - "x-request-time": "0.157" + "x-ms-routing-request-id": "JAPANEAST:20221010T082240Z:9139a6a0-6194-48ef-b01a-14667a745c64", + "x-request-time": "0.344" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_785600726739/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_699982597219/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -579,7 +579,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/AE365ExePoolComponent.json", - "name": "test_785600726739", + "name": "test_699982597219", "version": "0.0.1", "display_name": "CAX EyesOn Module [ND] v1.6", "is_deterministic": "True", @@ -688,21 +688,21 @@ "ae365exepool": { "ref_id": "654ec0ba-bed3-48eb-a594-efd0e9275e0d" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/16c2bd31-0d3e-4f21-9349-1d46c3e16c4c/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/c9319d9f-12c0-4f61-8318-7186e19eb493/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:15:09.108508\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T08:22:38.0996441\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:15:09.3418456\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T08:22:38.8139954\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } } ], "Variables": { - "component_name": "test_785600726739" + "component_name": "test_699982597219" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/batch_inference/batch_score.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/batch_inference/batch_score.yaml].json index 21575df870b8..bca878d001df 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/batch_inference/batch_score.yaml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/batch_inference/batch_score.yaml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:36 GMT", + "Date": "Mon, 10 Oct 2022 08:21:50 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-a3c218e3faee5a934c0e6cdb3062ad80-8c29697f59a99a15-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-a352b2b4fd137612916d6d78c1fd9666-f95a788ce7342036-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "432b2ad3-6c4a-4cce-8965-755ca335d129", + "x-ms-correlation-request-id": "42a5f957-a612-4586-8c56-5a6428750b10", "x-ms-ratelimit-remaining-subscription-reads": "11995", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151437Z:432b2ad3-6c4a-4cce-8965-755ca335d129", - "x-request-time": "0.129" + "x-ms-routing-request-id": "JAPANEAST:20221010T082150Z:42a5f957-a612-4586-8c56-5a6428750b10", + "x-request-time": "0.133" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sawcdivl5vo3cem", - "containerName": "azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-19T00:10:19.4497254\u002B00:00", + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-19T00:10:20.0957203\u002B00:00", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:36 GMT", + "Date": "Mon, 10 Oct 2022 08:21:51 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-ac5d6fc37909d8c3cb19bd99c5988112-342bac555bed82ba-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-689005d37dd3fc1fde31f82d8c793ff1-d65825ffce855eb9-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "dc4ef23f-730e-430e-acbc-37ec7c73545b", + "x-ms-correlation-request-id": "6af2ddd3-e443-44e9-8aaa-cc887a93d19a", "x-ms-ratelimit-remaining-subscription-writes": "1197", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151437Z:dc4ef23f-730e-430e-acbc-37ec7c73545b", - "x-request-time": "0.094" + "x-ms-routing-request-id": "JAPANEAST:20221010T082151Z:6af2ddd3-e443-44e9-8aaa-cc887a93d19a", + "x-request-time": "0.120" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,26 +101,26 @@ } }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/batch_inference/batch_score.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/batch_inference/batch_score.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:14:37 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 08:21:51 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Accept-Ranges": "bytes", - "Content-Length": "1785", - "Content-MD5": "49mgDMscslXyD\u002BqKAzbAWQ==", + "Content-Length": "1890", + "Content-MD5": "Nsal/dhEjjdoIJBn7yWG7Q==", "Content-Type": "application/octet-stream", - "Date": "Mon, 19 Sep 2022 15:14:37 GMT", - "ETag": "\u00220x8DA99D37733C020\u0022", - "Last-Modified": "Mon, 19 Sep 2022 00:11:14 GMT", + "Date": "Mon, 10 Oct 2022 08:21:51 GMT", + "ETag": "\u00220x8DAAA6EF2CC2544\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:24:32 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 19 Sep 2022 00:11:14 GMT", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:24:32 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "3f55b831-c769-40ed-be03-c7a574b42b38", + "x-ms-meta-name": "12a3d416-e2ad-465d-9896-ebaf6bf0b49e", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/az-ml-artifacts/00000000000000000000000000000000/batch_inference/batch_score.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/batch_inference/batch_score.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:14:37 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 08:21:51 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 19 Sep 2022 15:14:37 GMT", + "Date": "Mon, 10 Oct 2022 08:21:51 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3f55b831-c769-40ed-be03-c7a574b42b38/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/12a3d416-e2ad-465d-9896-ebaf6bf0b49e/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "304", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/batch_inference" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/batch_inference" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:37 GMT", + "Date": "Mon, 10 Oct 2022 08:21:52 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-bc8425a8609ca68a19c6f8b7caf5784e-329d2caf45e5b032-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-c0a3672e623aef0be9037972094511f8-f8473ae305eb182e-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "c72cab46-778b-4bc1-9559-386664d7da6f", + "x-ms-correlation-request-id": "0afa2c58-6905-4b23-85a9-0986c12efd27", "x-ms-ratelimit-remaining-subscription-writes": "1195", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151438Z:c72cab46-778b-4bc1-9559-386664d7da6f", - "x-request-time": "0.087" + "x-ms-routing-request-id": "JAPANEAST:20221010T082152Z:0afa2c58-6905-4b23-85a9-0986c12efd27", + "x-request-time": "0.249" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3f55b831-c769-40ed-be03-c7a574b42b38/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/12a3d416-e2ad-465d-9896-ebaf6bf0b49e/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,20 +225,20 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/batch_inference" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/batch_inference" }, "systemData": { - "createdAt": "2022-09-19T00:11:14.955282\u002B00:00", - "createdBy": "10832f61-6ea1-44eb-9622-85f30271eec4", - "createdByType": "Application", - "lastModifiedAt": "2022-09-19T15:14:38.534132\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:24:32.8523963\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T08:21:52.3602777\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_135385380155/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_708243128765/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "1828", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -261,7 +261,7 @@ "isAnonymous": false, "isArchived": false, "componentSpec": { - "name": "test_135385380155", + "name": "test_708243128765", "description": "Score images with MNIST image classification model.", "tags": { "Parallel": "", @@ -289,7 +289,7 @@ } }, "type": "ParallelComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3f55b831-c769-40ed-be03-c7a574b42b38/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/12a3d416-e2ad-465d-9896-ebaf6bf0b49e/versions/1", "environment": { "docker": { "image": "mcr.microsoft.com/azureml/openmpi3.1.2-cuda10.1-cudnn7-ubuntu18.04" @@ -329,25 +329,25 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "3237", + "Content-Length": "3235", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:38 GMT", + "Date": "Mon, 10 Oct 2022 08:21:54 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_135385380155/versions/0.0.1?api-version=2022-05-01", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_708243128765/versions/0.0.1?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-385b32986586aa9a9fe7e7133bbd1d9b-b5bf7b34d6280773-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-e765835c8b7e44c130478697343d8701-a53c4471515b14be-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "859c5ea5-b648-4b5b-a2d1-dc496eb5a809", + "x-ms-correlation-request-id": "be5fd015-48e8-439f-b505-f495d6c0019f", "x-ms-ratelimit-remaining-subscription-writes": "1194", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151439Z:859c5ea5-b648-4b5b-a2d1-dc496eb5a809", - "x-request-time": "0.721" + "x-ms-routing-request-id": "JAPANEAST:20221010T082154Z:be5fd015-48e8-439f-b505-f495d6c0019f", + "x-request-time": "1.760" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_135385380155/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_708243128765/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -363,7 +363,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/ParallelComponent.json", - "name": "test_135385380155", + "name": "test_708243128765", "version": "0.0.1", "display_name": "Parallel Score Image Classification with MNIST", "is_deterministic": "True", @@ -429,27 +429,27 @@ "output_data": "outputs.scored_dataset", "entry": "batch_score.py" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3f55b831-c769-40ed-be03-c7a574b42b38/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/12a3d416-e2ad-465d-9896-ebaf6bf0b49e/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:14:39.1069807\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T08:21:53.5907515\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:14:39.3259672\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T08:21:54.2497496\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_135385380155/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_708243128765/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "GET", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -457,27 +457,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:38 GMT", + "Date": "Mon, 10 Oct 2022 08:21:55 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-4eeb5a61367db77e8748ebabacb9b60a-c33d1226e97bc66c-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-05170112d2d63027c48e3204783b4d4a-334ab2dee4671bdd-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "7b6f2524-4bda-4816-a72e-31a51171098b", + "x-ms-correlation-request-id": "38e927a0-6028-4d31-b352-8179439f4e7a", "x-ms-ratelimit-remaining-subscription-reads": "11994", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151439Z:7b6f2524-4bda-4816-a72e-31a51171098b", - "x-request-time": "0.160" + "x-ms-routing-request-id": "JAPANEAST:20221010T082155Z:38e927a0-6028-4d31-b352-8179439f4e7a", + "x-request-time": "0.389" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_135385380155/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_708243128765/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -493,7 +493,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/ParallelComponent.json", - "name": "test_135385380155", + "name": "test_708243128765", "version": "0.0.1", "display_name": "Parallel Score Image Classification with MNIST", "is_deterministic": "True", @@ -559,21 +559,21 @@ "output_data": "outputs.scored_dataset", "entry": "batch_score.py" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3f55b831-c769-40ed-be03-c7a574b42b38/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/12a3d416-e2ad-465d-9896-ebaf6bf0b49e/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:14:39.1069807\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T08:21:53.5907515\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:14:39.3259672\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T08:21:54.2497496\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } } ], "Variables": { - "component_name": "test_135385380155" + "component_name": "test_708243128765" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/command-component-ls/ls_command_component.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/command-component-ls/ls_command_component.yaml].json new file mode 100644 index 000000000000..3bfc3c74358a --- /dev/null +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/command-component-ls/ls_command_component.yaml].json @@ -0,0 +1,406 @@ +{ + "Entries": [ + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore?api-version=2022-05-01", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 08:21:30 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-77563ae69dfcbcbc4c6d48e79db3cac5-e1919993fa825460-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-test-westus2-02", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "c4b3688f-ce57-4d6f-9748-187ae4f6752d", + "x-ms-ratelimit-remaining-subscription-reads": "11999", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T082131Z:c4b3688f-ce57-4d6f-9748-187ae4f6752d", + "x-request-time": "0.953" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", + "name": "workspaceblobstore", + "type": "Microsoft.MachineLearningServices/workspaces/datastores", + "properties": { + "description": null, + "tags": null, + "properties": null, + "isDefault": true, + "credentials": { + "credentialsType": "AccountKey" + }, + "datastoreType": "AzureBlob", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "endpoint": "core.windows.net", + "protocol": "https", + "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" + }, + "systemData": { + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "createdByType": "Application", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "lastModifiedByType": "Application" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore/listSecrets?api-version=2022-05-01", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 08:21:31 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-6a02b8d456ce6dfc3231e5f56a2db5fb-ca2ffeea1e2141bb-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-test-westus2-02", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "88069f23-beff-41d2-85fb-07c8ba56e404", + "x-ms-ratelimit-remaining-subscription-writes": "1199", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T082132Z:88069f23-beff-41d2-85fb-07c8ba56e404", + "x-request-time": "0.604" + }, + "ResponseBody": { + "secretsType": "AccountKey", + "key": "dGhpcyBpcyBmYWtlIGtleQ==" + } + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/command-component-ls/ls_command_component.yaml", + "RequestMethod": "HEAD", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 08:21:32 GMT", + "x-ms-version": "2021-08-06" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Accept-Ranges": "bytes", + "Content-Length": "234", + "Content-MD5": "UrxIkzZNuLtqksFOP/IPuw==", + "Content-Type": "application/octet-stream", + "Date": "Mon, 10 Oct 2022 08:21:33 GMT", + "ETag": "\u00220x8DAAA704BF59F5F\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:34:11 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "Vary": "Origin", + "x-ms-access-tier": "Hot", + "x-ms-access-tier-inferred": "true", + "x-ms-blob-type": "BlockBlob", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:34:11 GMT", + "x-ms-lease-state": "available", + "x-ms-lease-status": "unlocked", + "x-ms-meta-name": "79148717-5f10-44c7-83de-7b53696b6795", + "x-ms-meta-upload_status": "completed", + "x-ms-meta-version": "1", + "x-ms-server-encrypted": "true", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/command-component-ls/ls_command_component.yaml", + "RequestMethod": "HEAD", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 08:21:33 GMT", + "x-ms-version": "2021-08-06" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Date": "Mon, 10 Oct 2022 08:21:33 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "Transfer-Encoding": "chunked", + "Vary": "Origin", + "x-ms-error-code": "BlobNotFound", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/79148717-5f10-44c7-83de-7b53696b6795/versions/1?api-version=2022-05-01", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "309", + "Content-Type": "application/json", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": { + "properties": { + "properties": { + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" + }, + "isAnonymous": true, + "isArchived": false, + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/command-component-ls" + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 08:21:34 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-0f1c02175e4011df06ecf595884ab344-a266b5eb15a2b052-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-test-westus2-02", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "8548c46e-2e51-43f9-af0d-010b3bd5f1f8", + "x-ms-ratelimit-remaining-subscription-writes": "1199", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T082135Z:8548c46e-2e51-43f9-af0d-010b3bd5f1f8", + "x-request-time": "0.947" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/79148717-5f10-44c7-83de-7b53696b6795/versions/1", + "name": "1", + "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", + "properties": { + "description": null, + "tags": {}, + "properties": { + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" + }, + "isArchived": false, + "isAnonymous": false, + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/command-component-ls" + }, + "systemData": { + "createdAt": "2022-10-10T03:34:12.2357175\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T08:21:35.0668577\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_494965668828/versions/0.0.1?api-version=2022-05-01", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "645", + "Content-Type": "application/json", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": { + "properties": { + "properties": {}, + "tags": {}, + "isAnonymous": false, + "isArchived": false, + "componentSpec": { + "name": "test_494965668828", + "tags": {}, + "version": "0.0.1", + "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", + "display_name": "Ls Command", + "is_deterministic": true, + "inputs": {}, + "outputs": {}, + "type": "CommandComponent", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/79148717-5f10-44c7-83de-7b53696b6795/versions/1", + "environment": { + "os": "Linux", + "name": "AzureML-Designer" + }, + "command": "ls" + } + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "1336", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 08:21:38 GMT", + "Expires": "-1", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_494965668828/versions/0.0.1?api-version=2022-05-01", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-017d94849f6aa9031e0853603eb79b29-a024fd8505735d6d-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-02", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "32619251-9811-4bca-b48f-4b777b9d3d40", + "x-ms-ratelimit-remaining-subscription-writes": "1198", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T082138Z:32619251-9811-4bca-b48f-4b777b9d3d40", + "x-request-time": "3.412" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_494965668828/versions/0.0.1", + "name": "0.0.1", + "type": "Microsoft.MachineLearningServices/workspaces/components/versions", + "properties": { + "description": null, + "tags": {}, + "properties": {}, + "isArchived": false, + "isAnonymous": false, + "componentSpec": { + "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", + "name": "test_494965668828", + "version": "0.0.1", + "display_name": "Ls Command", + "is_deterministic": "True", + "type": "CommandComponent", + "environment": { + "name": "AzureML-Designer", + "os": "Linux" + }, + "successful_return_code": "Zero", + "command": "ls", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/79148717-5f10-44c7-83de-7b53696b6795/versions/1" + } + }, + "systemData": { + "createdAt": "2022-10-10T08:21:37.889345\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T08:21:38.5599159\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_494965668828/versions/0.0.1?api-version=2022-05-01", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 08:21:38 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-9f2d0a34d8dac4549de87fe0621d0b77-0f839c7346bc9880-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-test-westus2-02", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "18ca472a-bf04-4a31-a101-7c525c3e2b3a", + "x-ms-ratelimit-remaining-subscription-reads": "11998", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T082139Z:18ca472a-bf04-4a31-a101-7c525c3e2b3a", + "x-request-time": "0.346" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_494965668828/versions/0.0.1", + "name": "0.0.1", + "type": "Microsoft.MachineLearningServices/workspaces/components/versions", + "properties": { + "description": null, + "tags": {}, + "properties": {}, + "isArchived": false, + "isAnonymous": false, + "componentSpec": { + "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", + "name": "test_494965668828", + "version": "0.0.1", + "display_name": "Ls Command", + "is_deterministic": "True", + "type": "CommandComponent", + "environment": { + "name": "AzureML-Designer", + "os": "Linux" + }, + "successful_return_code": "Zero", + "command": "ls", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/79148717-5f10-44c7-83de-7b53696b6795/versions/1" + } + }, + "systemData": { + "createdAt": "2022-10-10T08:21:37.889345\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T08:21:38.5599159\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" + } + } + } + ], + "Variables": { + "component_name": "test_494965668828" + } +} diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/data-transfer-component/component_spec.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/data-transfer-component/component_spec.yaml].json index 7f7acc925215..d5a6b8f937da 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/data-transfer-component/component_spec.yaml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/data-transfer-component/component_spec.yaml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:53 GMT", + "Date": "Mon, 10 Oct 2022 08:22:19 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-daec7fcce49b8ef02661b5bae615d273-9aaeebc29670aa7e-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-857792aaa2c642d864266974a9310d40-73fa2daf7467597a-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "7ecceaf0-3c5c-4b8f-9250-a726868b6d3a", + "x-ms-correlation-request-id": "085b9d2f-8a74-491e-bc90-d8914daa3b99", "x-ms-ratelimit-remaining-subscription-reads": "11987", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151454Z:7ecceaf0-3c5c-4b8f-9250-a726868b6d3a", - "x-request-time": "0.106" + "x-ms-routing-request-id": "JAPANEAST:20221010T082219Z:085b9d2f-8a74-491e-bc90-d8914daa3b99", + "x-request-time": "0.090" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sawcdivl5vo3cem", - "containerName": "azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-19T00:10:19.4497254\u002B00:00", + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-19T00:10:20.0957203\u002B00:00", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:54 GMT", + "Date": "Mon, 10 Oct 2022 08:22:19 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-c0d177c421add6a4fb4e14ad5dde1359-c895cea16c459822-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-5b9d6be15e73ea7a840d5a867c96835d-037b1543d62b570a-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "65987b06-44ed-474d-9752-ab8d8e88e41f", + "x-ms-correlation-request-id": "60a510d1-aaf6-4293-a323-e2976ab73879", "x-ms-ratelimit-remaining-subscription-writes": "1193", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151455Z:65987b06-44ed-474d-9752-ab8d8e88e41f", - "x-request-time": "0.099" + "x-ms-routing-request-id": "JAPANEAST:20221010T082220Z:60a510d1-aaf6-4293-a323-e2976ab73879", + "x-request-time": "0.117" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,26 +101,26 @@ } }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/data-transfer-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/data-transfer-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:14:55 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 08:22:20 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Accept-Ranges": "bytes", - "Content-Length": "662", - "Content-MD5": "MKNy0eziOSgx4bMOiS4wuw==", + "Content-Length": "534", + "Content-MD5": "AGevjuGj0u\u002BzWFtkFxspxA==", "Content-Type": "application/octet-stream", - "Date": "Mon, 19 Sep 2022 15:14:55 GMT", - "ETag": "\u00220x8DA99D376E5D274\u0022", - "Last-Modified": "Mon, 19 Sep 2022 00:11:13 GMT", + "Date": "Mon, 10 Oct 2022 08:22:20 GMT", + "ETag": "\u00220x8DAAA6F0716787F\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:25:06 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 19 Sep 2022 00:11:13 GMT", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:25:06 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "adbb1689-e476-4344-8db5-2e4c692f650a", + "x-ms-meta-name": "e4143c07-53b4-4159-a962-a0c3efc68cc3", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/az-ml-artifacts/00000000000000000000000000000000/data-transfer-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/data-transfer-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:14:55 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 08:22:20 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 19 Sep 2022 15:14:55 GMT", + "Date": "Mon, 10 Oct 2022 08:22:20 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/adbb1689-e476-4344-8db5-2e4c692f650a/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/e4143c07-53b4-4159-a962-a0c3efc68cc3/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "312", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/data-transfer-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/data-transfer-component" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:56 GMT", + "Date": "Mon, 10 Oct 2022 08:22:20 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-4d2dfc20f3ddd1c287651ad96b7da7c4-ba10023e937f497c-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-7b8bbdf7d192f1b66ece0430fceb4b81-216d57382bf6c7f5-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "a5c73db0-88e8-4437-8a69-0bac660571f9", + "x-ms-correlation-request-id": "160cc797-b421-44ed-ac19-f632e5ef903e", "x-ms-ratelimit-remaining-subscription-writes": "1187", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151456Z:a5c73db0-88e8-4437-8a69-0bac660571f9", - "x-request-time": "0.068" + "x-ms-routing-request-id": "JAPANEAST:20221010T082221Z:160cc797-b421-44ed-ac19-f632e5ef903e", + "x-request-time": "0.256" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/adbb1689-e476-4344-8db5-2e4c692f650a/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/e4143c07-53b4-4159-a962-a0c3efc68cc3/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,20 +225,20 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/data-transfer-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/data-transfer-component" }, "systemData": { - "createdAt": "2022-09-19T00:11:14.7354197\u002B00:00", - "createdBy": "10832f61-6ea1-44eb-9622-85f30271eec4", - "createdByType": "Application", - "lastModifiedAt": "2022-09-19T15:14:56.5989079\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:25:06.8837744\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T08:22:21.1269439\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_596140572090/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_565509701420/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "1075", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -259,7 +259,7 @@ "isAnonymous": false, "isArchived": false, "componentSpec": { - "name": "test_596140572090", + "name": "test_565509701420", "description": "transfer data between common storage types such as Azure Blob Storage and Azure Data Lake.", "tags": { "category": "Component Tutorial", @@ -282,32 +282,32 @@ } }, "type": "DataTransferComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/adbb1689-e476-4344-8db5-2e4c692f650a/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/e4143c07-53b4-4159-a962-a0c3efc68cc3/versions/1" } } }, "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1880", + "Content-Length": "1878", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:57 GMT", + "Date": "Mon, 10 Oct 2022 08:22:22 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_596140572090/versions/0.0.1?api-version=2022-05-01", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_565509701420/versions/0.0.1?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-728155321b225155da813c72d71f17bc-3dbdf28a29a43387-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-f373744095298f4cc97fcf41dbc53031-c2d3a5f0ccef4ce8-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "c460b892-9dbb-4537-b864-2c74fc8ac279", + "x-ms-correlation-request-id": "65082d50-658b-4afe-868a-26f65e557227", "x-ms-ratelimit-remaining-subscription-writes": "1186", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151457Z:c460b892-9dbb-4537-b864-2c74fc8ac279", - "x-request-time": "0.594" + "x-ms-routing-request-id": "JAPANEAST:20221010T082223Z:65082d50-658b-4afe-868a-26f65e557227", + "x-request-time": "1.731" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_596140572090/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_565509701420/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -321,7 +321,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/DataTransferComponent.json", - "name": "test_596140572090", + "name": "test_565509701420", "version": "0.0.1", "display_name": "Data Transfer", "is_deterministic": "True", @@ -347,27 +347,27 @@ "datatransfer": { "allow_overwrite": "True" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/adbb1689-e476-4344-8db5-2e4c692f650a/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/e4143c07-53b4-4159-a962-a0c3efc68cc3/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:14:57.058927\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T08:22:22.211214\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:14:57.2430354\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T08:22:22.8930557\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_596140572090/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_565509701420/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "GET", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -375,27 +375,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:57 GMT", + "Date": "Mon, 10 Oct 2022 08:22:23 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-51a2356a89d89f30c370bf7c64cfd10a-e504f65d28ab74f5-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-f60494c556cee8644c0f403fa2fd2d81-46e2a4927839598f-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "f45e9859-b860-46e7-b418-e3e6d9fd3dbb", + "x-ms-correlation-request-id": "c7c02e7c-10c8-476d-957c-123f18f570cc", "x-ms-ratelimit-remaining-subscription-reads": "11986", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151457Z:f45e9859-b860-46e7-b418-e3e6d9fd3dbb", - "x-request-time": "0.130" + "x-ms-routing-request-id": "JAPANEAST:20221010T082224Z:c7c02e7c-10c8-476d-957c-123f18f570cc", + "x-request-time": "0.313" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_596140572090/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_565509701420/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -409,7 +409,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/DataTransferComponent.json", - "name": "test_596140572090", + "name": "test_565509701420", "version": "0.0.1", "display_name": "Data Transfer", "is_deterministic": "True", @@ -435,21 +435,21 @@ "datatransfer": { "allow_overwrite": "True" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/adbb1689-e476-4344-8db5-2e4c692f650a/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/e4143c07-53b4-4159-a962-a0c3efc68cc3/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:14:57.058927\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T08:22:22.211214\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:14:57.2430354\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T08:22:22.8930557\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } } ], "Variables": { - "component_name": "test_596140572090" + "component_name": "test_565509701420" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/distribution-component/component_spec.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/distribution-component/component_spec.yaml].json index f88761fbacd8..99748d627427 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/distribution-component/component_spec.yaml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/distribution-component/component_spec.yaml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:32 GMT", + "Date": "Mon, 10 Oct 2022 08:21:42 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-2bf050150e726aad0b758bc4ed676d5b-548884a5ed39c464-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-9be0f44ae3395c827baed1b6414cc470-8bb09cf6d8c16f4f-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "5f1918a5-4668-4704-8278-04d51a69a790", + "x-ms-correlation-request-id": "acbfaf9d-8442-4298-85da-1dc1880cd952", "x-ms-ratelimit-remaining-subscription-reads": "11997", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151433Z:5f1918a5-4668-4704-8278-04d51a69a790", - "x-request-time": "0.084" + "x-ms-routing-request-id": "JAPANEAST:20221010T082142Z:acbfaf9d-8442-4298-85da-1dc1880cd952", + "x-request-time": "0.083" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sawcdivl5vo3cem", - "containerName": "azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-19T00:10:19.4497254\u002B00:00", + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-19T00:10:20.0957203\u002B00:00", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:32 GMT", + "Date": "Mon, 10 Oct 2022 08:21:42 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-ace5b40482e35a4de8f107a8099167b0-31e9149abaae2c70-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-4b8817d075d71fd82f14b5940d8c6624-c2ebb947dc0f220a-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "95a4465b-adc5-4a8b-bb28-04af537029c0", + "x-ms-correlation-request-id": "928f7d6f-e8b1-4552-9798-3a60ad21a4f0", "x-ms-ratelimit-remaining-subscription-writes": "1198", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151433Z:95a4465b-adc5-4a8b-bb28-04af537029c0", - "x-request-time": "0.094" + "x-ms-routing-request-id": "JAPANEAST:20221010T082142Z:928f7d6f-e8b1-4552-9798-3a60ad21a4f0", + "x-request-time": "0.100" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,26 +101,26 @@ } }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/distribution-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/distribution-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:14:33 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 08:21:43 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Accept-Ranges": "bytes", - "Content-Length": "958", - "Content-MD5": "eBpew2DsgVPNUdWwo1Ymyg==", + "Content-Length": "758", + "Content-MD5": "btu6HWM/OieNWo2NW/ZsWA==", "Content-Type": "application/octet-stream", - "Date": "Mon, 19 Sep 2022 15:14:33 GMT", - "ETag": "\u00220x8DA99D37719D33D\u0022", - "Last-Modified": "Mon, 19 Sep 2022 00:11:14 GMT", + "Date": "Mon, 10 Oct 2022 08:21:43 GMT", + "ETag": "\u00220x8DAAA6EED25D44D\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:24:22 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 19 Sep 2022 00:11:14 GMT", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:24:22 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "de780bcc-4585-439e-9768-8971bc5798cf", + "x-ms-meta-name": "d6667388-5223-4184-8359-e2929a825e06", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/az-ml-artifacts/00000000000000000000000000000000/distribution-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/distribution-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:14:33 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 08:21:43 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 19 Sep 2022 15:14:33 GMT", + "Date": "Mon, 10 Oct 2022 08:21:43 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/de780bcc-4585-439e-9768-8971bc5798cf/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "311", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/distribution-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/distribution-component" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:33 GMT", + "Date": "Mon, 10 Oct 2022 08:21:44 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-c12c05a45b1c1fb2447d1f99bc289687-a9f143a68c9b4c5d-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-6a92a231a2d6e4bdbb4a673878c4c5c6-e3643a97d36c3670-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "6b788db9-ea0d-40ac-8100-f37ab17fadc3", + "x-ms-correlation-request-id": "6eac6ad1-e84e-4dd2-bec4-524e1e3517b0", "x-ms-ratelimit-remaining-subscription-writes": "1197", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151433Z:6b788db9-ea0d-40ac-8100-f37ab17fadc3", - "x-request-time": "0.071" + "x-ms-routing-request-id": "JAPANEAST:20221010T082144Z:6eac6ad1-e84e-4dd2-bec4-524e1e3517b0", + "x-request-time": "0.253" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/de780bcc-4585-439e-9768-8971bc5798cf/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,20 +225,20 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/distribution-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/distribution-component" }, "systemData": { - "createdAt": "2022-09-19T00:11:14.8305647\u002B00:00", - "createdBy": "10832f61-6ea1-44eb-9622-85f30271eec4", - "createdByType": "Application", - "lastModifiedAt": "2022-09-19T15:14:33.9246219\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:24:23.5013448\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T08:21:43.9472959\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_602026988697/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_796835642678/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "1078", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -255,7 +255,7 @@ "isAnonymous": false, "isArchived": false, "componentSpec": { - "name": "test_602026988697", + "name": "test_796835642678", "tags": {}, "version": "0.0.1", "$schema": "https://componentsdk.azureedge.net/jsonschema/DistributedComponent.json", @@ -278,7 +278,7 @@ } }, "type": "DistributedComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/de780bcc-4585-439e-9768-8971bc5798cf/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1", "environment": { "os": "Linux", "name": "AzureML-Minimal" @@ -295,23 +295,23 @@ "Cache-Control": "no-cache", "Content-Length": "2069", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:34 GMT", + "Date": "Mon, 10 Oct 2022 08:21:47 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_602026988697/versions/0.0.1?api-version=2022-05-01", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_796835642678/versions/0.0.1?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-a215914582bb65f8c9ffbd6fb579107c-e718584190b934f1-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-628beda7c10e6a6b7ea3bb172448af44-690622f1608620ba-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "aa4b74a9-a516-4157-bb0b-2971fd0160af", + "x-ms-correlation-request-id": "9d4091ed-b843-4d49-a8d2-644d7b0385ff", "x-ms-ratelimit-remaining-subscription-writes": "1196", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151435Z:aa4b74a9-a516-4157-bb0b-2971fd0160af", - "x-request-time": "1.071" + "x-ms-routing-request-id": "JAPANEAST:20221010T082147Z:9d4091ed-b843-4d49-a8d2-644d7b0385ff", + "x-request-time": "2.531" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_602026988697/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_796835642678/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -322,7 +322,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/DistributedComponent.json", - "name": "test_602026988697", + "name": "test_796835642678", "version": "0.0.1", "display_name": "MPI Example", "is_deterministic": "True", @@ -355,27 +355,27 @@ "type": "mpi", "additional_arguments": "python train.py --input-path {inputs.input_path} [--string-parameter {inputs.string_parameter}] --output-path {outputs.output_path}" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/de780bcc-4585-439e-9768-8971bc5798cf/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:14:34.7443356\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T08:21:45.9846443\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:14:34.98522\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T08:21:46.6483014\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_602026988697/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_796835642678/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "GET", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -383,27 +383,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:34 GMT", + "Date": "Mon, 10 Oct 2022 08:21:47 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-786067b74fabb72c4d50482d39f728a9-b25232148293719e-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-b9a99787bbd936a50b01b8033f9ef31b-32c22e9b73b7db35-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "debc0613-f656-43ec-9caf-4eb152ed2824", + "x-ms-correlation-request-id": "684d5991-35e8-4569-8b3b-17764cccd804", "x-ms-ratelimit-remaining-subscription-reads": "11996", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151435Z:debc0613-f656-43ec-9caf-4eb152ed2824", - "x-request-time": "0.120" + "x-ms-routing-request-id": "JAPANEAST:20221010T082147Z:684d5991-35e8-4569-8b3b-17764cccd804", + "x-request-time": "0.352" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_602026988697/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_796835642678/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -414,7 +414,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/DistributedComponent.json", - "name": "test_602026988697", + "name": "test_796835642678", "version": "0.0.1", "display_name": "MPI Example", "is_deterministic": "True", @@ -447,21 +447,21 @@ "type": "mpi", "additional_arguments": "python train.py --input-path {inputs.input_path} [--string-parameter {inputs.string_parameter}] --output-path {outputs.output_path}" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/de780bcc-4585-439e-9768-8971bc5798cf/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:14:34.7443356\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T08:21:45.9846443\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:14:34.98522\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T08:21:46.6483014\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } } ], "Variables": { - "component_name": "test_602026988697" + "component_name": "test_796835642678" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/hdi-component/component_spec.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/hdi-component/component_spec.yaml].json index a9f6243d1c12..cad8cdfd8cc8 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/hdi-component/component_spec.yaml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/hdi-component/component_spec.yaml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:44 GMT", + "Date": "Mon, 10 Oct 2022 06:46:12 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-47552a212bcd7a4b15df1ae498e8f211-355a839624208932-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-25cffd6ac80ea61def3abfadc400b057-d05efb9dc53b6e00-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "7b61b201-973d-47ac-9baf-1cdb04a2c4a1", - "x-ms-ratelimit-remaining-subscription-reads": "11991", + "x-ms-correlation-request-id": "e895546a-0bf6-40e9-a295-8b9e8b0cd76a", + "x-ms-ratelimit-remaining-subscription-reads": "11999", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151444Z:7b61b201-973d-47ac-9baf-1cdb04a2c4a1", - "x-request-time": "0.092" + "x-ms-routing-request-id": "JAPANEAST:20221010T064612Z:e895546a-0bf6-40e9-a295-8b9e8b0cd76a", + "x-request-time": "0.188" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sawcdivl5vo3cem", - "containerName": "azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-19T00:10:19.4497254\u002B00:00", + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-19T00:10:20.0957203\u002B00:00", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:44 GMT", + "Date": "Mon, 10 Oct 2022 06:46:13 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-818230e7c8d5ae98fae365c574db6fe4-3044ff2f69465a3e-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-272a6551a9df45f56be9df11232110ec-8ccd76b9c0fead31-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "2655223c-52ec-48f0-ac3f-67ff029d296e", - "x-ms-ratelimit-remaining-subscription-writes": "1195", + "x-ms-correlation-request-id": "1ec972f5-8895-4a96-8715-e22a830adbf5", + "x-ms-ratelimit-remaining-subscription-writes": "1199", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151445Z:2655223c-52ec-48f0-ac3f-67ff029d296e", - "x-request-time": "0.097" + "x-ms-routing-request-id": "JAPANEAST:20221010T064613Z:1ec972f5-8895-4a96-8715-e22a830adbf5", + "x-request-time": "0.487" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,26 +101,26 @@ } }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/hdi-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/hdi-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:14:45 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 06:46:13 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Accept-Ranges": "bytes", - "Content-Length": "1108", - "Content-MD5": "YwjqftKHRlA4Fjk2RZSO8w==", + "Content-Length": "996", + "Content-MD5": "YQpjQbTaabwHHrCyGPUlDQ==", "Content-Type": "application/octet-stream", - "Date": "Mon, 19 Sep 2022 15:14:45 GMT", - "ETag": "\u00220x8DA99D377591D0C\u0022", - "Last-Modified": "Mon, 19 Sep 2022 00:11:14 GMT", + "Date": "Mon, 10 Oct 2022 06:46:14 GMT", + "ETag": "\u00220x8DAAA7098D2C25D\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:36:20 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 19 Sep 2022 00:11:14 GMT", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:36:19 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "d2c00006-beca-4b1a-a8b3-e9f8a3c02817", + "x-ms-meta-name": "e570c693-a029-4859-b95b-ad7969f48661", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/az-ml-artifacts/00000000000000000000000000000000/hdi-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/hdi-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:14:45 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 06:46:14 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 19 Sep 2022 15:14:45 GMT", + "Date": "Mon, 10 Oct 2022 06:46:14 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d2c00006-beca-4b1a-a8b3-e9f8a3c02817/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/e570c693-a029-4859-b95b-ad7969f48661/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "302", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/hdi-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/hdi-component" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:44 GMT", + "Date": "Mon, 10 Oct 2022 06:46:15 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-a132103fa749023528821f64afe102a6-3b23e5391625f2dc-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-c9b0e6a8ad5cd4b88ccc116bd5e204ea-05ef8ff04459938c-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "efc66157-6ded-4f82-a46d-e1432dac601c", - "x-ms-ratelimit-remaining-subscription-writes": "1191", + "x-ms-correlation-request-id": "fa313090-28e0-4232-90d2-8511078e51b1", + "x-ms-ratelimit-remaining-subscription-writes": "1199", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151445Z:efc66157-6ded-4f82-a46d-e1432dac601c", - "x-request-time": "0.068" + "x-ms-routing-request-id": "JAPANEAST:20221010T064616Z:fa313090-28e0-4232-90d2-8511078e51b1", + "x-request-time": "0.338" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d2c00006-beca-4b1a-a8b3-e9f8a3c02817/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/e570c693-a029-4859-b95b-ad7969f48661/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,20 +225,20 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/hdi-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/hdi-component" }, "systemData": { - "createdAt": "2022-09-19T00:11:15.2501424\u002B00:00", - "createdBy": "10832f61-6ea1-44eb-9622-85f30271eec4", - "createdByType": "Application", - "lastModifiedAt": "2022-09-19T15:14:45.5778141\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:36:21.0505082\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T06:46:16.0448881\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_264584502583/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_771683924009/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "1454", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -261,7 +261,7 @@ "isAnonymous": false, "isArchived": false, "componentSpec": { - "name": "test_264584502583", + "name": "test_771683924009", "description": "Train a Spark ML model using an HDInsight Spark cluster", "tags": { "HDInsight": "", @@ -291,7 +291,7 @@ } }, "type": "HDInsightComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d2c00006-beca-4b1a-a8b3-e9f8a3c02817/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/e570c693-a029-4859-b95b-ad7969f48661/versions/1", "hdinsight": { "file": "train-spark.py", "args": "--input_path {inputs.input_path} [--regularization_rate {inputs.regularization_rate}] --output_path {outputs.output_path}" @@ -302,25 +302,25 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2374", + "Content-Length": "2372", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:45 GMT", + "Date": "Mon, 10 Oct 2022 06:46:17 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_264584502583/versions/0.0.1?api-version=2022-05-01", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_771683924009/versions/0.0.1?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-c8280a01e9747fad1ac0eb57dcc82bda-04920e9d98b5df86-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-b5cd8a0aade2fadeebedc6be3b8637a6-78686853f62ec4f1-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "aadfdaaf-4569-4673-ab35-6c5e054d1172", - "x-ms-ratelimit-remaining-subscription-writes": "1190", + "x-ms-correlation-request-id": "d2a0db2d-4b4b-4ded-a7b3-5c28db7e2471", + "x-ms-ratelimit-remaining-subscription-writes": "1198", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151446Z:aadfdaaf-4569-4673-ab35-6c5e054d1172", - "x-request-time": "0.754" + "x-ms-routing-request-id": "JAPANEAST:20221010T064618Z:d2a0db2d-4b4b-4ded-a7b3-5c28db7e2471", + "x-request-time": "1.796" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_264584502583/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_771683924009/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -336,7 +336,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/HDInsightComponent.json", - "name": "test_264584502583", + "name": "test_771683924009", "version": "0.0.1", "display_name": "Train in Spark", "is_deterministic": "True", @@ -371,27 +371,27 @@ "args": "--input_path {inputs.input_path} [--regularization_rate {inputs.regularization_rate}] --output_path {outputs.output_path}", "file": "train-spark.py" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d2c00006-beca-4b1a-a8b3-e9f8a3c02817/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/e570c693-a029-4859-b95b-ad7969f48661/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:14:46.1145559\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T06:46:17.2616833\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:14:46.3488651\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T06:46:17.9085779\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_264584502583/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_771683924009/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "GET", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -399,27 +399,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:45 GMT", + "Date": "Mon, 10 Oct 2022 06:46:18 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-796c3dfbea56a35b96f73ce54808af9b-94b40a67806a5257-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-a7414b4b173e52313d4aebef990c0652-2181fd71bc5020dd-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "47a2fee8-a45c-4a4f-b151-c978d476483e", - "x-ms-ratelimit-remaining-subscription-reads": "11990", + "x-ms-correlation-request-id": "744f7998-65f9-4696-b365-7a3279d208bd", + "x-ms-ratelimit-remaining-subscription-reads": "11998", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151446Z:47a2fee8-a45c-4a4f-b151-c978d476483e", - "x-request-time": "0.125" + "x-ms-routing-request-id": "JAPANEAST:20221010T064619Z:744f7998-65f9-4696-b365-7a3279d208bd", + "x-request-time": "0.689" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_264584502583/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_771683924009/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -435,7 +435,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/HDInsightComponent.json", - "name": "test_264584502583", + "name": "test_771683924009", "version": "0.0.1", "display_name": "Train in Spark", "is_deterministic": "True", @@ -470,21 +470,21 @@ "args": "--input_path {inputs.input_path} [--regularization_rate {inputs.regularization_rate}] --output_path {outputs.output_path}", "file": "train-spark.py" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d2c00006-beca-4b1a-a8b3-e9f8a3c02817/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/e570c693-a029-4859-b95b-ad7969f48661/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:14:46.1145559\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T06:46:17.2616833\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:14:46.3488651\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T06:46:17.9085779\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } } ], "Variables": { - "component_name": "test_264584502583" + "component_name": "test_771683924009" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/hemera-component/component.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/hemera-component/component.yaml].json index c0685d6e8130..070076f0c0ea 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/hemera-component/component.yaml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/hemera-component/component.yaml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:47 GMT", + "Date": "Mon, 10 Oct 2022 08:22:11 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-4d2089c6c3b7dd5900ebb5058106ca16-2fb34164adc6fa21-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-d520308334a5d860c327f11b1d0c9940-0c3ecd4c5c10c7e5-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "0f3ff9bc-9818-4478-9858-1b7f6f507ad9", + "x-ms-correlation-request-id": "99d2abec-8b23-41ce-aebe-a29d671840ca", "x-ms-ratelimit-remaining-subscription-reads": "11989", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151448Z:0f3ff9bc-9818-4478-9858-1b7f6f507ad9", - "x-request-time": "0.091" + "x-ms-routing-request-id": "JAPANEAST:20221010T082212Z:99d2abec-8b23-41ce-aebe-a29d671840ca", + "x-request-time": "0.112" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sawcdivl5vo3cem", - "containerName": "azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-19T00:10:19.4497254\u002B00:00", + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-19T00:10:20.0957203\u002B00:00", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,20 +79,20 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:47 GMT", + "Date": "Mon, 10 Oct 2022 08:22:12 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-2fbfd22be28aa7c28d85db0b1f7ef16c-adb508dd1a1c2cf5-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-7035726cdd8a2e41a299ea6187c3c6db-cd0f90103a1d73c9-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "7b10f53e-ee02-48e0-91e2-399f47727805", + "x-ms-correlation-request-id": "2985e17f-84ed-47cd-a3d0-b244b3b8bf50", "x-ms-ratelimit-remaining-subscription-writes": "1194", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151448Z:7b10f53e-ee02-48e0-91e2-399f47727805", + "x-ms-routing-request-id": "JAPANEAST:20221010T082212Z:2985e17f-84ed-47cd-a3d0-b244b3b8bf50", "x-request-time": "0.099" }, "ResponseBody": { @@ -101,26 +101,26 @@ } }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/hemera-component/component.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/hemera-component/component.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:14:48 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 08:22:12 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Accept-Ranges": "bytes", - "Content-Length": "2180", - "Content-MD5": "vW/0UQWaDxIzmm/HEeANvA==", + "Content-Length": "1905", + "Content-MD5": "AcQHpefZr524XtHJQHzR7Q==", "Content-Type": "application/octet-stream", - "Date": "Mon, 19 Sep 2022 15:14:48 GMT", - "ETag": "\u00220x8DA99D377487DA0\u0022", - "Last-Modified": "Mon, 19 Sep 2022 00:11:14 GMT", + "Date": "Mon, 10 Oct 2022 08:22:12 GMT", + "ETag": "\u00220x8DAAA6F020D13E0\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:24:57 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 19 Sep 2022 00:11:14 GMT", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:24:57 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "6651a080-8439-48fc-9469-ed56845fb6ea", + "x-ms-meta-name": "efc28047-774b-4de0-8703-4c096cd4319e", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/az-ml-artifacts/00000000000000000000000000000000/hemera-component/component.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/hemera-component/component.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:14:48 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 08:22:12 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 19 Sep 2022 15:14:48 GMT", + "Date": "Mon, 10 Oct 2022 08:22:12 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/6651a080-8439-48fc-9469-ed56845fb6ea/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/efc28047-774b-4de0-8703-4c096cd4319e/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "305", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/hemera-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/hemera-component" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:48 GMT", + "Date": "Mon, 10 Oct 2022 08:22:13 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-59e51a0e27af8fb39bc8112f9d226faa-5add368df909216c-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-4408002ac3cb96263424859ad461f84a-36af99aed275d5cb-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "1bd7b2fd-6564-4e59-ae79-1c8ae7beffb8", + "x-ms-correlation-request-id": "d074ed5c-8115-47bd-9d5f-0488db293cea", "x-ms-ratelimit-remaining-subscription-writes": "1189", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151449Z:1bd7b2fd-6564-4e59-ae79-1c8ae7beffb8", - "x-request-time": "0.428" + "x-ms-routing-request-id": "JAPANEAST:20221010T082213Z:d074ed5c-8115-47bd-9d5f-0488db293cea", + "x-request-time": "0.257" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/6651a080-8439-48fc-9469-ed56845fb6ea/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/efc28047-774b-4de0-8703-4c096cd4319e/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,20 +225,20 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/hemera-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/hemera-component" }, "systemData": { - "createdAt": "2022-09-19T00:11:15.1784471\u002B00:00", - "createdBy": "10832f61-6ea1-44eb-9622-85f30271eec4", - "createdByType": "Application", - "lastModifiedAt": "2022-09-19T15:14:49.3105516\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:24:58.5267334\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T08:22:13.5591772\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_682896139165/versions/0.0.2?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_315280257191/versions/0.0.2?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "2227", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -259,7 +259,7 @@ "isAnonymous": false, "isArchived": false, "componentSpec": { - "name": "test_682896139165", + "name": "test_315280257191", "description": "Ads LR DNN Raw Keys Dummy sample.", "tags": { "category": "Component Tutorial", @@ -322,7 +322,7 @@ } }, "type": "HemeraComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/6651a080-8439-48fc-9469-ed56845fb6ea/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/efc28047-774b-4de0-8703-4c096cd4319e/versions/1", "command": "run.bat [-_TrainingDataDir {inputs.TrainingDataDir}] [-_ValidationDataDir {inputs.ValidationDataDir}] [-_InitialModelDir {inputs.InitialModelDir}] -_CosmosRootDir {inputs.CosmosRootDir} -_PsCount 0 %CLUSTER%={inputs.YarnCluster} -JobQueue {inputs.JobQueue} -_WorkerCount {inputs.WorkerCount} -_Cpu {inputs.Cpu} -_Memory {inputs.Memory} -_HdfsRootDir {inputs.HdfsRootDir} -_ExposedPort \u00223200-3210,3300-3321\u0022 -_NodeLostBlocker -_UsePhysicalIP -_SyncWorker -_EntranceFileName run.py -_StartupArguments \u0022\u0022 -_PythonZipPath \u0022https://dummy/foo/bar.zip\u0022 -_ModelOutputDir {outputs.output1} -_ValidationOutputDir {outputs.output2}", "hemera": { "ref_id": "1bd1525c-082e-4652-a9b2-9c60783ec551" @@ -333,25 +333,25 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "3665", + "Content-Length": "3663", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:51 GMT", + "Date": "Mon, 10 Oct 2022 08:22:15 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_682896139165/versions/0.0.2?api-version=2022-05-01", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_315280257191/versions/0.0.2?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-4bea055afa29919381180f8cf72178b4-7bbbf003942ba24c-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-d79c391db451632abb6ace0c30a392e8-52a8ea4c4e7521f7-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "47fee220-2170-4f78-92ad-c6a1159ed60f", + "x-ms-correlation-request-id": "b647f9d0-024b-4e4b-9e04-3878c6ad114f", "x-ms-ratelimit-remaining-subscription-writes": "1188", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151452Z:47fee220-2170-4f78-92ad-c6a1159ed60f", - "x-request-time": "0.919" + "x-ms-routing-request-id": "JAPANEAST:20221010T082215Z:b647f9d0-024b-4e4b-9e04-3878c6ad114f", + "x-request-time": "1.703" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_682896139165/versions/0.0.2", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_315280257191/versions/0.0.2", "name": "0.0.2", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -365,7 +365,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/HemeraComponent.json", - "name": "test_682896139165", + "name": "test_315280257191", "version": "0.0.2", "display_name": "Ads LR DNN Raw Keys", "is_deterministic": "True", @@ -439,27 +439,27 @@ "hemera": { "ref_id": "1bd1525c-082e-4652-a9b2-9c60783ec551" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/6651a080-8439-48fc-9469-ed56845fb6ea/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/efc28047-774b-4de0-8703-4c096cd4319e/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:14:51.8643132\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T08:22:14.6357398\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:14:52.0794274\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T08:22:15.3114219\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_682896139165/versions/0.0.2?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_315280257191/versions/0.0.2?api-version=2022-05-01", "RequestMethod": "GET", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -467,27 +467,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:51 GMT", + "Date": "Mon, 10 Oct 2022 08:22:16 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-081426682403bea7dfcc8eb4c9b51450-3961a68120153a1d-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-dab772606f57c87d9e45c5c703fd1975-14e1539dbf6fcdf9-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "3f97ebb2-b20e-4bf4-bc1c-61d65f196b5e", + "x-ms-correlation-request-id": "5e47b836-edae-49e2-9ad1-1dbc0eeec8fc", "x-ms-ratelimit-remaining-subscription-reads": "11988", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151452Z:3f97ebb2-b20e-4bf4-bc1c-61d65f196b5e", - "x-request-time": "0.149" + "x-ms-routing-request-id": "JAPANEAST:20221010T082216Z:5e47b836-edae-49e2-9ad1-1dbc0eeec8fc", + "x-request-time": "0.326" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_682896139165/versions/0.0.2", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_315280257191/versions/0.0.2", "name": "0.0.2", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -501,7 +501,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/HemeraComponent.json", - "name": "test_682896139165", + "name": "test_315280257191", "version": "0.0.2", "display_name": "Ads LR DNN Raw Keys", "is_deterministic": "True", @@ -575,21 +575,21 @@ "hemera": { "ref_id": "1bd1525c-082e-4652-a9b2-9c60783ec551" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/6651a080-8439-48fc-9469-ed56845fb6ea/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/efc28047-774b-4de0-8703-4c096cd4319e/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:14:51.8643132\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T08:22:14.6357398\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:14:52.0794274\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T08:22:15.3114219\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } } ], "Variables": { - "component_name": "test_682896139165" + "component_name": "test_315280257191" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/ls_command_component.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/ls_command_component.yaml].json deleted file mode 100644 index 30372b916580..000000000000 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/ls_command_component.yaml].json +++ /dev/null @@ -1,2781 +0,0 @@ -{ - "Entries": [ - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore?api-version=2022-05-01", - "RequestMethod": "GET", - "RequestHeaders": { - "Accept": "application/json", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.13 (Windows-10-10.0.22621-SP0)" - }, - "RequestBody": null, - "StatusCode": 200, - "ResponseHeaders": { - "Cache-Control": "no-cache", - "Content-Encoding": "gzip", - "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 02:57:59 GMT", - "Expires": "-1", - "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-70b9bcefa07e4ee3366cfd0ecafeb026-034dcd1a5abe79fa-01\u0022", - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Transfer-Encoding": "chunked", - "Vary": [ - "Accept-Encoding", - "Accept-Encoding" - ], - "x-aml-cluster": "vienna-test-westus2-01", - "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "943e5252-6d24-43f5-9cb2-d629a5b653f6", - "x-ms-ratelimit-remaining-subscription-reads": "11998", - "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20220930T025800Z:943e5252-6d24-43f5-9cb2-d629a5b653f6", - "x-request-time": "0.131" - }, - "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", - "name": "workspaceblobstore", - "type": "Microsoft.MachineLearningServices/workspaces/datastores", - "properties": { - "description": null, - "tags": null, - "properties": null, - "isDefault": true, - "credentials": { - "credentialsType": "AccountKey" - }, - "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", - "endpoint": "core.windows.net", - "protocol": "https", - "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" - }, - "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", - "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", - "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", - "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", - "lastModifiedByType": "Application" - } - } - }, - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore/listSecrets?api-version=2022-05-01", - "RequestMethod": "POST", - "RequestHeaders": { - "Accept": "application/json", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.13 (Windows-10-10.0.22621-SP0)" - }, - "RequestBody": null, - "StatusCode": 200, - "ResponseHeaders": { - "Cache-Control": "no-cache", - "Content-Encoding": "gzip", - "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 02:58:00 GMT", - "Expires": "-1", - "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-17063ef401d136cf3476891f7e298b77-e712981352963567-01\u0022", - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Transfer-Encoding": "chunked", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-01", - "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "2873a4d2-39fb-4377-b81b-4bc7638adb82", - "x-ms-ratelimit-remaining-subscription-writes": "1199", - "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20220930T025801Z:2873a4d2-39fb-4377-b81b-4bc7638adb82", - "x-request-time": "0.099" - }, - "ResponseBody": { - "secretsType": "AccountKey", - "key": "dGhpcyBpcyBmYWtlIGtleQ==" - } - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/.gitattributes", - "RequestMethod": "HEAD", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Fri, 30 Sep 2022 02:58:01 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": null, - "StatusCode": 404, - "ResponseHeaders": { - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "Transfer-Encoding": "chunked", - "Vary": "Origin", - "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/.gitattributes", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "19", - "Content-MD5": "GTc0QMDRF8A1AiQ\u002BQg5suw==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "KiB0ZXh0PWF1dG8gZW9sPWxmCg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "GTc0QMDRF8A1AiQ\u002BQg5suw==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F970CF9C8\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:02 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "y3e9M1S/S4w=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/additional_includes/assets/LICENSE", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "24", - "Content-MD5": "OPSuMV1kzaelt7RNAso03A==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "VEhJUyBJUyBBIEZBS0UgTElDRU5TRSEK", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "OPSuMV1kzaelt7RNAso03A==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F9729A546\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:02 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "QNirJFvGTh0=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/additional_includes/library/hello.py", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "16", - "Content-MD5": "b3cFCaiaq\u002BnmwHMwuU0PqQ==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "cHJpbnQoIkhlbGxvICIpCg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "b3cFCaiaq\u002BnmwHMwuU0PqQ==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F974602B2\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:02 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "xohmeijl8Y0=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/additional_includes/assets/helloworld_invalid_additional_includes_existing_file.yml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "38", - "Content-MD5": "SnTL8Ld24McBaXedKCGDKA==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "VEhJUyBJUyBBIEZJTEUgVE8gVEVTVCBFWElTVElORyBGSUxFLgo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "SnTL8Ld24McBaXedKCGDKA==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F97626021\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "qQJxURsFEMU=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/additional_includes/library/world.py", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "16", - "Content-MD5": "SXJqVSFL9HC\u002BySp9hCFhOQ==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "cHJpbnQoIldvcmxkISIpCg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "SXJqVSFL9HC\u002BySp9hCFhOQ==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F9775BE2D\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "1WMIubjk4AA=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/ae365exepool-component/component_spec.loaded_from_rest.json", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "3403", - "Content-MD5": "xV0WH\u002BQHI9sS7EHHgRSQsA==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "ewogICJkZXNjcmlwdGlvbiI6ICJVc2UgdGhpcyBhdXRvLWFwcHJvdmVkIG1vZHVsZSB0byBkb3dubG9hZCBkYXRhIG9uIEV5ZXNPbiBtYWNoaW5lIGFuZCBpbnRlcmFjdCB3aXRoIGl0IGZvciBDb21wbGlhbnQgQW5ub3RhdGlvbiBwdXJwb3NlLiIsCiAgInRhZ3MiOiB7CiAgICAiY2F0ZWdvcnkiOiAiQ29tcG9uZW50IFR1dG9yaWFsIiwKICAgICJjb250YWN0IjogImFtbGRlc2lnbmVyQG1pY3Jvc29mdC5jb20iCiAgfSwKICAidmVyc2lvbiI6ICIwLjAuMSIsCiAgIiRzY2hlbWEiOiAiaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0FFMzY1RXhlUG9vbENvbXBvbmVudC5qc29uIiwKICAiZGlzcGxheV9uYW1lIjogIkNBWCBFeWVzT24gTW9kdWxlIFtORF0gdjEuNiIsCiAgImlzX2RldGVybWluaXN0aWMiOiB0cnVlLAogICJpbnB1dHMiOiB7CiAgICAiRGF0YVRvTG9va0F0IjogewogICAgICAidHlwZSI6ICJBbnlGaWxlIgogICAgfSwKICAgICJHb2xkSGl0UlRBRGF0YSI6IHsKICAgICAgInR5cGUiOiAiQW55RmlsZSIsCiAgICAgICJvcHRpb25hbCI6IHRydWUKICAgIH0sCiAgICAiQ29tcGxpYW5jZUNsdXN0ZXIiOiB7CiAgICAgICJ0eXBlIjogInN0cmluZyIsCiAgICAgICJkZWZhdWx0IjogIk1zUmVzZWFyY2gtRXllc09uLUFubm90YXRpb24iLAogICAgICAiZGVzY3JpcHRpb24iOiAiY29tcGxpYW5jZSBjbHVzdGVyIG5hbWUiCiAgICB9LAogICAgIkhlcm9uSWQiOiB7CiAgICAgICJ0eXBlIjogInN0cmluZyIsCiAgICAgICJkZXNjcmlwdGlvbiI6ICJIZXJvbiBJRCIKICAgIH0sCiAgICAibG9jYWxvdXRwdXRmb2xkZXJFbmMiOiB7CiAgICAgICJ0eXBlIjogInN0cmluZyIsCiAgICAgICJvcHRpb25hbCI6IHRydWUsCiAgICAgICJkZXNjcmlwdGlvbiI6ICJsb2NhbCBvdXRwdXQgZm9sZGVyIGZvciBlbmNyeXB0ZWQgZGF0YSIKICAgIH0sCiAgICAibG9jYWxvdXRwdXRmb2xkZXJEZWMiOiB7CiAgICAgICJ0eXBlIjogInN0cmluZyIsCiAgICAgICJvcHRpb25hbCI6IHRydWUsCiAgICAgICJkZXNjcmlwdGlvbiI6ICJsb2NhbCBvdXRwdXQgZm9sZGVyIGZvciBkZWNyeXB0ZWQgZGF0YSIKICAgIH0sCiAgICAiVGltZW91dFNlY29uZHMiOiB7CiAgICAgICJ0eXBlIjogImludGVnZXIiLAogICAgICAib3B0aW9uYWwiOiB0cnVlLAogICAgICAiZGVmYXVsdCI6IDUwMDAwMCwKICAgICAgImRlc2NyaXB0aW9uIjogInRpbWVvdXQgaW4gc2Vjb25kcyIKICAgIH0sCiAgICAiaGl0YXBwaWQiOiB7CiAgICAgICJ0eXBlIjogImludGVnZXIiLAogICAgICAib3B0aW9uYWwiOiB0cnVlLAogICAgICAiZGVmYXVsdCI6IDMxMzQ2LAogICAgICAiZGVzY3JpcHRpb24iOiAiaGl0YXBwIGlkIgogICAgfSwKICAgICJwcm9qZWN0bmFtZSI6IHsKICAgICAgInR5cGUiOiAic3RyaW5nIiwKICAgICAgIm9wdGlvbmFsIjogdHJ1ZSwKICAgICAgImRlZmF1bHQiOiAiTGF0ZXN0RTJFdGVtcGxhdGUiLAogICAgICAiZGVzY3JpcHRpb24iOiAicHJvamVjdCBuYW1lIgogICAgfSwKICAgICJqdWRnZXMiOiB7CiAgICAgICJ0eXBlIjogInN0cmluZyIsCiAgICAgICJvcHRpb25hbCI6IHRydWUsCiAgICAgICJkZWZhdWx0IjogImp1d2FuZzticmFkd2FsbCIsCiAgICAgICJkZXNjcmlwdGlvbiI6ICJqdWRnZXMiCiAgICB9LAogICAgImFubm90YXRpb25zTWF5SW5jbHVkZUN1c3RvbWVyQ29udGVudCI6IHsKICAgICAgInR5cGUiOiAic3RyaW5nIiwKICAgICAgIm9wdGlvbmFsIjogdHJ1ZSwKICAgICAgImRlZmF1bHQiOiAiMSIsCiAgICAgICJkZXNjcmlwdGlvbiI6ICJhbm5vdGF0aW9ucyBtYXkgaW5jbHVkZSBjdXN0b21lciBjb250ZW50IgogICAgfSwKICAgICJUYXNrR3JvdXBJZCI6IHsKICAgICAgInR5cGUiOiAiaW50ZWdlciIsCiAgICAgICJvcHRpb25hbCI6IHRydWUsCiAgICAgICJkZWZhdWx0IjogODY4OTEsCiAgICAgICJkZXNjcmlwdGlvbiI6ICJ0YXNrIGdyb3VwIGlkIgogICAgfSwKICAgICJHb2xkSGl0UlRBRGF0YVR5cGUiOiB7CiAgICAgICJ0eXBlIjogImVudW0iLAogICAgICAib3B0aW9uYWwiOiB0cnVlLAogICAgICAiZGVzY3JpcHRpb24iOiAiZ29sZCBoaXQgcnRhIGRhdGEgdHlwZSIsCiAgICAgICJlbnVtIjogWwogICAgICAgICJHb2xkIiwKICAgICAgICAiUlRBIiwKICAgICAgICAiUXVhbGlmaWNhdGlvbiIsCiAgICAgICAgIlByZXZpZXciCiAgICAgIF0KICAgIH0sCiAgICAidGFza0ZpbGVUaW1lc3RhbXAiOiB7CiAgICAgICJ0eXBlIjogInN0cmluZyIsCiAgICAgICJvcHRpb25hbCI6IHRydWUsCiAgICAgICJkZWZhdWx0IjogIjIwMjEuMTIuMjEuMjMuNTUuMDAiLAogICAgICAiZGVzY3JpcHRpb24iOiAidGFzayBmaWxlIHRpbWVzdGFtcCIKICAgIH0KICB9LAogICJvdXRwdXRzIjogewogICAgIm91dHB1dGZvbGRlckVuYyI6IHsKICAgICAgInR5cGUiOiAiQW55RGlyZWN0b3J5IgogICAgfSwKICAgICJvdXRwdXRmb2xkZXJEZWMiOiB7CiAgICAgICJ0eXBlIjogIkFueURpcmVjdG9yeSIKICAgIH0sCiAgICAiT3JpZ2luYWxIaXREYXRhIjogewogICAgICAidHlwZSI6ICJBbnlEaXJlY3RvcnkiCiAgICB9CiAgfSwKICAidHlwZSI6ICJBRTM2NUV4ZVBvb2xDb21wb25lbnQiLAogICJjb21tYW5kIjogImNheC5leWVzb25tb2R1bGUuZXhlIGlucHV0PXtpbnB1dHMuRGF0YVRvTG9va0F0fSBpbnB1dEdvbGRIaXRSdGE9W3tpbnB1dHMuR29sZEhpdFJUQURhdGF9XSBsb2NhbG91dHB1dGZvbGRlckVuYz1be2lucHV0cy5sb2NhbG91dHB1dGZvbGRlckVuY31dIGxvY2Fsb3V0cHV0Zm9sZGVyRGVjPVt7aW5wdXRzLmxvY2Fsb3V0cHV0Zm9sZGVyRGVjfV0gdGltZW91dFNlY29uZHM9W3tpbnB1dHMuVGltZW91dFNlY29uZHN9XSBoaXRhcHBpZD1be2lucHV0cy5oaXRhcHBpZH1dIHByb2plY3RuYW1lPVt7aW5wdXRzLnByb2plY3RuYW1lfV0ganVkZ2VzPVt7aW5wdXRzLmp1ZGdlc31dIG91dHB1dGZvbGRlckVuYz17b3V0cHV0cy5vdXRwdXRmb2xkZXJFbmN9IG91dHB1dGZvbGRlckRlYz17b3V0cHV0cy5vdXRwdXRmb2xkZXJEZWN9IGFubm90YXRpb25zTWF5SW5jbHVkZUN1c3RvbWVyQ29udGVudD1be2lucHV0cy5hbm5vdGF0aW9uc01heUluY2x1ZGVDdXN0b21lckNvbnRlbnR9XSB0YXNrR3JvdXBJZD1be2lucHV0cy5UYXNrR3JvdXBJZH1dIGdvbGRIaXRSVEFEYXRhVHlwZT1be2lucHV0cy5Hb2xkSGl0UlRBRGF0YVR5cGV9XSBvdXRwdXRmb2xkZXJGb3JPcmlnaW5hbEhpdERhdGE9e291dHB1dHMuT3JpZ2luYWxIaXREYXRhfSB0YXNrRmlsZVRpbWVzdGFtcD1be2lucHV0cy50YXNrRmlsZVRpbWVzdGFtcH1dIiwKICAiYWUzNjVleGVwb29sIjogewogICAgInJlZl9pZCI6ICI2NTRlYzBiYS1iZWQzLTQ4ZWItYTU5NC1lZmQwZTkyNzVlMGQiCiAgfQp9Cg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "xV0WH\u002BQHI9sS7EHHgRSQsA==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F9776CF73\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "KqtOE3rbrNE=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/command-component/command-linux/ls/ls.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "331", - "Content-MD5": "DgFLARKi0e4hqmZOmJSCJA==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbgpuYW1lOiBsc19jb21tYW5kCmRpc3BsYXlfbmFtZTogTHMgQ29tbWFuZAp2ZXJzaW9uOiAwLjAuMQp0eXBlOiBDb21tYW5kQ29tcG9uZW50CmlzX2RldGVybWluaXN0aWM6IHRydWUKdGFnczoge30KaW5wdXRzOgogIGlucHV0X2RpcjoKICAgIHR5cGU6IHBhdGgKICAgIG9wdGlvbmFsOiBmYWxzZQpvdXRwdXRzOiB7fQpjb21tYW5kOiA\u002BLQogIGxzIHtpbnB1dHMuaW5wdXRfZGlyfQplbnZpcm9ubWVudDoKICBuYW1lOiBBenVyZU1MLURlc2lnbmVyCg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "DgFLARKi0e4hqmZOmJSCJA==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F97771D8A\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "8BDO7s0uo8s=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/ae365exepool-component/component_spec.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "2941", - "Content-MD5": "glYxzHDJu53MSEh5A7PntQ==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0FFMzY1RXhlUG9vbENvbXBvbmVudC5qc29uCm5hbWU6IG1pY3Jvc29mdF9jb21fYXp1cmVtbF9zYW1wbGVzX2FlMzY1ZXhlcG9vbF9jYXhfZXllc19vbl9tb2R1bGUKdmVyc2lvbjogMC4wLjEKZGlzcGxheV9uYW1lOiBDQVggRXllc09uIE1vZHVsZSBbTkRdIHYxLjYKdHlwZTogQUUzNjVFeGVQb29sQ29tcG9uZW50CmRlc2NyaXB0aW9uOiBVc2UgdGhpcyBhdXRvLWFwcHJvdmVkIG1vZHVsZSB0byBkb3dubG9hZCBkYXRhIG9uIEV5ZXNPbiBtYWNoaW5lIGFuZCBpbnRlcmFjdCB3aXRoIGl0IGZvciBDb21wbGlhbnQgQW5ub3RhdGlvbiBwdXJwb3NlLgp0YWdzOiB7Y2F0ZWdvcnk6IENvbXBvbmVudCBUdXRvcmlhbCwgY29udGFjdDogYW1sZGVzaWduZXJAbWljcm9zb2Z0LmNvbX0KaW5wdXRzOgogIENvbXBsaWFuY2VDbHVzdGVyOgogICAgdHlwZTogc3RyaW5nCiAgICBkZXNjcmlwdGlvbjogY29tcGxpYW5jZSBjbHVzdGVyIG5hbWUKICAgIGRlZmF1bHQ6ICJNc1Jlc2VhcmNoLUV5ZXNPbi1Bbm5vdGF0aW9uIgogICAgb3B0aW9uYWw6IGZhbHNlCiAgSGVyb25JZDoKICAgIHR5cGU6IHN0cmluZwogICAgZGVzY3JpcHRpb246IEhlcm9uIElECiAgICBkZWZhdWx0OiAiIgogICAgb3B0aW9uYWw6IGZhbHNlCiAgbG9jYWxvdXRwdXRmb2xkZXJFbmM6CiAgICB0eXBlOiBzdHJpbmcKICAgIGRlc2NyaXB0aW9uOiBsb2NhbCBvdXRwdXQgZm9sZGVyIGZvciBlbmNyeXB0ZWQgZGF0YQogICAgZGVmYXVsdDogIiIKICAgIG9wdGlvbmFsOiB0cnVlCiAgbG9jYWxvdXRwdXRmb2xkZXJEZWM6CiAgICB0eXBlOiBzdHJpbmcKICAgIGRlc2NyaXB0aW9uOiBsb2NhbCBvdXRwdXQgZm9sZGVyIGZvciBkZWNyeXB0ZWQgZGF0YQogICAgZGVmYXVsdDogIiIKICAgIG9wdGlvbmFsOiB0cnVlCiAgVGltZW91dFNlY29uZHM6CiAgICB0eXBlOiBpbnRlZ2VyCiAgICBkZXNjcmlwdGlvbjogdGltZW91dCBpbiBzZWNvbmRzCiAgICBkZWZhdWx0OiA1MDAwMDAKICAgIG9wdGlvbmFsOiB0cnVlCiAgaGl0YXBwaWQ6CiAgICB0eXBlOiBpbnRlZ2VyCiAgICBkZXNjcmlwdGlvbjogaGl0YXBwIGlkCiAgICBkZWZhdWx0OiAzMTM0NgogICAgb3B0aW9uYWw6IHRydWUKICBwcm9qZWN0bmFtZToKICAgIHR5cGU6IHN0cmluZwogICAgZGVzY3JpcHRpb246IHByb2plY3QgbmFtZQogICAgZGVmYXVsdDogIkxhdGVzdEUyRXRlbXBsYXRlIgogICAgb3B0aW9uYWw6IHRydWUKICBqdWRnZXM6CiAgICB0eXBlOiBzdHJpbmcKICAgIGRlc2NyaXB0aW9uOiBqdWRnZXMKICAgIGRlZmF1bHQ6ICJqdXdhbmc7YnJhZHdhbGwiCiAgICBvcHRpb25hbDogdHJ1ZQogIGFubm90YXRpb25zTWF5SW5jbHVkZUN1c3RvbWVyQ29udGVudDoKICAgIHR5cGU6IHN0cmluZwogICAgZGVzY3JpcHRpb246IGFubm90YXRpb25zIG1heSBpbmNsdWRlIGN1c3RvbWVyIGNvbnRlbnQKICAgIGRlZmF1bHQ6ICIxIgogICAgb3B0aW9uYWw6IHRydWUKICBUYXNrR3JvdXBJZDoKICAgIHR5cGU6IGludGVnZXIKICAgIGRlc2NyaXB0aW9uOiB0YXNrIGdyb3VwIGlkCiAgICBkZWZhdWx0OiA4Njg5MQogICAgb3B0aW9uYWw6IHRydWUKICBHb2xkSGl0UlRBRGF0YVR5cGU6CiAgICB0eXBlOiBlbnVtCiAgICBkZXNjcmlwdGlvbjogZ29sZCBoaXQgcnRhIGRhdGEgdHlwZQogICAgZW51bToKICAgIC0gR29sZAogICAgLSBSVEEKICAgIC0gUXVhbGlmaWNhdGlvbgogICAgLSBQcmV2aWV3CiAgICBkZWZhdWx0OiAiIgogICAgb3B0aW9uYWw6IHRydWUKICB0YXNrRmlsZVRpbWVzdGFtcDoKICAgIHR5cGU6IHN0cmluZwogICAgZGVzY3JpcHRpb246IHRhc2sgZmlsZSB0aW1lc3RhbXAKICAgIGRlZmF1bHQ6ICIyMDIxLjEyLjIxLjIzLjU1LjAwIgogICAgb3B0aW9uYWw6IHRydWUKICBEYXRhVG9Mb29rQXQ6CiAgICB0eXBlOiBBbnlGaWxlCiAgICBvcHRpb25hbDogZmFsc2UKICBHb2xkSGl0UlRBRGF0YToKICAgIHR5cGU6IEFueUZpbGUKICAgIG9wdGlvbmFsOiB0cnVlCm91dHB1dHM6CiAgb3V0cHV0Zm9sZGVyRW5jOgogICAgdHlwZTogQW55RGlyZWN0b3J5CiAgb3V0cHV0Zm9sZGVyRGVjOgogICAgdHlwZTogQW55RGlyZWN0b3J5CiAgT3JpZ2luYWxIaXREYXRhOgogICAgdHlwZTogQW55RGlyZWN0b3J5CmNvbW1hbmQ6ID4tCiAgY2F4LmV5ZXNvbm1vZHVsZS5leGUgaW5wdXQ9e2lucHV0cy5EYXRhVG9Mb29rQXR9IGlucHV0R29sZEhpdFJ0YT1be2lucHV0cy5Hb2xkSGl0UlRBRGF0YX1dCiAgbG9jYWxvdXRwdXRmb2xkZXJFbmM9W3tpbnB1dHMubG9jYWxvdXRwdXRmb2xkZXJFbmN9XSBsb2NhbG91dHB1dGZvbGRlckRlYz1be2lucHV0cy5sb2NhbG91dHB1dGZvbGRlckRlY31dCiAgdGltZW91dFNlY29uZHM9W3tpbnB1dHMuVGltZW91dFNlY29uZHN9XSBoaXRhcHBpZD1be2lucHV0cy5oaXRhcHBpZH1dIHByb2plY3RuYW1lPVt7aW5wdXRzLnByb2plY3RuYW1lfV0KICBqdWRnZXM9W3tpbnB1dHMuanVkZ2VzfV0gb3V0cHV0Zm9sZGVyRW5jPXtvdXRwdXRzLm91dHB1dGZvbGRlckVuY30gb3V0cHV0Zm9sZGVyRGVjPXtvdXRwdXRzLm91dHB1dGZvbGRlckRlY30KICBhbm5vdGF0aW9uc01heUluY2x1ZGVDdXN0b21lckNvbnRlbnQ9W3tpbnB1dHMuYW5ub3RhdGlvbnNNYXlJbmNsdWRlQ3VzdG9tZXJDb250ZW50fV0gdGFza0dyb3VwSWQ9W3tpbnB1dHMuVGFza0dyb3VwSWR9XQogIGdvbGRIaXRSVEFEYXRhVHlwZT1be2lucHV0cy5Hb2xkSGl0UlRBRGF0YVR5cGV9XSBvdXRwdXRmb2xkZXJGb3JPcmlnaW5hbEhpdERhdGE9e291dHB1dHMuT3JpZ2luYWxIaXREYXRhfQogIHRhc2tGaWxlVGltZXN0YW1wPVt7aW5wdXRzLnRhc2tGaWxlVGltZXN0YW1wfV0KYWUzNjVleGVwb29sOgogIHJlZl9pZDogNjU0ZWMwYmEtYmVkMy00OGViLWE1OTQtZWZkMGU5Mjc1ZTBkCg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "glYxzHDJu53MSEh5A7PntQ==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F977792AC\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "PSGww3AgTww=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/batch_inference/batch_score.loaded_from_rest.json", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1787", - "Content-MD5": "dKES9DvWXOVKclNtcajnZw==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "ewogICJkZXNjcmlwdGlvbiI6ICJTY29yZSBpbWFnZXMgd2l0aCBNTklTVCBpbWFnZSBjbGFzc2lmaWNhdGlvbiBtb2RlbC4iLAogICJ0YWdzIjogewogICAgIlBhcmFsbGVsIjogIiIsCiAgICAiU2FtcGxlIjogIiIsCiAgICAiY29udGFjdCI6ICJNaWNyb3NvZnQgQ29ycG9yYXRpb24gPHh4eEBtaWNyb3NvZnQuY29tPiIsCiAgICAiaGVscERvY3VtZW50IjogImh0dHBzOi8vYWthLm1zL3BhcmFsbGVsLW1vZHVsZXMiCiAgfSwKICAidmVyc2lvbiI6ICIwLjAuMSIsCiAgIiRzY2hlbWEiOiAiaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL1BhcmFsbGVsQ29tcG9uZW50Lmpzb24iLAogICJkaXNwbGF5X25hbWUiOiAiUGFyYWxsZWwgU2NvcmUgSW1hZ2UgQ2xhc3NpZmljYXRpb24gd2l0aCBNTklTVCIsCiAgImlzX2RldGVybWluaXN0aWMiOiB0cnVlLAogICJpbnB1dHMiOiB7CiAgICAibW9kZWxfcGF0aCI6IHsKICAgICAgInR5cGUiOiAicGF0aCIsCiAgICAgICJkZXNjcmlwdGlvbiI6ICJUcmFpbmVkIE1OSVNUIGltYWdlIGNsYXNzaWZpY2F0aW9uIG1vZGVsLiIsCiAgICAgICJkYXRhc3RvcmVfbW9kZSI6ICJNb3VudCIKICAgIH0sCiAgICAiaW1hZ2VzX3RvX3Njb3JlIjogewogICAgICAidHlwZSI6ICJwYXRoIiwKICAgICAgImRlc2NyaXB0aW9uIjogIkltYWdlcyB0byBzY29yZS4iLAogICAgICAiZGF0YXN0b3JlX21vZGUiOiAiTW91bnQiCiAgICB9CiAgfSwKICAib3V0cHV0cyI6IHsKICAgICJzY29yZWRfZGF0YXNldCI6IHsKICAgICAgInR5cGUiOiAicGF0aCIsCiAgICAgICJkZXNjcmlwdGlvbiI6ICJPdXRwdXQgZm9sZGVyIHRvIHNhdmUgc2NvcmVkIHJlc3VsdC4iLAogICAgICAiZGF0YXN0b3JlX21vZGUiOiAiVXBsb2FkIgogICAgfQogIH0sCiAgInR5cGUiOiAiUGFyYWxsZWxDb21wb25lbnQiLAogICJlbnZpcm9ubWVudCI6IHsKICAgICJkb2NrZXIiOiB7CiAgICAgICJpbWFnZSI6ICJtY3IubWljcm9zb2Z0LmNvbS9henVyZW1sL29wZW5tcGkzLjEuMi1jdWRhMTAuMS1jdWRubjctdWJ1bnR1MTguMDQiCiAgICB9LAogICAgImNvbmRhIjogewogICAgICAiY29uZGFfZGVwZW5kZW5jaWVzIjogewogICAgICAgICJjaGFubmVscyI6IFsKICAgICAgICAgICJkZWZhdWx0cyIKICAgICAgICBdLAogICAgICAgICJkZXBlbmRlbmNpZXMiOiBbCiAgICAgICAgICAicHl0aG9uPTMuNy45IiwKICAgICAgICAgICJwaXA9MjAuMCIsCiAgICAgICAgICB7CiAgICAgICAgICAgICJwaXAiOiBbCiAgICAgICAgICAgICAgInByb3RvYnVmPT0zLjIwLjEiLAogICAgICAgICAgICAgICJ0ZW5zb3JmbG93PT0xLjE1LjIiLAogICAgICAgICAgICAgICJwaWxsb3ciLAogICAgICAgICAgICAgICJhenVyZW1sLWNvcmUiLAogICAgICAgICAgICAgICJhenVyZW1sLWRhdGFzZXQtcnVudGltZVtmdXNlLCBwYW5kYXNdIgogICAgICAgICAgICBdCiAgICAgICAgICB9CiAgICAgICAgXSwKICAgICAgICAibmFtZSI6ICJiYXRjaF9lbnZpcm9ubWVudCIKICAgICAgfQogICAgfSwKICAgICJvcyI6ICJMaW51eCIKICB9LAogICJwYXJhbGxlbCI6IHsKICAgICJhcmdzIjogIi0tbW9kZWxfcGF0aCB7aW5wdXRzLm1vZGVsX3BhdGh9IC0tc2NvcmVkX2RhdGFzZXQge291dHB1dHMuc2NvcmVkX2RhdGFzZXR9IiwKICAgICJpbnB1dF9kYXRhIjogImlucHV0cy5pbWFnZXNfdG9fc2NvcmUiLAogICAgIm91dHB1dF9kYXRhIjogIm91dHB1dHMuc2NvcmVkX2RhdGFzZXQiLAogICAgImVudHJ5IjogImJhdGNoX3Njb3JlLnB5IgogIH0KfQo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "dKES9DvWXOVKclNtcajnZw==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977792AC\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "Cg0uhr3L2RY=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/command-component/command-linux/one-line-tsv/component.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "484", - "Content-MD5": "Q0YxYUzE62GmIWAgIMzf\u002Bg==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbgpuYW1lOiBvbmVfbGluZV90c3YKZGlzcGxheV9uYW1lOiBHZW5lcmF0ZSBPbmUgTGluZSBUc3YKdmVyc2lvbjogMC4wLjEKdHlwZTogQ29tbWFuZENvbXBvbmVudAppc19kZXRlcm1pbmlzdGljOiB0cnVlCnRhZ3M6IHt9CmlucHV0czoKICBjb250ZW50OgogICAgdHlwZTogc3RyaW5nCiAgICBvcHRpb25hbDogZmFsc2UKICB0c3ZfZmlsZToKICAgIHR5cGU6IHN0cmluZwogICAgb3B0aW9uYWw6IGZhbHNlCiAgICBkZWZhdWx0OiBvdXRwdXQudHN2Cm91dHB1dHM6CiAgb3V0cHV0X2RpcjoKICAgIHR5cGU6IHBhdGgKY29tbWFuZDogPi0KICBlY2hvIHtpbnB1dHMuY29udGVudH0gPiB7b3V0cHV0cy5vdXRwdXRfZGlyfS97aW5wdXRzLnRzdl9maWxlfQplbnZpcm9ubWVudDoKICBuYW1lOiBBenVyZU1MLURlc2lnbmVyCg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "Q0YxYUzE62GmIWAgIMzf\u002Bg==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977792AC\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "Ga9IhQJH98o=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/batch_inference/batch_score.py", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1836", - "Content-MD5": "1Td5md4lWFQepFukuyU4bA==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "IyBDb3B5cmlnaHQgKGMpIE1pY3Jvc29mdC4gQWxsIHJpZ2h0cyByZXNlcnZlZC4KIyBMaWNlbnNlZCB1bmRlciB0aGUgTUlUIGxpY2Vuc2UuCgppbXBvcnQgYXJncGFyc2UKaW1wb3J0IG9zCmZyb20gdXVpZCBpbXBvcnQgdXVpZDQKCmltcG9ydCBudW1weSBhcyBucAppbXBvcnQgcGFuZGFzIGFzIHBkCmltcG9ydCB0ZW5zb3JmbG93IGFzIHRmCmZyb20gUElMIGltcG9ydCBJbWFnZQoKCmRlZiBpbml0KCk6CiAgICBnbG9iYWwgZ190Zl9zZXNzCiAgICBnbG9iYWwgb3V0cHV0X2ZvbGRlcgoKICAgICMgR2V0IG1vZGVsIGZyb20gdGhlIG1vZGVsIGRpcgogICAgcGFyc2VyID0gYXJncGFyc2UuQXJndW1lbnRQYXJzZXIoKQogICAgcGFyc2VyLmFkZF9hcmd1bWVudCgiLS1tb2RlbF9wYXRoIikKICAgIHBhcnNlci5hZGRfYXJndW1lbnQoIi0tc2NvcmVkX2RhdGFzZXQiKQogICAgYXJncywgXyA9IHBhcnNlci5wYXJzZV9rbm93bl9hcmdzKCkKICAgIG1vZGVsX3BhdGggPSBhcmdzLm1vZGVsX3BhdGgKICAgIG91dHB1dF9mb2xkZXIgPSBhcmdzLnNjb3JlZF9kYXRhc2V0CgogICAgIyBjb250cnVjdCBncmFwaCB0byBleGVjdXRlCiAgICB0Zi5yZXNldF9kZWZhdWx0X2dyYXBoKCkKICAgIHNhdmVyID0gdGYudHJhaW4uaW1wb3J0X21ldGFfZ3JhcGgob3MucGF0aC5qb2luKG1vZGVsX3BhdGgsICJtbmlzdC10Zi5tb2RlbC5tZXRhIikpCiAgICBnX3RmX3Nlc3MgPSB0Zi5TZXNzaW9uKGNvbmZpZz10Zi5Db25maWdQcm90byhkZXZpY2VfY291bnQ9eyJHUFUiOiAwfSkpCiAgICBzYXZlci5yZXN0b3JlKGdfdGZfc2Vzcywgb3MucGF0aC5qb2luKG1vZGVsX3BhdGgsICJtbmlzdC10Zi5tb2RlbCIpKQoKCmRlZiBydW4obWluaV9iYXRjaCk6CiAgICBwcmludChmInJ1biBtZXRob2Qgc3RhcnQ6IHtfX2ZpbGVfX30sIHJ1bih7bWluaV9iYXRjaH0pIikKICAgIGluX3RlbnNvciA9IGdfdGZfc2Vzcy5ncmFwaC5nZXRfdGVuc29yX2J5X25hbWUoIm5ldHdvcmsvWDowIikKICAgIG91dHB1dCA9IGdfdGZfc2Vzcy5ncmFwaC5nZXRfdGVuc29yX2J5X25hbWUoIm5ldHdvcmsvb3V0cHV0L01hdE11bDowIikKICAgIHJlc3VsdHMgPSBbXQoKICAgIGZvciBpbWFnZSBpbiBtaW5pX2JhdGNoOgogICAgICAgICMgcHJlcGFyZSBlYWNoIGltYWdlCiAgICAgICAgZGF0YSA9IEltYWdlLm9wZW4oaW1hZ2UpCiAgICAgICAgbnBfaW0gPSBucC5hcnJheShkYXRhKS5yZXNoYXBlKCgxLCA3ODQpKQogICAgICAgICMgcGVyZm9ybSBpbmZlcmVuY2UKICAgICAgICBpbmZlcmVuY2VfcmVzdWx0ID0gb3V0cHV0LmV2YWwoZmVlZF9kaWN0PXtpbl90ZW5zb3I6IG5wX2ltfSwgc2Vzc2lvbj1nX3RmX3Nlc3MpCiAgICAgICAgIyBmaW5kIGJlc3QgcHJvYmFiaWxpdHksIGFuZCBhZGQgdG8gcmVzdWx0IGxpc3QKICAgICAgICBiZXN0X3Jlc3VsdCA9IG5wLmFyZ21heChpbmZlcmVuY2VfcmVzdWx0KQogICAgICAgIHJlc3VsdHMuYXBwZW5kKFtvcy5wYXRoLmJhc2VuYW1lKGltYWdlKSwgYmVzdF9yZXN1bHRdKQogICAgIyBXcml0ZSB0aGUgZGF0YWZyYW1lIHRvIHBhcnF1ZXQgZmlsZSBpbiB0aGUgb3V0cHV0IGZvbGRlci4KICAgIHJlc3VsdF9kZiA9IHBkLkRhdGFGcmFtZShyZXN1bHRzLCBjb2x1bW5zPVsiRmlsZW5hbWUiLCAiQ2xhc3MiXSkKICAgIHByaW50KCJSZXN1bHQ6IikKICAgIHByaW50KHJlc3VsdF9kZikKICAgIG91dHB1dF9maWxlID0gb3MucGF0aC5qb2luKG91dHB1dF9mb2xkZXIsIGYie3V1aWQ0KCkuaGV4fS5wYXJxdWV0IikKICAgIHJlc3VsdF9kZi50b19wYXJxdWV0KG91dHB1dF9maWxlLCBpbmRleD1GYWxzZSkKICAgIHJldHVybiByZXN1bHRfZGYK", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "1Td5md4lWFQepFukuyU4bA==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977807C3\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "hZgvymvOwcw=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/batch_inference/batch_score.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1460", - "Content-MD5": "3lgCEV9dNFWREK8QoJsArA==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "IyBDb3B5cmlnaHQgKGMpIE1pY3Jvc29mdCBDb3Jwb3JhdGlvbi4KIyBMaWNlbnNlZCB1bmRlciB0aGUgTUlUIExpY2Vuc2UuCiRzY2hlbWE6IGh0dHBzOi8vY29tcG9uZW50c2RrLmF6dXJlZWRnZS5uZXQvanNvbnNjaGVtYS9QYXJhbGxlbENvbXBvbmVudC5qc29uCm5hbWU6IG1pY3Jvc29mdC5jb20uYXp1cmVtbC5zYW1wbGVzLnBhcmFsbGVsX3Njb3JlX2ltYWdlCnZlcnNpb246IDAuMC4xCmRpc3BsYXlfbmFtZTogUGFyYWxsZWwgU2NvcmUgSW1hZ2UgQ2xhc3NpZmljYXRpb24gd2l0aCBNTklTVAp0eXBlOiBQYXJhbGxlbENvbXBvbmVudApkZXNjcmlwdGlvbjogU2NvcmUgaW1hZ2VzIHdpdGggTU5JU1QgaW1hZ2UgY2xhc3NpZmljYXRpb24gbW9kZWwuCnRhZ3M6CiAgUGFyYWxsZWw6ICcnCiAgU2FtcGxlOiAnJwogIGNvbnRhY3Q6IE1pY3Jvc29mdCBDb3Jwb3JhdGlvbiA8eHh4QG1pY3Jvc29mdC5jb20\u002BCiAgaGVscERvY3VtZW50OiBodHRwczovL2FrYS5tcy9wYXJhbGxlbC1tb2R1bGVzCmlucHV0czoKICBtb2RlbF9wYXRoOgogICAgdHlwZTogcGF0aAogICAgZGVzY3JpcHRpb246IFRyYWluZWQgTU5JU1QgaW1hZ2UgY2xhc3NpZmljYXRpb24gbW9kZWwuCiAgICBvcHRpb25hbDogZmFsc2UKICBpbWFnZXNfdG9fc2NvcmU6CiAgICB0eXBlOiBwYXRoCiAgICBkZXNjcmlwdGlvbjogSW1hZ2VzIHRvIHNjb3JlLgogICAgb3B0aW9uYWw6IGZhbHNlCm91dHB1dHM6CiAgc2NvcmVkX2RhdGFzZXQ6CiAgICB0eXBlOiBwYXRoCiAgICBkZXNjcmlwdGlvbjogT3V0cHV0IGZvbGRlciB0byBzYXZlIHNjb3JlZCByZXN1bHQuCmVudmlyb25tZW50OgogIGRvY2tlcjoKICAgIGltYWdlOiBtY3IubWljcm9zb2Z0LmNvbS9henVyZW1sL29wZW5tcGkzLjEuMi1jdWRhMTAuMS1jdWRubjctdWJ1bnR1MTguMDQKICBjb25kYToKICAgIGNvbmRhX2RlcGVuZGVuY2llczoKICAgICAgY2hhbm5lbHM6CiAgICAgICAgLSBkZWZhdWx0cwogICAgICBkZXBlbmRlbmNpZXM6CiAgICAgICAgLSBweXRob249My43LjkKICAgICAgICAtIHBpcD0yMC4wCiAgICAgICAgLSBwaXA6CiAgICAgICAgICAgIC0gcHJvdG9idWY9PTMuMjAuMQogICAgICAgICAgICAtIHRlbnNvcmZsb3c9PTEuMTUuMgogICAgICAgICAgICAtIHBpbGxvdwogICAgICAgICAgICAtIGF6dXJlbWwtY29yZQogICAgICAgICAgICAtIGF6dXJlbWwtZGF0YXNldC1ydW50aW1lW2Z1c2UsIHBhbmRhc10KICAgICAgbmFtZTogYmF0Y2hfZW52aXJvbm1lbnQKICBvczogTGludXgKCnBhcmFsbGVsOgogIGlucHV0X2RhdGE6IGlucHV0cy5pbWFnZXNfdG9fc2NvcmUKICBvdXRwdXRfZGF0YTogb3V0cHV0cy5zY29yZWRfZGF0YXNldAogIGVudHJ5OiBiYXRjaF9zY29yZS5weQogIGFyZ3M6ID4tCiAgICAtLW1vZGVsX3BhdGgge2lucHV0cy5tb2RlbF9wYXRofSAtLXNjb3JlZF9kYXRhc2V0IHtvdXRwdXRzLnNjb3JlZF9kYXRhc2V0fQo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "3lgCEV9dNFWREK8QoJsArA==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F97782ED5\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "ZcPu/cEe8Xo=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/command-component/command-linux/copy/component.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "453", - "Content-MD5": "Jqdc5leOuyfw0porsP/Kzg==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbgpuYW1lOiBjb3B5X2NvbW1hbmQKZGlzcGxheV9uYW1lOiBDb3B5IENvbW1hbmQKdmVyc2lvbjogMC4wLjEKdHlwZTogQ29tbWFuZENvbXBvbmVudAppc19kZXRlcm1pbmlzdGljOiB0cnVlCnRhZ3M6IHt9CmlucHV0czoKICBpbnB1dF9kaXI6CiAgICB0eXBlOiBwYXRoCiAgICBvcHRpb25hbDogZmFsc2UKICBmaWxlX25hbWVzOgogICAgdHlwZTogc3RyaW5nCiAgICBvcHRpb25hbDogZmFsc2UKb3V0cHV0czoKICBvdXRwdXRfZGlyOgogICAgdHlwZTogcGF0aApjb21tYW5kOiA\u002BLQogIGNwIHtpbnB1dHMuaW5wdXRfZGlyfS97aW5wdXRzLmZpbGVfbmFtZXN9IHtvdXRwdXRzLm91dHB1dF9kaXJ9CmVudmlyb25tZW50OgogIG5hbWU6IEF6dXJlTUwtRGVzaWduZXIK", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "Jqdc5leOuyfw0porsP/Kzg==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F97796724\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "MjoZB2L66xU=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/component_with_additional_includes/helloworld_invalid_additional_includes_existing_file.additional_includes", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "87", - "Content-MD5": "UL37fUtoKjUoE67QScLpcQ==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "Li4vYWRkaXRpb25hbF9pbmNsdWRlcy9hc3NldHMvaGVsbG93b3JsZF9pbnZhbGlkX2FkZGl0aW9uYWxfaW5jbHVkZXNfZXhpc3RpbmdfZmlsZS55bWwK", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "UL37fUtoKjUoE67QScLpcQ==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F97796724\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "8nR7xb8w\u002Buk=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/component_with_additional_includes/helloworld_with_code.yml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1172", - "Content-MD5": "P7bDDgo7/7U7sxiKyJ/Wug==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbgpuYW1lOiBtaWNyb3NvZnQuY29tLmF6dXJlbWwuc2FtcGxlcy50cmFpbgp2ZXJzaW9uOiAwLjAuNApkaXNwbGF5X25hbWU6IFRyYWluCnR5cGU6IENvbW1hbmRDb21wb25lbnQKZGVzY3JpcHRpb246IEEgZHVtbXkgdHJhaW5pbmcgbW9kdWxlCnRhZ3M6IHtjYXRlZ29yeTogQ29tcG9uZW50IFR1dG9yaWFsLCBjb250YWN0OiBhbWxkZXNpZ25lckBtaWNyb3NvZnQuY29tfQppbnB1dHM6CiAgdHJhaW5pbmdfZGF0YToKICAgIHR5cGU6IHBhdGgKICAgIGRlc2NyaXB0aW9uOiBUcmFpbmluZyBkYXRhIG9yZ2FuaXplZCBpbiB0aGUgdG9yY2h2aXNpb24gZm9ybWF0L3N0cnVjdHVyZQogICAgb3B0aW9uYWw6IGZhbHNlCiAgbWF4X2Vwb2NoczoKICAgIHR5cGU6IGludGVnZXIKICAgIGRlc2NyaXB0aW9uOiBNYXhpbXVtIG51bWJlciBvZiBlcG9jaHMgZm9yIHRoZSB0cmFpbmluZwogICAgb3B0aW9uYWw6IGZhbHNlCiAgbGVhcm5pbmdfcmF0ZToKICAgIHR5cGU6IGZsb2F0CiAgICBkZXNjcmlwdGlvbjogTGVhcm5pbmcgcmF0ZSwgZGVmYXVsdCBpcyAwLjAxCiAgICBkZWZhdWx0OiAwLjAxCiAgICBvcHRpb25hbDogZmFsc2UKb3V0cHV0czoKICBtb2RlbF9vdXRwdXQ6CiAgICB0eXBlOiBwYXRoCiAgICBkZXNjcmlwdGlvbjogVGhlIG91dHB1dCBtb2RlbApjb2RlOiAuLi8KY29tbWFuZDogPi0KICBweXRob24gdHJhaW4ucHkgLS10cmFpbmluZ19kYXRhIHtpbnB1dHMudHJhaW5pbmdfZGF0YX0gLS1tYXhfZXBvY2hzIHtpbnB1dHMubWF4X2Vwb2Noc30KICAtLWxlYXJuaW5nX3JhdGUge2lucHV0cy5sZWFybmluZ19yYXRlfSAtLW1vZGVsX291dHB1dCB7b3V0cHV0cy5tb2RlbF9vdXRwdXR9CmVudmlyb25tZW50OgogIGNvbmRhOgogICAgY29uZGFfZGVwZW5kZW5jaWVzOgogICAgICBuYW1lOiBwcm9qZWN0X2Vudmlyb25tZW50CiAgICAgIGNoYW5uZWxzOgogICAgICAtIGRlZmF1bHRzCiAgICAgIGRlcGVuZGVuY2llczoKICAgICAgLSBweXRob249My42LjgKICAgICAgLSBwaXA9MjAuMAogICAgICAtIHBpcDoKICAgICAgICAtIGF6dXJlbWwtZGVmYXVsdHMKICAgICAgICAtIGF6dXJlbWwtZGF0YXByZXA\u002BPTEuNgogIG9zOiBMaW51eAo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "P7bDDgo7/7U7sxiKyJ/Wug==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977B3B9D\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "ZjWH6S5nkEA=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/component_with_additional_includes/helloworld_additional_includes.additional_includes", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "69", - "Content-MD5": "TbYm6KwzeyLOcP5qeE3STw==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "Li4vYWRkaXRpb25hbF9pbmNsdWRlcy9hc3NldHMvTElDRU5TRQouLi9hZGRpdGlvbmFsX2luY2x1ZGVzL2xpYnJhcnkK", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "TbYm6KwzeyLOcP5qeE3STw==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977B3B9D\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "P2h2i11jMos=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/component_with_additional_includes/helloworld_additional_includes.yml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1162", - "Content-MD5": "QgwPRSxpNPmXUMjY8WgfFg==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbgpuYW1lOiBtaWNyb3NvZnQuY29tLmF6dXJlbWwuc2FtcGxlcy50cmFpbgp2ZXJzaW9uOiAwLjAuNApkaXNwbGF5X25hbWU6IFRyYWluCnR5cGU6IENvbW1hbmRDb21wb25lbnQKZGVzY3JpcHRpb246IEEgZHVtbXkgdHJhaW5pbmcgbW9kdWxlCnRhZ3M6IHtjYXRlZ29yeTogQ29tcG9uZW50IFR1dG9yaWFsLCBjb250YWN0OiBhbWxkZXNpZ25lckBtaWNyb3NvZnQuY29tfQppbnB1dHM6CiAgdHJhaW5pbmdfZGF0YToKICAgIHR5cGU6IHBhdGgKICAgIGRlc2NyaXB0aW9uOiBUcmFpbmluZyBkYXRhIG9yZ2FuaXplZCBpbiB0aGUgdG9yY2h2aXNpb24gZm9ybWF0L3N0cnVjdHVyZQogICAgb3B0aW9uYWw6IGZhbHNlCiAgbWF4X2Vwb2NoczoKICAgIHR5cGU6IGludGVnZXIKICAgIGRlc2NyaXB0aW9uOiBNYXhpbXVtIG51bWJlciBvZiBlcG9jaHMgZm9yIHRoZSB0cmFpbmluZwogICAgb3B0aW9uYWw6IGZhbHNlCiAgbGVhcm5pbmdfcmF0ZToKICAgIHR5cGU6IGZsb2F0CiAgICBkZXNjcmlwdGlvbjogTGVhcm5pbmcgcmF0ZSwgZGVmYXVsdCBpcyAwLjAxCiAgICBkZWZhdWx0OiAwLjAxCiAgICBvcHRpb25hbDogZmFsc2UKb3V0cHV0czoKICBtb2RlbF9vdXRwdXQ6CiAgICB0eXBlOiBwYXRoCiAgICBkZXNjcmlwdGlvbjogVGhlIG91dHB1dCBtb2RlbApjb21tYW5kOiA\u002BLQogIHB5dGhvbiB0cmFpbi5weSAtLXRyYWluaW5nX2RhdGEge2lucHV0cy50cmFpbmluZ19kYXRhfSAtLW1heF9lcG9jaHMge2lucHV0cy5tYXhfZXBvY2hzfQogIC0tbGVhcm5pbmdfcmF0ZSB7aW5wdXRzLmxlYXJuaW5nX3JhdGV9IC0tbW9kZWxfb3V0cHV0IHtvdXRwdXRzLm1vZGVsX291dHB1dH0KZW52aXJvbm1lbnQ6CiAgY29uZGE6CiAgICBjb25kYV9kZXBlbmRlbmNpZXM6CiAgICAgIG5hbWU6IHByb2plY3RfZW52aXJvbm1lbnQKICAgICAgY2hhbm5lbHM6CiAgICAgIC0gZGVmYXVsdHMKICAgICAgZGVwZW5kZW5jaWVzOgogICAgICAtIHB5dGhvbj0zLjYuOAogICAgICAtIHBpcD0yMC4wCiAgICAgIC0gcGlwOgogICAgICAgIC0gYXp1cmVtbC1kZWZhdWx0cwogICAgICAgIC0gYXp1cmVtbC1kYXRhcHJlcD49MS42CiAgb3M6IExpbnV4Cg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "QgwPRSxpNPmXUMjY8WgfFg==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977B3B9D\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "dkGwVT13HAM=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/component_with_additional_includes/helloworld_invalid_additional_includes_existing_file.yml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1162", - "Content-MD5": "QgwPRSxpNPmXUMjY8WgfFg==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbgpuYW1lOiBtaWNyb3NvZnQuY29tLmF6dXJlbWwuc2FtcGxlcy50cmFpbgp2ZXJzaW9uOiAwLjAuNApkaXNwbGF5X25hbWU6IFRyYWluCnR5cGU6IENvbW1hbmRDb21wb25lbnQKZGVzY3JpcHRpb246IEEgZHVtbXkgdHJhaW5pbmcgbW9kdWxlCnRhZ3M6IHtjYXRlZ29yeTogQ29tcG9uZW50IFR1dG9yaWFsLCBjb250YWN0OiBhbWxkZXNpZ25lckBtaWNyb3NvZnQuY29tfQppbnB1dHM6CiAgdHJhaW5pbmdfZGF0YToKICAgIHR5cGU6IHBhdGgKICAgIGRlc2NyaXB0aW9uOiBUcmFpbmluZyBkYXRhIG9yZ2FuaXplZCBpbiB0aGUgdG9yY2h2aXNpb24gZm9ybWF0L3N0cnVjdHVyZQogICAgb3B0aW9uYWw6IGZhbHNlCiAgbWF4X2Vwb2NoczoKICAgIHR5cGU6IGludGVnZXIKICAgIGRlc2NyaXB0aW9uOiBNYXhpbXVtIG51bWJlciBvZiBlcG9jaHMgZm9yIHRoZSB0cmFpbmluZwogICAgb3B0aW9uYWw6IGZhbHNlCiAgbGVhcm5pbmdfcmF0ZToKICAgIHR5cGU6IGZsb2F0CiAgICBkZXNjcmlwdGlvbjogTGVhcm5pbmcgcmF0ZSwgZGVmYXVsdCBpcyAwLjAxCiAgICBkZWZhdWx0OiAwLjAxCiAgICBvcHRpb25hbDogZmFsc2UKb3V0cHV0czoKICBtb2RlbF9vdXRwdXQ6CiAgICB0eXBlOiBwYXRoCiAgICBkZXNjcmlwdGlvbjogVGhlIG91dHB1dCBtb2RlbApjb21tYW5kOiA\u002BLQogIHB5dGhvbiB0cmFpbi5weSAtLXRyYWluaW5nX2RhdGEge2lucHV0cy50cmFpbmluZ19kYXRhfSAtLW1heF9lcG9jaHMge2lucHV0cy5tYXhfZXBvY2hzfQogIC0tbGVhcm5pbmdfcmF0ZSB7aW5wdXRzLmxlYXJuaW5nX3JhdGV9IC0tbW9kZWxfb3V0cHV0IHtvdXRwdXRzLm1vZGVsX291dHB1dH0KZW52aXJvbm1lbnQ6CiAgY29uZGE6CiAgICBjb25kYV9kZXBlbmRlbmNpZXM6CiAgICAgIG5hbWU6IHByb2plY3RfZW52aXJvbm1lbnQKICAgICAgY2hhbm5lbHM6CiAgICAgIC0gZGVmYXVsdHMKICAgICAgZGVwZW5kZW5jaWVzOgogICAgICAtIHB5dGhvbj0zLjYuOAogICAgICAtIHBpcD0yMC4wCiAgICAgIC0gcGlwOgogICAgICAgIC0gYXp1cmVtbC1kZWZhdWx0cwogICAgICAgIC0gYXp1cmVtbC1kYXRhcHJlcD49MS42CiAgb3M6IExpbnV4Cg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "QgwPRSxpNPmXUMjY8WgfFg==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F977B89B2\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "dkGwVT13HAM=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/component_with_additional_includes/helloworld_with_code_and_additional_includes.additional_includes", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "38", - "Content-MD5": "n7JW4UKbXAdBkd9\u002B\u002BMwAeA==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "Li4vYWRkaXRpb25hbF9pbmNsdWRlcy9hc3NldHMvTElDRU5TRQo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "n7JW4UKbXAdBkd9\u002B\u002BMwAeA==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977B89B2\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "Qno4okjy/TA=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/component_with_additional_includes/helloworld_with_code_and_additional_includes.yml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1172", - "Content-MD5": "P7bDDgo7/7U7sxiKyJ/Wug==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbgpuYW1lOiBtaWNyb3NvZnQuY29tLmF6dXJlbWwuc2FtcGxlcy50cmFpbgp2ZXJzaW9uOiAwLjAuNApkaXNwbGF5X25hbWU6IFRyYWluCnR5cGU6IENvbW1hbmRDb21wb25lbnQKZGVzY3JpcHRpb246IEEgZHVtbXkgdHJhaW5pbmcgbW9kdWxlCnRhZ3M6IHtjYXRlZ29yeTogQ29tcG9uZW50IFR1dG9yaWFsLCBjb250YWN0OiBhbWxkZXNpZ25lckBtaWNyb3NvZnQuY29tfQppbnB1dHM6CiAgdHJhaW5pbmdfZGF0YToKICAgIHR5cGU6IHBhdGgKICAgIGRlc2NyaXB0aW9uOiBUcmFpbmluZyBkYXRhIG9yZ2FuaXplZCBpbiB0aGUgdG9yY2h2aXNpb24gZm9ybWF0L3N0cnVjdHVyZQogICAgb3B0aW9uYWw6IGZhbHNlCiAgbWF4X2Vwb2NoczoKICAgIHR5cGU6IGludGVnZXIKICAgIGRlc2NyaXB0aW9uOiBNYXhpbXVtIG51bWJlciBvZiBlcG9jaHMgZm9yIHRoZSB0cmFpbmluZwogICAgb3B0aW9uYWw6IGZhbHNlCiAgbGVhcm5pbmdfcmF0ZToKICAgIHR5cGU6IGZsb2F0CiAgICBkZXNjcmlwdGlvbjogTGVhcm5pbmcgcmF0ZSwgZGVmYXVsdCBpcyAwLjAxCiAgICBkZWZhdWx0OiAwLjAxCiAgICBvcHRpb25hbDogZmFsc2UKb3V0cHV0czoKICBtb2RlbF9vdXRwdXQ6CiAgICB0eXBlOiBwYXRoCiAgICBkZXNjcmlwdGlvbjogVGhlIG91dHB1dCBtb2RlbApjb2RlOiAuLi8KY29tbWFuZDogPi0KICBweXRob24gdHJhaW4ucHkgLS10cmFpbmluZ19kYXRhIHtpbnB1dHMudHJhaW5pbmdfZGF0YX0gLS1tYXhfZXBvY2hzIHtpbnB1dHMubWF4X2Vwb2Noc30KICAtLWxlYXJuaW5nX3JhdGUge2lucHV0cy5sZWFybmluZ19yYXRlfSAtLW1vZGVsX291dHB1dCB7b3V0cHV0cy5tb2RlbF9vdXRwdXR9CmVudmlyb25tZW50OgogIGNvbmRhOgogICAgY29uZGFfZGVwZW5kZW5jaWVzOgogICAgICBuYW1lOiBwcm9qZWN0X2Vudmlyb25tZW50CiAgICAgIGNoYW5uZWxzOgogICAgICAtIGRlZmF1bHRzCiAgICAgIGRlcGVuZGVuY2llczoKICAgICAgLSBweXRob249My42LjgKICAgICAgLSBwaXA9MjAuMAogICAgICAtIHBpcDoKICAgICAgICAtIGF6dXJlbWwtZGVmYXVsdHMKICAgICAgICAtIGF6dXJlbWwtZGF0YXByZXA\u002BPTEuNgogIG9zOiBMaW51eAo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "P7bDDgo7/7U7sxiKyJ/Wug==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977B89B2\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "ZjWH6S5nkEA=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/component_with_additional_includes/helloworld_without_code_and_additional_includes.yml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1162", - "Content-MD5": "QgwPRSxpNPmXUMjY8WgfFg==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbgpuYW1lOiBtaWNyb3NvZnQuY29tLmF6dXJlbWwuc2FtcGxlcy50cmFpbgp2ZXJzaW9uOiAwLjAuNApkaXNwbGF5X25hbWU6IFRyYWluCnR5cGU6IENvbW1hbmRDb21wb25lbnQKZGVzY3JpcHRpb246IEEgZHVtbXkgdHJhaW5pbmcgbW9kdWxlCnRhZ3M6IHtjYXRlZ29yeTogQ29tcG9uZW50IFR1dG9yaWFsLCBjb250YWN0OiBhbWxkZXNpZ25lckBtaWNyb3NvZnQuY29tfQppbnB1dHM6CiAgdHJhaW5pbmdfZGF0YToKICAgIHR5cGU6IHBhdGgKICAgIGRlc2NyaXB0aW9uOiBUcmFpbmluZyBkYXRhIG9yZ2FuaXplZCBpbiB0aGUgdG9yY2h2aXNpb24gZm9ybWF0L3N0cnVjdHVyZQogICAgb3B0aW9uYWw6IGZhbHNlCiAgbWF4X2Vwb2NoczoKICAgIHR5cGU6IGludGVnZXIKICAgIGRlc2NyaXB0aW9uOiBNYXhpbXVtIG51bWJlciBvZiBlcG9jaHMgZm9yIHRoZSB0cmFpbmluZwogICAgb3B0aW9uYWw6IGZhbHNlCiAgbGVhcm5pbmdfcmF0ZToKICAgIHR5cGU6IGZsb2F0CiAgICBkZXNjcmlwdGlvbjogTGVhcm5pbmcgcmF0ZSwgZGVmYXVsdCBpcyAwLjAxCiAgICBkZWZhdWx0OiAwLjAxCiAgICBvcHRpb25hbDogZmFsc2UKb3V0cHV0czoKICBtb2RlbF9vdXRwdXQ6CiAgICB0eXBlOiBwYXRoCiAgICBkZXNjcmlwdGlvbjogVGhlIG91dHB1dCBtb2RlbApjb21tYW5kOiA\u002BLQogIHB5dGhvbiB0cmFpbi5weSAtLXRyYWluaW5nX2RhdGEge2lucHV0cy50cmFpbmluZ19kYXRhfSAtLW1heF9lcG9jaHMge2lucHV0cy5tYXhfZXBvY2hzfQogIC0tbGVhcm5pbmdfcmF0ZSB7aW5wdXRzLmxlYXJuaW5nX3JhdGV9IC0tbW9kZWxfb3V0cHV0IHtvdXRwdXRzLm1vZGVsX291dHB1dH0KZW52aXJvbm1lbnQ6CiAgY29uZGE6CiAgICBjb25kYV9kZXBlbmRlbmNpZXM6CiAgICAgIG5hbWU6IHByb2plY3RfZW52aXJvbm1lbnQKICAgICAgY2hhbm5lbHM6CiAgICAgIC0gZGVmYXVsdHMKICAgICAgZGVwZW5kZW5jaWVzOgogICAgICAtIHB5dGhvbj0zLjYuOAogICAgICAtIHBpcD0yMC4wCiAgICAgIC0gcGlwOgogICAgICAgIC0gYXp1cmVtbC1kZWZhdWx0cwogICAgICAgIC0gYXp1cmVtbC1kYXRhcHJlcD49MS42CiAgb3M6IExpbnV4Cg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "QgwPRSxpNPmXUMjY8WgfFg==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977C25DA\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "dkGwVT13HAM=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/component_with_additional_includes/helloworld_invalid_additional_includes_root_directory.yml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1162", - "Content-MD5": "QgwPRSxpNPmXUMjY8WgfFg==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbgpuYW1lOiBtaWNyb3NvZnQuY29tLmF6dXJlbWwuc2FtcGxlcy50cmFpbgp2ZXJzaW9uOiAwLjAuNApkaXNwbGF5X25hbWU6IFRyYWluCnR5cGU6IENvbW1hbmRDb21wb25lbnQKZGVzY3JpcHRpb246IEEgZHVtbXkgdHJhaW5pbmcgbW9kdWxlCnRhZ3M6IHtjYXRlZ29yeTogQ29tcG9uZW50IFR1dG9yaWFsLCBjb250YWN0OiBhbWxkZXNpZ25lckBtaWNyb3NvZnQuY29tfQppbnB1dHM6CiAgdHJhaW5pbmdfZGF0YToKICAgIHR5cGU6IHBhdGgKICAgIGRlc2NyaXB0aW9uOiBUcmFpbmluZyBkYXRhIG9yZ2FuaXplZCBpbiB0aGUgdG9yY2h2aXNpb24gZm9ybWF0L3N0cnVjdHVyZQogICAgb3B0aW9uYWw6IGZhbHNlCiAgbWF4X2Vwb2NoczoKICAgIHR5cGU6IGludGVnZXIKICAgIGRlc2NyaXB0aW9uOiBNYXhpbXVtIG51bWJlciBvZiBlcG9jaHMgZm9yIHRoZSB0cmFpbmluZwogICAgb3B0aW9uYWw6IGZhbHNlCiAgbGVhcm5pbmdfcmF0ZToKICAgIHR5cGU6IGZsb2F0CiAgICBkZXNjcmlwdGlvbjogTGVhcm5pbmcgcmF0ZSwgZGVmYXVsdCBpcyAwLjAxCiAgICBkZWZhdWx0OiAwLjAxCiAgICBvcHRpb25hbDogZmFsc2UKb3V0cHV0czoKICBtb2RlbF9vdXRwdXQ6CiAgICB0eXBlOiBwYXRoCiAgICBkZXNjcmlwdGlvbjogVGhlIG91dHB1dCBtb2RlbApjb21tYW5kOiA\u002BLQogIHB5dGhvbiB0cmFpbi5weSAtLXRyYWluaW5nX2RhdGEge2lucHV0cy50cmFpbmluZ19kYXRhfSAtLW1heF9lcG9jaHMge2lucHV0cy5tYXhfZXBvY2hzfQogIC0tbGVhcm5pbmdfcmF0ZSB7aW5wdXRzLmxlYXJuaW5nX3JhdGV9IC0tbW9kZWxfb3V0cHV0IHtvdXRwdXRzLm1vZGVsX291dHB1dH0KZW52aXJvbm1lbnQ6CiAgY29uZGE6CiAgICBjb25kYV9kZXBlbmRlbmNpZXM6CiAgICAgIG5hbWU6IHByb2plY3RfZW52aXJvbm1lbnQKICAgICAgY2hhbm5lbHM6CiAgICAgIC0gZGVmYXVsdHMKICAgICAgZGVwZW5kZW5jaWVzOgogICAgICAtIHB5dGhvbj0zLjYuOAogICAgICAtIHBpcD0yMC4wCiAgICAgIC0gcGlwOgogICAgICAgIC0gYXp1cmVtbC1kZWZhdWx0cwogICAgICAgIC0gYXp1cmVtbC1kYXRhcHJlcD49MS42CiAgb3M6IExpbnV4Cg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "QgwPRSxpNPmXUMjY8WgfFg==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977C25DA\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "dkGwVT13HAM=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/data-transfer-component/component_spec.loaded_from_rest.json", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "638", - "Content-MD5": "gN6tPcyG/B2sWk16ipGOHg==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "ewogICJkZXNjcmlwdGlvbiI6ICJ0cmFuc2ZlciBkYXRhIGJldHdlZW4gY29tbW9uIHN0b3JhZ2UgdHlwZXMgc3VjaCBhcyBBenVyZSBCbG9iIFN0b3JhZ2UgYW5kIEF6dXJlIERhdGEgTGFrZS4iLAogICJ0YWdzIjogewogICAgImNhdGVnb3J5IjogIkNvbXBvbmVudCBUdXRvcmlhbCIsCiAgICAiY29udGFjdCI6ICJhbWxkZXNpZ25lckBtaWNyb3NvZnQuY29tIgogIH0sCiAgInZlcnNpb24iOiAiMC4wLjEiLAogICIkc2NoZW1hIjogImh0dHBzOi8vY29tcG9uZW50c2RrLmF6dXJlZWRnZS5uZXQvanNvbnNjaGVtYS9EYXRhVHJhbnNmZXJDb21wb25lbnQuanNvbiIsCiAgImRpc3BsYXlfbmFtZSI6ICJEYXRhIFRyYW5zZmVyIiwKICAiaXNfZGV0ZXJtaW5pc3RpYyI6IHRydWUsCiAgImlucHV0cyI6IHsKICAgICJzb3VyY2VfZGF0YSI6IHsKICAgICAgInR5cGUiOiAicGF0aCIsCiAgICAgICJkZXNjcmlwdGlvbiI6ICJTb3VyY2UgZGF0YSIKICAgIH0KICB9LAogICJvdXRwdXRzIjogewogICAgImRlc3RpbmF0aW9uX2RhdGEiOiB7CiAgICAgICJ0eXBlIjogInBhdGgiLAogICAgICAiZGVzY3JpcHRpb24iOiAiRGVzdGluYXRpb24gZGF0YSIKICAgIH0KICB9LAogICJ0eXBlIjogIkRhdGFUcmFuc2ZlckNvbXBvbmVudCIKfQo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "gN6tPcyG/B2sWk16ipGOHg==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977C73EE\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "TLXO155J3rk=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/component_with_input_types/component_spec_with_attrs.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1520", - "Content-MD5": "HLrNyORV0nYtUaYsKFH\u002BNg==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL1Njb3BlQ29tcG9uZW50Lmpzb24KCm5hbWU6IGJpbmdfcmVsZXZhbmNlX2NvbnZlcnQyc3MKdmVyc2lvbjogMC4wLjEKZGlzcGxheV9uYW1lOiBDb252ZXJ0IFRleHQgdG8gU3RydWN0dXJlU3RyZWFtCgp0eXBlOiBDb21tYW5kQ29tcG9uZW50Cgppc19kZXRlcm1pbmlzdGljOiBUcnVlCgp0YWdzOgogIG9yZzogYmluZwogIHByb2plY3Q6IHJlbGV2YW5jZQoKZGVzY3JpcHRpb246IENvbnZlcnQgQURMUyB0ZXN0IGRhdGEgdG8gU1MgZm9ybWF0CgppbnB1dHM6CiAgcGFyYW1fZGF0YV9wYXRoOgogICAgdHlwZTogcGF0aAogICAgZGVzY3JpcHRpb246IFBhdGggdG8gdGhlIGRhdGEKICAgIGlzX3Jlc291cmNlOiBUcnVlCiAgICBkYXRhc3RvcmVfbW9kZTogbW91bnQKICBwYXJhbV9zdHJpbmdfd2l0aF9kZWZhdWx0X3ZhbHVlOgogICAgdHlwZTogc3RyaW5nCiAgICBkZWZhdWx0OiAiLCIKICBwYXJhbV9zdHJpbmdfd2l0aF9kZWZhdWx0X3ZhbHVlXzI6CiAgICB0eXBlOiBzdHJpbmcKICAgIGRlZmF1bHQ6IHV0ZjgKICBwYXJhbV9zdHJpbmdfd2l0aF95ZXNfdmFsdWU6CiAgICB0eXBlOiBzdHJpbmcKICAgIGRlZmF1bHQ6IHllcwogIHBhcmFtX3N0cmluZ193aXRoX3F1b3RlX3llc192YWx1ZToKICAgIHR5cGU6IHN0cmluZwogICAgZGVmYXVsdDogInllcyIKICBwYXJhbV9pbnQ6CiAgICB0eXBlOiBpbnRlZ2VyCiAgcGFyYW1fZmxvYXQ6CiAgICB0eXBlOiBmbG9hdAogIHBhcmFtX2Jvb2w6CiAgICB0eXBlOiBib29sZWFuCiAgcGFyYW1fZW51bV93aXRoX2ludF92YWx1ZXM6CiAgICB0eXBlOiBlbnVtCiAgICBlbnVtOiBbMSwgMi4wLCAzLCA0XQogICAgZGVmYXVsdDogMwogIHBhcmFtX2VudW1fY2FwOgogICAgdHlwZTogRW51bQogICAgZW51bTogW21pbmltYWwsIHJldXNlLCBleHBpcnksIHBvbGljaWVzXQoKZW52aXJvbm1lbnQ6IGF6dXJlbWw6QXp1cmVFbnY6MQoKc2NvcGU6CiAgc2NyaXB0OiBjb252ZXJ0MnNzLnNjcmlwdAogICMgdG8gcmVmZXJlbmNlIHRoZSBpbnB1dHMvb3V0cHV0cyBpbiB5b3VyIHNjcmlwdAogICMgeW91IG11c3QgZGVmaW5lIHRoZSBhcmd1bWVudCBuYW1lIG9mIHlvdXIgaW50cHVzL291dHB1dHMgaW4gYXJncyBzZWN0aW9uCiAgIyBCb3RoICdhcmd1bWVudF9uYW1lIHtpbnB1dHMuaW5wdXRfbmFtZX0nIGFuZCAnYXJndW1lbnRfbmFtZT17aW5wdXRzLmlucHV0X25hbWV9JyBhcmUgc3VwcG9ydGVkCiAgIyBmb3IgZXhhbXBsZSwgaWYgeW91IGRlZmluZSB5b3VyIGFyZ3MgYXMgYmVsb3csIHlvdSBjYW4gdXNlIEBASW5wdXRfVGV4dERhdGFAQCB0byByZWZlciB0byB5b3VyIGNvbXBvbmVudCdzIGlucHV0IFRleHREYXRhCiAgYXJnczogPi0KICAgIElucHV0X1RleHREYXRhIHtpbnB1dHMuVGV4dERhdGF9CiAgICBFeHRyYWN0aW9uQ2xhdXNlPXtpbnB1dHMuRXh0cmFjdGlvbkNsYXVzZX0KICAgIE91dHB1dF9TU1BhdGgge291dHB1dHMuU1NQYXRofQo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "HLrNyORV0nYtUaYsKFH\u002BNg==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977C73EE\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "pScytFnkIMM=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/data-transfer-component/component_spec.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "518", - "Content-MD5": "JBtnixhxU\u002BxnV/HnnJtUug==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0RhdGFUcmFuc2ZlckNvbXBvbmVudC5qc29uCm5hbWU6IGRhdGFfdHJhbnNmZXIKdmVyc2lvbjogMC4wLjEKZGlzcGxheV9uYW1lOiBEYXRhIFRyYW5zZmVyCnR5cGU6IERhdGFUcmFuc2ZlckNvbXBvbmVudApkZXNjcmlwdGlvbjogdHJhbnNmZXIgZGF0YSBiZXR3ZWVuIGNvbW1vbiBzdG9yYWdlIHR5cGVzIHN1Y2ggYXMgQXp1cmUgQmxvYiBTdG9yYWdlIGFuZCBBenVyZSBEYXRhIExha2UuCnRhZ3M6IHtjYXRlZ29yeTogQ29tcG9uZW50IFR1dG9yaWFsLCBjb250YWN0OiBhbWxkZXNpZ25lckBtaWNyb3NvZnQuY29tfQppc19kZXRlcm1pbmlzdGljOiBUcnVlCmlucHV0czoKICBzb3VyY2VfZGF0YToKICAgIHR5cGU6IHBhdGgKICAgIGRlc2NyaXB0aW9uOiBTb3VyY2UgZGF0YQpvdXRwdXRzOgogIGRlc3RpbmF0aW9uX2RhdGE6CiAgICB0eXBlOiBwYXRoCiAgICBkZXNjcmlwdGlvbjogRGVzdGluYXRpb24gZGF0YQo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "JBtnixhxU\u002BxnV/HnnJtUug==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977C73EE\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "ozJjUAwJ6iw=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/component_with_input_types/component_spec.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "2636", - "Content-MD5": "jiLWKGxMGk\u002BBP/mrSbVcsg==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL1Njb3BlQ29tcG9uZW50Lmpzb24KCm5hbWU6IGJpbmdfcmVsZXZhbmNlX2NvbnZlcnQyc3MKdmVyc2lvbjogMC4wLjEKZGlzcGxheV9uYW1lOiBDb252ZXJ0IFRleHQgdG8gU3RydWN0dXJlU3RyZWFtCgp0eXBlOiBTY29wZUNvbXBvbmVudAoKaXNfZGV0ZXJtaW5pc3RpYzogVHJ1ZQoKdGFnczoKICBvcmc6IGJpbmcKICBwcm9qZWN0OiByZWxldmFuY2UKCmRlc2NyaXB0aW9uOiBDb252ZXJ0IEFETFMgdGVzdCBkYXRhIHRvIFNTIGZvcm1hdAoKaW5wdXRzOgogICMgZGF0YQogIGRhdGFfcGF0aDoKICAgIHR5cGU6IHBhdGgKICBkYXRhX2F6dXJlbWxfZGF0YXNldDoKICAgIHR5cGU6IEF6dXJlTUxEYXRhc2V0CiAgIyB1c2VkIGJ5IGJ1aWx0aW4gY29tcG9uZW50cwogIGRhdGFfYW55X2RpcmVjdG9yeToKICAgIHR5cGU6IEFueURpcmVjdG9yeQogIGRhdGFfYW55X2ZpbGU6CiAgICB0eXBlOiBBbnlGaWxlCiAgZGF0YV96aXBfZmlsZToKICAgIHR5cGU6IFppcEZpbGUKICBkYXRhX2Nzdl9maWxlOgogICAgdHlwZTogQ3N2RmlsZQogIGRhdGFfdHJhbnNmb3JtYXRpb25fZGlyZWN0b3J5OgogICAgdHlwZTogVHJhbnNmb3JtYXRpb25EaXJlY3RvcnkKICBkYXRhX3VudHJhaW5lZF9tb2RlbF9kaXJlY3Rvcnk6CiAgICB0eXBlOiBVbnRyYWluZWRNb2RlbERpcmVjdG9yeQogIGRhdGFfaW1hZ2VfZGlyZWN0b3J5OgogICAgdHlwZTogSW1hZ2VEaXJlY3RvcnkKICBkYXRhX21vZGVsX2RpcmVjdG9yeToKICAgIHR5cGU6IE1vZGVsRGlyZWN0b3J5CiAgZGF0YV9kYXRhX2ZyYW1lX2RpcmVjdG9yeToKICAgIHR5cGU6IERhdGFGcmFtZURpcmVjdG9yeQogICMgdXNlZCBieSBTY29wZSBjb21wb25lbnRzCiAgZGF0YV9jb3Ntb3Nfc3RydWN0dXJlZF9zdHJlYW06CiAgICB0eXBlOiBDb3Ntb3NTdHJ1Y3R1cmVkU3RyZWFtCgogICMgcGFyYW1ldGVycwogIHBhcmFtX3N0cmluZzoKICAgIHR5cGU6IHN0cmluZwogIHBhcmFtX3N0cmluZ19jYXA6CiAgICB0eXBlOiBTdHJpbmcKICBwYXJhbV9pbnQ6CiAgICB0eXBlOiBpbnRlZ2VyCiAgcGFyYW1faW50X2NhcDoKICAgIHR5cGU6IEludGVnZXIKICBwYXJhbV9mbG9hdDoKICAgIHR5cGU6IGZsb2F0CiAgcGFyYW1fZmxvYXRfY2FwOgogICAgdHlwZTogRmxvYXQKICBwYXJhbV9ib29sOgogICAgdHlwZTogYm9vbGVhbgogIHBhcmFtX2Jvb2xfY2FwOgogICAgdHlwZTogQm9vbGVhbgogIHBhcmFtX2VudW06CiAgICB0eXBlOiBlbnVtCiAgICBlbnVtOiBbbWluaW1hbCwgcmV1c2UsIGV4cGlyeSwgcG9saWNpZXNdCiAgcGFyYW1fZW51bV9jYXA6CiAgICB0eXBlOiBFbnVtCiAgICBlbnVtOiBbbWluaW1hbCwgcmV1c2UsIGV4cGlyeSwgcG9saWNpZXNdCgpvdXRwdXRzOgogICMgZGF0YQogIGRhdGFfcGF0aDoKICAgIHR5cGU6IHBhdGgKICBkYXRhX2F6dXJlbWxfZGF0YXNldDoKICAgIHR5cGU6IEF6dXJlTUxEYXRhc2V0CiAgIyB1c2VkIGJ5IGJ1aWx0aW4gY29tcG9uZW50cwogIGRhdGFfYW55X2RpcmVjdG9yeToKICAgIHR5cGU6IEFueURpcmVjdG9yeQogIGRhdGFfYW55X2ZpbGU6CiAgICB0eXBlOiBBbnlGaWxlCiAgZGF0YV96aXBfZmlsZToKICAgIHR5cGU6IFppcEZpbGUKICBkYXRhX2Nzdl9maWxlOgogICAgdHlwZTogQ3N2RmlsZQogIGRhdGFfdHJhbnNmb3JtYXRpb25fZGlyZWN0b3J5OgogICAgdHlwZTogVHJhbnNmb3JtYXRpb25EaXJlY3RvcnkKICBkYXRhX3VudHJhaW5lZF9tb2RlbF9kaXJlY3Rvcnk6CiAgICB0eXBlOiBVbnRyYWluZWRNb2RlbERpcmVjdG9yeQogIGRhdGFfaW1hZ2VfZGlyZWN0b3J5OgogICAgdHlwZTogSW1hZ2VEaXJlY3RvcnkKICBkYXRhX21vZGVsX2RpcmVjdG9yeToKICAgIHR5cGU6IE1vZGVsRGlyZWN0b3J5CiAgZGF0YV9kYXRhX2ZyYW1lX2RpcmVjdG9yeToKICAgIHR5cGU6IERhdGFGcmFtZURpcmVjdG9yeQogICMgdXNlZCBieSBTY29wZSBjb21wb25lbnRzCiAgZGF0YV9jb3Ntb3Nfc3RydWN0dXJlZF9zdHJlYW06CiAgICB0eXBlOiBDb3Ntb3NTdHJ1Y3R1cmVkU3RyZWFtCgpjb2RlOiAuLi9zY29wZQoKZW52aXJvbm1lbnQ6IGF6dXJlbWw6QXp1cmVFbnY6MQoKc2NvcGU6CiAgc2NyaXB0OiBjb252ZXJ0MnNzLnNjcmlwdAogICMgdG8gcmVmZXJlbmNlIHRoZSBpbnB1dHMvb3V0cHV0cyBpbiB5b3VyIHNjcmlwdAogICMgeW91IG11c3QgZGVmaW5lIHRoZSBhcmd1bWVudCBuYW1lIG9mIHlvdXIgaW50cHVzL291dHB1dHMgaW4gYXJncyBzZWN0aW9uCiAgIyBCb3RoICdhcmd1bWVudF9uYW1lIHtpbnB1dHMuaW5wdXRfbmFtZX0nIGFuZCAnYXJndW1lbnRfbmFtZT17aW5wdXRzLmlucHV0X25hbWV9JyBhcmUgc3VwcG9ydGVkCiAgIyBmb3IgZXhhbXBsZSwgaWYgeW91IGRlZmluZSB5b3VyIGFyZ3MgYXMgYmVsb3csIHlvdSBjYW4gdXNlIEBASW5wdXRfVGV4dERhdGFAQCB0byByZWZlciB0byB5b3VyIGNvbXBvbmVudCdzIGlucHV0IFRleHREYXRhCiAgYXJnczogPi0KICAgIElucHV0X1RleHREYXRhIHtpbnB1dHMuVGV4dERhdGF9CiAgICBFeHRyYWN0aW9uQ2xhdXNlPXtpbnB1dHMuRXh0cmFjdGlvbkNsYXVzZX0KICAgIE91dHB1dF9TU1BhdGgge291dHB1dHMuU1NQYXRofQo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "jiLWKGxMGk\u002BBP/mrSbVcsg==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977C9AFD\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "8j1roEbFT/s=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/component_with_additional_includes/helloworld_invalid_additional_includes_root_directory.additional_includes", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "2", - "Content-MD5": "pVgiQmpTMMBGJaQdJkwZCw==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "Lwo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "pVgiQmpTMMBGJaQdJkwZCw==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977CC200\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "NNdXgr9TxAU=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/distribution-component/component_spec.loaded_from_rest.json", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "957", - "Content-MD5": "kvzuq3W58kRQAkjYohUHcg==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "ewogICJ0YWdzIjoge30sCiAgInZlcnNpb24iOiAiMC4wLjEiLAogICIkc2NoZW1hIjogImh0dHBzOi8vY29tcG9uZW50c2RrLmF6dXJlZWRnZS5uZXQvanNvbnNjaGVtYS9EaXN0cmlidXRlZENvbXBvbmVudC5qc29uIiwKICAiZGlzcGxheV9uYW1lIjogIk1QSSBFeGFtcGxlIiwKICAiaXNfZGV0ZXJtaW5pc3RpYyI6IHRydWUsCiAgImlucHV0cyI6IHsKICAgICJpbnB1dF9wYXRoIjogewogICAgICAidHlwZSI6ICJwYXRoIiwKICAgICAgImRlc2NyaXB0aW9uIjogIlRoZSBkaXJlY3RvcnkgY29udGFpbnMgaW5wdXQgZGF0YS4iLAogICAgICAiZGF0YXN0b3JlX21vZGUiOiAiTW91bnQiCiAgICB9LAogICAgInN0cmluZ19wYXJhbWV0ZXIiOiB7CiAgICAgICJ0eXBlIjogInN0cmluZyIsCiAgICAgICJvcHRpb25hbCI6IHRydWUsCiAgICAgICJkZXNjcmlwdGlvbiI6ICJBIHBhcmFtZXRlciBhY2NlcHRzIGEgc3RyaW5nIHZhbHVlLiIKICAgIH0KICB9LAogICJvdXRwdXRzIjogewogICAgIm91dHB1dF9wYXRoIjogewogICAgICAidHlwZSI6ICJwYXRoIiwKICAgICAgImRlc2NyaXB0aW9uIjogIlRoZSBkaXJlY3RvcnkgY29udGFpbnMgb3V0cHV0IGRhdGEuIiwKICAgICAgImRhdGFzdG9yZV9tb2RlIjogIlVwbG9hZCIKICAgIH0KICB9LAogICJ0eXBlIjogIkRpc3RyaWJ1dGVkQ29tcG9uZW50IiwKICAiZW52aXJvbm1lbnQiOiB7CiAgICAib3MiOiAiTGludXgiLAogICAgIm5hbWUiOiAiQXp1cmVNTC1NaW5pbWFsIgogIH0sCiAgImxhdW5jaGVyIjogewogICAgInR5cGUiOiAibXBpIiwKICAgICJhZGRpdGlvbmFsX2FyZ3VtZW50cyI6ICJweXRob24gdHJhaW4ucHkgLS1pbnB1dC1wYXRoIHtpbnB1dHMuaW5wdXRfcGF0aH0gWy0tc3RyaW5nLXBhcmFtZXRlciB7aW5wdXRzLnN0cmluZ19wYXJhbWV0ZXJ9XSAtLW91dHB1dC1wYXRoIHtvdXRwdXRzLm91dHB1dF9wYXRofSIKICB9Cn0K", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "kvzuq3W58kRQAkjYohUHcg==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977CE90A\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "2vS/y3PDt3c=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/env-pip-dependencies/component_spec.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "275", - "Content-MD5": "9\u002BDqqqOqv4/qBeaHPWMKGw==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbgpuYW1lOiBsc19jb21tYW5kCmRpc3BsYXlfbmFtZTogTHMgQ29tbWFuZAp2ZXJzaW9uOiAwLjAuMQp0eXBlOiBDb21tYW5kQ29tcG9uZW50CmlzX2RldGVybWluaXN0aWM6IHRydWUKY29tbWFuZDogPi0KICBscwplbnZpcm9ubWVudDoKICBjb25kYToKICAgIHBpcF9yZXF1aXJlbWVudHNfZmlsZTogcmVxdWlyZW1lbnRzLnR4dAogIG9zOiBMaW51eAo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "9\u002BDqqqOqv4/qBeaHPWMKGw==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977D101C\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "peeOPXjbSAw=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/distribution-component/component_spec.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "733", - "Content-MD5": "EFixpigOffQp\u002BkwkJx5gug==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0Rpc3RyaWJ1dGVkQ29tcG9uZW50Lmpzb24KbmFtZTogbWljcm9zb2Z0LmNvbS5henVyZW1sLnNhbXBsZXMubXBpX2V4YW1wbGUKdmVyc2lvbjogMC4wLjEKZGlzcGxheV9uYW1lOiBNUEkgRXhhbXBsZQp0eXBlOiBEaXN0cmlidXRlZENvbXBvbmVudAppbnB1dHM6CiAgaW5wdXRfcGF0aDoKICAgIHR5cGU6IHBhdGgKICAgIGRlc2NyaXB0aW9uOiBUaGUgZGlyZWN0b3J5IGNvbnRhaW5zIGlucHV0IGRhdGEuCiAgICBvcHRpb25hbDogZmFsc2UKICBzdHJpbmdfcGFyYW1ldGVyOgogICAgdHlwZTogU3RyaW5nCiAgICBkZXNjcmlwdGlvbjogQSBwYXJhbWV0ZXIgYWNjZXB0cyBhIHN0cmluZyB2YWx1ZS4KICAgIG9wdGlvbmFsOiB0cnVlCm91dHB1dHM6CiAgb3V0cHV0X3BhdGg6CiAgICB0eXBlOiBwYXRoCiAgICBkZXNjcmlwdGlvbjogVGhlIGRpcmVjdG9yeSBjb250YWlucyBvdXRwdXQgZGF0YS4KbGF1bmNoZXI6CiAgdHlwZTogbXBpCiAgYWRkaXRpb25hbF9hcmd1bWVudHM6ID4tCiAgICBweXRob24gdHJhaW4ucHkgLS1pbnB1dC1wYXRoIHtpbnB1dHMuaW5wdXRfcGF0aH0gWy0tc3RyaW5nLXBhcmFtZXRlciB7aW5wdXRzLnN0cmluZ19wYXJhbWV0ZXJ9XQogICAgLS1vdXRwdXQtcGF0aCB7b3V0cHV0cy5vdXRwdXRfcGF0aH0KZW52aXJvbm1lbnQ6CiAgbmFtZTogQXp1cmVNTC1NaW5pbWFsCg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "EFixpigOffQp\u002BkwkJx5gug==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F977D5E2C\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "u0cVoaJKrAs=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/env-conda-dependencies/conda.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "153", - "Content-MD5": "/cF2sNoPLnwKbFgCODMbng==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "bmFtZTogcHJvamVjdF9lbnZpcm9ubWVudApjaGFubmVsczoKICAtIGRlZmF1bHRzCmRlcGVuZGVuY2llczoKICAtIHB5dGhvbj0zLjcuOQogIC0gcGlwPTIwLjAKICAtIHBpcDoKICAgIC0gYXp1cmVtbC1kZWZhdWx0cwogICAgLSBhenVyZW1sLWRhdGFwcmVwPj0xLjYK", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "/cF2sNoPLnwKbFgCODMbng==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F977F0B9A\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "HcMZbC1eCLk=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/env-conda-dependencies/component_spec.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "271", - "Content-MD5": "ln6zQFsqkz8A9yl0XymFcA==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbgpuYW1lOiBsc19jb21tYW5kCmRpc3BsYXlfbmFtZTogTHMgQ29tbWFuZAp2ZXJzaW9uOiAwLjAuMQp0eXBlOiBDb21tYW5kQ29tcG9uZW50CmlzX2RldGVybWluaXN0aWM6IHRydWUKY29tbWFuZDogPi0KICBscwplbnZpcm9ubWVudDoKICBjb25kYToKICAgIGNvbmRhX2RlcGVuZGVuY2llc19maWxlOiBjb25kYS55YW1sCiAgb3M6IExpbnV4Cg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "ln6zQFsqkz8A9yl0XymFcA==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F977F32A3\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "Wv9LWteUK08=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/env-duplicate-dependencies/requirements.txt", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "26", - "Content-MD5": "RIVRbNF\u002B2LO5z09ZkpgUlA==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "YXp1cmVtbC1kZWZhdWx0cwpyc2E9PTQuNwo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "RIVRbNF\u002B2LO5z09ZkpgUlA==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F977F59B1\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "i8INGZjNE2o=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/env-dockerfile-build/component_spec.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "323", - "Content-MD5": "/dSN9fRLeaqkIEcAPTM7qQ==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbgpuYW1lOiBsc19jb21tYW5kCmRpc3BsYXlfbmFtZTogTHMgQ29tbWFuZAp2ZXJzaW9uOiAwLjAuMQp0eXBlOiBDb21tYW5kQ29tcG9uZW50CmlzX2RldGVybWluaXN0aWM6IHRydWUKY29tbWFuZDogPi0KICBscwplbnZpcm9ubWVudDoKICBkb2NrZXI6CiAgICBidWlsZDoKICAgICAgZG9ja2VyZmlsZTogZmlsZTpkb2NrZXJmaWxlCiAgcHl0aG9uOgogICAgdXNlcl9tYW5hZ2VkX2RlcGVuZGVuY2llczogdHJ1ZQogIG9zOiBMaW51eAo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "/dSN9fRLeaqkIEcAPTM7qQ==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F977F59B1\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "1AgUh00jPpg=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/env-dockerfile-build/dockerfile", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "68", - "Content-MD5": "pNOXXDra8TA6mXY8yryrMg==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "RlJPTSBtY3IubWljcm9zb2Z0LmNvbS9henVyZW1sL29wZW5tcGk0LjEuMC11YnVudHUyMC4wNDoyMDIyMDgxNS52MQo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "pNOXXDra8TA6mXY8yryrMg==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F977F59B1\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "0JbkQ28H5do=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/env-duplicate-dependencies/component_spec.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "546", - "Content-MD5": "cgsbbmqQQlBZSCjzErgQIQ==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbgpuYW1lOiBsc19jb21tYW5kCmRpc3BsYXlfbmFtZTogTHMgQ29tbWFuZAp2ZXJzaW9uOiAwLjAuMQp0eXBlOiBDb21tYW5kQ29tcG9uZW50CmlzX2RldGVybWluaXN0aWM6IHRydWUKY29tbWFuZDogPi0KICBscwplbnZpcm9ubWVudDoKICBjb25kYToKICAgIGNvbmRhX2RlcGVuZGVuY2llczoKICAgICAgbmFtZTogcHJvamVjdF9lbnZpcm9ubWVudAogICAgICBjaGFubmVsczoKICAgICAgICAtIGRlZmF1bHRzCiAgICAgIGRlcGVuZGVuY2llczoKICAgICAgICAtIHB5dGhvbj0zLjcuOQogICAgICAgIC0gcGlwPTIwLjAKICAgICAgICAtIHBpcDoKICAgICAgICAgIC0gYXp1cmVtbC1kZWZhdWx0cwogICAgICAgICAgLSBhenVyZW1sLWRhdGFwcmVwPj0xLjYKICAgIGNvbmRhX2RlcGVuZGVuY2llc19maWxlOiBjb25kYS55YW1sCiAgICBwaXBfcmVxdWlyZW1lbnRzX2ZpbGU6IHJlcXVpcmVtZW50cy50eHQKICBvczogTGludXgK", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "cgsbbmqQQlBZSCjzErgQIQ==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F97801CE3\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "7cdfj146cuM=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/env-invalid/pip_file_not_exist.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "275", - "Content-MD5": "9\u002BDqqqOqv4/qBeaHPWMKGw==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbgpuYW1lOiBsc19jb21tYW5kCmRpc3BsYXlfbmFtZTogTHMgQ29tbWFuZAp2ZXJzaW9uOiAwLjAuMQp0eXBlOiBDb21tYW5kQ29tcG9uZW50CmlzX2RldGVybWluaXN0aWM6IHRydWUKY29tbWFuZDogPi0KICBscwplbnZpcm9ubWVudDoKICBjb25kYToKICAgIHBpcF9yZXF1aXJlbWVudHNfZmlsZTogcmVxdWlyZW1lbnRzLnR4dAogIG9zOiBMaW51eAo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "9\u002BDqqqOqv4/qBeaHPWMKGw==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F9780E017\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "peeOPXjbSAw=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/env-pip-dependencies/requirements.txt", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "26", - "Content-MD5": "RIVRbNF\u002B2LO5z09ZkpgUlA==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "YXp1cmVtbC1kZWZhdWx0cwpyc2E9PTQuNwo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "RIVRbNF\u002B2LO5z09ZkpgUlA==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F978A2D84\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "i8INGZjNE2o=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/get_started_train_score_eval/eval.py", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "611", - "Content-MD5": "eV\u002BKJwCEsDK8WkW027x0OA==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "aW1wb3J0IGFyZ3BhcnNlCmZyb20gcGF0aGxpYiBpbXBvcnQgUGF0aAoKcGFyc2VyID0gYXJncGFyc2UuQXJndW1lbnRQYXJzZXIoInNjb3JlIikKcGFyc2VyLmFkZF9hcmd1bWVudCgiLS1zY29yaW5nX3Jlc3VsdCIsIHR5cGU9c3RyLCBoZWxwPSJQYXRoIG9mIHNjb3JpbmcgcmVzdWx0IikKcGFyc2VyLmFkZF9hcmd1bWVudCgiLS1ldmFsX291dHB1dCIsIHR5cGU9c3RyLCBoZWxwPSJQYXRoIG9mIG91dHB1dCBldmFsdWF0aW9uIHJlc3VsdCIpCgphcmdzID0gcGFyc2VyLnBhcnNlX2FyZ3MoKQoKbGluZXMgPSBbCiAgICBmIlNjb3JpbmcgcmVzdWx0IHBhdGg6IHthcmdzLnNjb3JpbmdfcmVzdWx0fSIsCiAgICBmIkV2YWx1YXRpb24gb3V0cHV0IHBhdGg6IHthcmdzLmV2YWxfb3V0cHV0fSIsCl0KCmZvciBsaW5lIGluIGxpbmVzOgogICAgcHJpbnQobGluZSkKCiMgRXZhbHVhdGUgdGhlIGluY29taW5nIHNjb3JpbmcgcmVzdWx0IGFuZCBvdXRwdXQgZXZhbHVhdGlvbiByZXN1bHQuCiMgSGVyZSBvbmx5IG91dHB1dCBhIGR1bW15IGZpbGUgZm9yIGRlbW8uCihQYXRoKGFyZ3MuZXZhbF9vdXRwdXQpIC8gImV2YWxfcmVzdWx0Iikud3JpdGVfdGV4dCgiZXZhbF9yZXN1bHQiKQo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "eV\u002BKJwCEsDK8WkW027x0OA==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F978A5490\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "7x09QDUHee4=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/env-duplicate-dependencies/conda.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "153", - "Content-MD5": "/cF2sNoPLnwKbFgCODMbng==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "bmFtZTogcHJvamVjdF9lbnZpcm9ubWVudApjaGFubmVsczoKICAtIGRlZmF1bHRzCmRlcGVuZGVuY2llczoKICAtIHB5dGhvbj0zLjcuOQogIC0gcGlwPTIwLjAKICAtIHBpcDoKICAgIC0gYXp1cmVtbC1kZWZhdWx0cwogICAgLSBhenVyZW1sLWRhdGFwcmVwPj0xLjYK", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "/cF2sNoPLnwKbFgCODMbng==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F978AC9AF\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "HcMZbC1eCLk=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/env-invalid/conda_file_not_exist.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "271", - "Content-MD5": "ln6zQFsqkz8A9yl0XymFcA==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbgpuYW1lOiBsc19jb21tYW5kCmRpc3BsYXlfbmFtZTogTHMgQ29tbWFuZAp2ZXJzaW9uOiAwLjAuMQp0eXBlOiBDb21tYW5kQ29tcG9uZW50CmlzX2RldGVybWluaXN0aWM6IHRydWUKY29tbWFuZDogPi0KICBscwplbnZpcm9ubWVudDoKICBjb25kYToKICAgIGNvbmRhX2RlcGVuZGVuY2llc19maWxlOiBjb25kYS55YW1sCiAgb3M6IExpbnV4Cg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "ln6zQFsqkz8A9yl0XymFcA==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F978AF0BB\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "Wv9LWteUK08=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/get_started_train_score_eval/eval.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1123", - "Content-MD5": "EjBDTdq\u002Bm\u002BSHYDO/ipJIqA==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "IyBDb3B5cmlnaHQgKGMpIE1pY3Jvc29mdCBDb3Jwb3JhdGlvbi4KIyBMaWNlbnNlZCB1bmRlciB0aGUgTUlUIExpY2Vuc2UuCgokc2NoZW1hOiBodHRwczovL2NvbXBvbmVudHNkay5henVyZWVkZ2UubmV0L2pzb25zY2hlbWEvQ29tbWFuZENvbXBvbmVudC5qc29uCm5hbWU6IHNhbXBsZXNfZXZhbHVhdGUKdmVyc2lvbjogMC4wLjUKZGlzcGxheV9uYW1lOiBFdmFsdWF0ZQp0eXBlOiBDb21tYW5kQ29tcG9uZW50CmRlc2NyaXB0aW9uOiBBIGR1bW15IGV2YWx1YXRlIG1vZHVsZQp0YWdzOiB7fQppbnB1dHM6CiAgc2NvcmluZ19yZXN1bHQ6CiAgICB0eXBlOiBwYXRoCiAgICBkZXNjcmlwdGlvbjogU2NvcmluZyByZXN1bHQgZmlsZSBpbiBUU1YgZm9ybWF0CiAgICBvcHRpb25hbDogZmFsc2UKb3V0cHV0czoKICBldmFsX291dHB1dDoKICAgIHR5cGU6IHBhdGgKICAgIGRlc2NyaXB0aW9uOiBFdmFsdWF0aW9uIHJlc3VsdApjb21tYW5kOiA\u002BLQogIHB5dGhvbiBldmFsLnB5IC0tc2NvcmluZ19yZXN1bHQge2lucHV0cy5zY29yaW5nX3Jlc3VsdH0gLS1ldmFsX291dHB1dCB7b3V0cHV0cy5ldmFsX291dHB1dH0KZW52aXJvbm1lbnQ6CiAgZG9ja2VyOgogICAgaW1hZ2U6IG1jci5taWNyb3NvZnQuY29tL2F6dXJlbWwvb3Blbm1waTMuMS4yLXVidW50dTE4LjA0OjIwMjIwNzE0LnYxCiAgY29uZGE6CiAgICBjb25kYV9kZXBlbmRlbmNpZXM6CiAgICAgIG5hbWU6IHByb2plY3RfZW52aXJvbm1lbnQKICAgICAgY2hhbm5lbHM6CiAgICAgIC0gY29uZGEtZm9yZ2UKICAgICAgZGVwZW5kZW5jaWVzOgogICAgICAtIHBpcD0yMC4yCiAgICAgIC0gcHl0aG9uPTMuNy45CiAgICAgIC0gc2Npa2l0LXN1cnByaXNlPTEuMC42CiAgICAgIC0gcGlwOgogICAgICAgIC0gd2FpdHJlc3M9PTIuMC4wCiAgICAgICAgLSBhenVyZW1sLWRlc2lnbmVyLWNsYXNzaWMtbW9kdWxlcz09MC4wLjE2MQogICAgICAgIC0gaHR0cHM6Ly9naXRodWIuY29tL2V4cGxvc2lvbi9zcGFjeS1tb2RlbHMvcmVsZWFzZXMvZG93bmxvYWQvZW5fY29yZV93ZWJfc20tMi4xLjAvZW5fY29yZV93ZWJfc20tMi4xLjAudGFyLmd6I2VnZz1lbl9jb3JlX3dlYl9zbQogICAgICAgIC0gc3BhY3k9PTIuMS43CiAgb3M6IExpbnV4Cg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "EjBDTdq\u002Bm\u002BSHYDO/ipJIqA==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F978B3ECC\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "Da4H5d7Svzg=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/get_started_train_score_eval/score.py", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "847", - "Content-MD5": "nVMr\u002BslVlPfj8LxwYPB0hg==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:02 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "aW1wb3J0IGFyZ3BhcnNlCmZyb20gcGF0aGxpYiBpbXBvcnQgUGF0aAoKcGFyc2VyID0gYXJncGFyc2UuQXJndW1lbnRQYXJzZXIoInNjb3JlIikKcGFyc2VyLmFkZF9hcmd1bWVudCgiLS1tb2RlbF9pbnB1dCIsIHR5cGU9c3RyLCBoZWxwPSJQYXRoIG9mIGlucHV0IG1vZGVsIikKcGFyc2VyLmFkZF9hcmd1bWVudCgiLS10ZXN0X2RhdGEiLCB0eXBlPXN0ciwgaGVscD0iUGF0aCB0byB0ZXN0IGRhdGEiKQpwYXJzZXIuYWRkX2FyZ3VtZW50KCItLXNjb3JlX291dHB1dCIsIHR5cGU9c3RyLCBoZWxwPSJQYXRoIG9mIHNjb3Jpbmcgb3V0cHV0IikKCmFyZ3MgPSBwYXJzZXIucGFyc2VfYXJncygpCgpsaW5lcyA9IFsKICAgIGYiTW9kZWwgcGF0aDoge2FyZ3MubW9kZWxfaW5wdXR9IiwKICAgIGYiVGVzdCBkYXRhIHBhdGg6IHthcmdzLnRlc3RfZGF0YX0iLAogICAgZiJTY29yaW5nIG91dHB1dCBwYXRoOiB7YXJncy5zY29yZV9vdXRwdXR9IiwKXQoKZm9yIGxpbmUgaW4gbGluZXM6CiAgICBwcmludChsaW5lKQoKIyBMb2FkIHRoZSBtb2RlbCBmcm9tIGlucHV0IHBvcnQKIyBIZXJlIG9ubHkgcHJpbnQgdGhlIG1vZGVsIGFzIHRleHQgc2luY2UgaXQgaXMgYSBkdW1teSBvbmUKbW9kZWwgPSAoUGF0aChhcmdzLm1vZGVsX2lucHV0KSAvICJtb2RlbCIpLnJlYWRfdGV4dCgpCnByaW50KCJNb2RlbDoiLCBtb2RlbCkKCiMgRG8gc2NvcmluZyB3aXRoIHRoZSBpbnB1dCBtb2RlbAojIEhlcmUgb25seSBwcmludCB0ZXh0IHRvIG91dHB1dCBmaWxlIGFzIGRlbW8KKFBhdGgoYXJncy5zY29yZV9vdXRwdXQpIC8gInNjb3JlIikud3JpdGVfdGV4dCgic2NvcmVkIHdpdGgge30iLmZvcm1hdChtb2RlbCkpCg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "nVMr\u002BslVlPfj8LxwYPB0hg==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F978B65D9\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "OtU0dLqfz64=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/get_started_train_score_eval/score.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1322", - "Content-MD5": "rUTeRvReJFIbpBgSuLO/zw==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "IyBDb3B5cmlnaHQgKGMpIE1pY3Jvc29mdCBDb3Jwb3JhdGlvbi4KIyBMaWNlbnNlZCB1bmRlciB0aGUgTUlUIExpY2Vuc2UuCgokc2NoZW1hOiBodHRwczovL2NvbXBvbmVudHNkay5henVyZWVkZ2UubmV0L2pzb25zY2hlbWEvQ29tbWFuZENvbXBvbmVudC5qc29uCm5hbWU6IHNhbXBsZXNfc2NvcmUKdmVyc2lvbjogMC4wLjQKZGlzcGxheV9uYW1lOiBTY29yZQp0eXBlOiBDb21tYW5kQ29tcG9uZW50CmRlc2NyaXB0aW9uOiBBIGR1bW15IHNjb3JpbmcgbW9kdWxlCnRhZ3M6CiAgY2F0ZWdvcnk6IENvbXBvbmVudCBUdXRvcmlhbAogIGNvbnRhY3Q6IGFtbGRlc2lnbmVyQG1pY3Jvc29mdC5jb20KaW5wdXRzOgogIG1vZGVsX2lucHV0OgogICAgdHlwZTogcGF0aAogICAgZGVzY3JpcHRpb246IFppcHBlZCBtb2RlbCBmaWxlCiAgICBvcHRpb25hbDogZmFsc2UKICB0ZXN0X2RhdGE6CiAgICB0eXBlOiBwYXRoCiAgICBkZXNjcmlwdGlvbjogVGVzdCBkYXRhIG9yZ2FuaXplZCBpbiB0aGUgdG9yY2h2aXNpb24gZm9ybWF0L3N0cnVjdHVyZQogICAgb3B0aW9uYWw6IGZhbHNlCm91dHB1dHM6CiAgc2NvcmVfb3V0cHV0OgogICAgdHlwZTogcGF0aAogICAgZGVzY3JpcHRpb246IFRoZSBzY29yaW5nIHJlc3VsdCBpbiBUU1YKY29tbWFuZDogPi0KICBweXRob24gc2NvcmUucHkgLS1tb2RlbF9pbnB1dCB7aW5wdXRzLm1vZGVsX2lucHV0fSAtLXRlc3RfZGF0YSB7aW5wdXRzLnRlc3RfZGF0YX0KICAtLXNjb3JlX291dHB1dCB7b3V0cHV0cy5zY29yZV9vdXRwdXR9CmVudmlyb25tZW50OgogIGRvY2tlcjoKICAgIGltYWdlOiBtY3IubWljcm9zb2Z0LmNvbS9henVyZW1sL29wZW5tcGkzLjEuMi11YnVudHUxOC4wNDoyMDIyMDcxNC52MQogIGNvbmRhOgogICAgY29uZGFfZGVwZW5kZW5jaWVzOgogICAgICBuYW1lOiBwcm9qZWN0X2Vudmlyb25tZW50CiAgICAgIGNoYW5uZWxzOgogICAgICAtIGNvbmRhLWZvcmdlCiAgICAgIGRlcGVuZGVuY2llczoKICAgICAgLSBwaXA9MjAuMgogICAgICAtIHB5dGhvbj0zLjcuOQogICAgICAtIHNjaWtpdC1zdXJwcmlzZT0xLjAuNgogICAgICAtIHBpcDoKICAgICAgICAtIHdhaXRyZXNzPT0yLjAuMAogICAgICAgIC0gYXp1cmVtbC1kZXNpZ25lci1jbGFzc2ljLW1vZHVsZXM9PTAuMC4xNjEKICAgICAgICAtIGh0dHBzOi8vZ2l0aHViLmNvbS9leHBsb3Npb24vc3BhY3ktbW9kZWxzL3JlbGVhc2VzL2Rvd25sb2FkL2VuX2NvcmVfd2ViX3NtLTIuMS4wL2VuX2NvcmVfd2ViX3NtLTIuMS4wLnRhci5neiNlZ2c9ZW5fY29yZV93ZWJfc20KICAgICAgICAtIHNwYWN5PT0yLjEuNwogIG9zOiBMaW51eAo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "rUTeRvReJFIbpBgSuLO/zw==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F978B65D9\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "aw4PlsVP4ZY=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/get_started_train_score_eval/train.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1511", - "Content-MD5": "lzq5IgZHfUMvbwndAothpQ==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "IyBDb3B5cmlnaHQgKGMpIE1pY3Jvc29mdCBDb3Jwb3JhdGlvbi4KIyBMaWNlbnNlZCB1bmRlciB0aGUgTUlUIExpY2Vuc2UuCgokc2NoZW1hOiBodHRwczovL2NvbXBvbmVudHNkay5henVyZWVkZ2UubmV0L2pzb25zY2hlbWEvQ29tbWFuZENvbXBvbmVudC5qc29uCm5hbWU6IHNhbXBsZXNfdHJhaW4KdmVyc2lvbjogMC4wLjUKZGlzcGxheV9uYW1lOiBUcmFpbgp0eXBlOiBDb21tYW5kQ29tcG9uZW50CmRlc2NyaXB0aW9uOiBBIGR1bW15IHRyYWluaW5nIG1vZHVsZQp0YWdzOiB7Y2F0ZWdvcnk6IENvbXBvbmVudCBUdXRvcmlhbCwgY29udGFjdDogYW1sZGVzaWduZXJAbWljcm9zb2Z0LmNvbX0KaW5wdXRzOgogIHRyYWluaW5nX2RhdGE6CiAgICB0eXBlOiBwYXRoCiAgICBkZXNjcmlwdGlvbjogVHJhaW5pbmcgZGF0YSBvcmdhbml6ZWQgaW4gdGhlIHRvcmNodmlzaW9uIGZvcm1hdC9zdHJ1Y3R1cmUKICAgIG9wdGlvbmFsOiBmYWxzZQogIG1heF9lcG9jaHM6CiAgICB0eXBlOiBpbnRlZ2VyCiAgICBkZXNjcmlwdGlvbjogTWF4aW11bSBudW1iZXIgb2YgZXBvY2hzIGZvciB0aGUgdHJhaW5pbmcKICAgIG9wdGlvbmFsOiBmYWxzZQogIGxlYXJuaW5nX3JhdGU6CiAgICB0eXBlOiBmbG9hdAogICAgZGVzY3JpcHRpb246IExlYXJuaW5nIHJhdGUsIGRlZmF1bHQgaXMgMC4wMQogICAgZGVmYXVsdDogMC4wMQogICAgb3B0aW9uYWw6IGZhbHNlCm91dHB1dHM6CiAgbW9kZWxfb3V0cHV0OgogICAgdHlwZTogcGF0aAogICAgZGVzY3JpcHRpb246IFRoZSBvdXRwdXQgbW9kZWwKY29tbWFuZDogPi0KICBweXRob24gdHJhaW4ucHkgLS10cmFpbmluZ19kYXRhIHtpbnB1dHMudHJhaW5pbmdfZGF0YX0gLS1tYXhfZXBvY2hzIHtpbnB1dHMubWF4X2Vwb2Noc30KICAtLWxlYXJuaW5nX3JhdGUge2lucHV0cy5sZWFybmluZ19yYXRlfSAtLW1vZGVsX291dHB1dCB7b3V0cHV0cy5tb2RlbF9vdXRwdXR9CmVudmlyb25tZW50OgogIGRvY2tlcjoKICAgIGltYWdlOiBtY3IubWljcm9zb2Z0LmNvbS9henVyZW1sL29wZW5tcGkzLjEuMi11YnVudHUxOC4wNDoyMDIyMDcxNC52MQogIGNvbmRhOgogICAgY29uZGFfZGVwZW5kZW5jaWVzOgogICAgICBuYW1lOiBwcm9qZWN0X2Vudmlyb25tZW50CiAgICAgIGNoYW5uZWxzOgogICAgICAtIGNvbmRhLWZvcmdlCiAgICAgIGRlcGVuZGVuY2llczoKICAgICAgLSBwaXA9MjAuMgogICAgICAtIHB5dGhvbj0zLjcuOQogICAgICAtIHNjaWtpdC1zdXJwcmlzZT0xLjAuNgogICAgICAtIHBpcDoKICAgICAgICAtIHdhaXRyZXNzPT0yLjAuMAogICAgICAgIC0gYXp1cmVtbC1kZXNpZ25lci1jbGFzc2ljLW1vZHVsZXM9PTAuMC4xNjEKICAgICAgICAtIGh0dHBzOi8vZ2l0aHViLmNvbS9leHBsb3Npb24vc3BhY3ktbW9kZWxzL3JlbGVhc2VzL2Rvd25sb2FkL2VuX2NvcmVfd2ViX3NtLTIuMS4wL2VuX2NvcmVfd2ViX3NtLTIuMS4wLnRhci5neiNlZ2c9ZW5fY29yZV93ZWJfc20KICAgICAgICAtIHNwYWN5PT0yLjEuNwogIG9zOiBMaW51eAo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "lzq5IgZHfUMvbwndAothpQ==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F97959D84\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "MgAv6TQymUo=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/hdi-component/component_spec.loaded_from_rest.json", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1072", - "Content-MD5": "\u002BqXzjz4TQb6ggc5d6Hu/lw==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "ewogICJkZXNjcmlwdGlvbiI6ICJUcmFpbiBhIFNwYXJrIE1MIG1vZGVsIHVzaW5nIGFuIEhESW5zaWdodCBTcGFyayBjbHVzdGVyIiwKICAidGFncyI6IHsKICAgICJIREluc2lnaHQiOiAiIiwKICAgICJTYW1wbGUiOiAiIiwKICAgICJjb250YWN0IjogIk1pY3Jvc29mdCBDb3BvcmF0aW9uIDx4eHhAbWljcm9zb2Z0LmNvbT4iLAogICAgImhlbHBEb2N1bWVudCI6ICJodHRwczovL2FrYS5tcy9oZGluc2lnaHQtbW9kdWxlcyIKICB9LAogICJ2ZXJzaW9uIjogIjAuMC4xIiwKICAiJHNjaGVtYSI6ICJodHRwczovL2NvbXBvbmVudHNkay5henVyZWVkZ2UubmV0L2pzb25zY2hlbWEvSERJbnNpZ2h0Q29tcG9uZW50Lmpzb24iLAogICJkaXNwbGF5X25hbWUiOiAiVHJhaW4gaW4gU3BhcmsiLAogICJpc19kZXRlcm1pbmlzdGljIjogdHJ1ZSwKICAiaW5wdXRzIjogewogICAgImlucHV0X3BhdGgiOiB7CiAgICAgICJ0eXBlIjogInBhdGgiLAogICAgICAiZGVzY3JpcHRpb24iOiAiSXJpcyBjc3YgZmlsZSIKICAgIH0sCiAgICAicmVndWxhcml6YXRpb25fcmF0ZSI6IHsKICAgICAgInR5cGUiOiAiRmxvYXQiLAogICAgICAiZGVzY3JpcHRpb24iOiAiUmVndWxhcml6YXRpb24gcmF0ZSB3aGVuIHRyYWluaW5nIHdpdGggbG9naXN0aWMgcmVncmVzc2lvbiIsCiAgICAgICJvcHRpb25hbCI6IHRydWUsCiAgICAgICJkZWZhdWx0IjogIjAuMDEiCiAgICB9CiAgfSwKICAib3V0cHV0cyI6IHsKICAgICJvdXRwdXRfcGF0aCI6IHsKICAgICAgInR5cGUiOiAicGF0aCIsCiAgICAgICJkZXNjcmlwdGlvbiI6ICJUaGUgb3V0cHV0IHBhdGggdG8gc2F2ZSB0aGUgdHJhaW5lZCBtb2RlbCB0byIKICAgIH0KICB9LAogICJ0eXBlIjogIkhESW5zaWdodENvbXBvbmVudCIsCiAgImhkaW5zaWdodCI6IHsKICAgICJhcmdzIjogIi0taW5wdXRfcGF0aCB7aW5wdXRzLmlucHV0X3BhdGh9IFstLXJlZ3VsYXJpemF0aW9uX3JhdGUge2lucHV0cy5yZWd1bGFyaXphdGlvbl9yYXRlfV0gLS1vdXRwdXRfcGF0aCB7b3V0cHV0cy5vdXRwdXRfcGF0aH0iLAogICAgImZpbGUiOiAidHJhaW4tc3BhcmsucHkiCiAgfQp9Cg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "\u002BqXzjz4TQb6ggc5d6Hu/lw==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F9796AECF\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "U2oaIwdDZcc=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/get_started_train_score_eval/train.py", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "872", - "Content-MD5": "MeDc\u002BsrqcpGOEbt2FeVt9g==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "aW1wb3J0IGFyZ3BhcnNlCmZyb20gcGF0aGxpYiBpbXBvcnQgUGF0aApmcm9tIHV1aWQgaW1wb3J0IHV1aWQ0CgpwYXJzZXIgPSBhcmdwYXJzZS5Bcmd1bWVudFBhcnNlcigidHJhaW4iKQpwYXJzZXIuYWRkX2FyZ3VtZW50KCItLXRyYWluaW5nX2RhdGEiLCB0eXBlPXN0ciwgaGVscD0iUGF0aCB0byB0cmFpbmluZyBkYXRhIikKcGFyc2VyLmFkZF9hcmd1bWVudCgiLS1tYXhfZXBvY2hzIiwgdHlwZT1pbnQsIGhlbHA9Ik1heCAjIG9mIGVwb2NocyBmb3IgdGhlIHRyYWluaW5nIikKcGFyc2VyLmFkZF9hcmd1bWVudCgiLS1sZWFybmluZ19yYXRlIiwgdHlwZT1mbG9hdCwgaGVscD0iTGVhcm5pbmcgcmF0ZSIpCnBhcnNlci5hZGRfYXJndW1lbnQoIi0tbW9kZWxfb3V0cHV0IiwgdHlwZT1zdHIsIGhlbHA9IlBhdGggb2Ygb3V0cHV0IG1vZGVsIikKCmFyZ3MgPSBwYXJzZXIucGFyc2VfYXJncygpCgpsaW5lcyA9IFsKICAgIGYiVHJhaW5pbmcgZGF0YSBwYXRoOiB7YXJncy50cmFpbmluZ19kYXRhfSIsCiAgICBmIk1heCBlcG9jaHM6IHthcmdzLm1heF9lcG9jaHN9IiwKICAgIGYiTGVhcm5pbmcgcmF0ZToge2FyZ3MubGVhcm5pbmdfcmF0ZX0iLAogICAgZiJNb2RlbCBvdXRwdXQgcGF0aDoge2FyZ3MubW9kZWxfb3V0cHV0fSIsCl0KCmZvciBsaW5lIGluIGxpbmVzOgogICAgcHJpbnQobGluZSkKCiMgRG8gdGhlIHRyYWluIGFuZCBzYXZlIHRoZSB0cmFpbmVkIG1vZGVsIGFzIGEgZmlsZSBpbnRvIHRoZSBvdXRwdXQgZm9sZGVyLgojIEhlcmUgb25seSBvdXRwdXQgYSBkdW1teSBkYXRhIGZvciBkZW1vLgptb2RlbCA9IHN0cih1dWlkNCgpKQooUGF0aChhcmdzLm1vZGVsX291dHB1dCkgLyAibW9kZWwiKS53cml0ZV90ZXh0KG1vZGVsKQo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "MeDc\u002BsrqcpGOEbt2FeVt9g==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F979353F8\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "RbMIv42fxpE=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/hdi-component/iris.csv", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "4550", - "Content-MD5": "LSWthyFPv8gaylzd0xFcUg==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "NS4xLDMuNSwxLjQsMC4yLElyaXMtc2V0b3NhCjQuOSwzLjAsMS40LDAuMixJcmlzLXNldG9zYQo0LjcsMy4yLDEuMywwLjIsSXJpcy1zZXRvc2EKNC42LDMuMSwxLjUsMC4yLElyaXMtc2V0b3NhCjUuMCwzLjYsMS40LDAuMixJcmlzLXNldG9zYQo1LjQsMy45LDEuNywwLjQsSXJpcy1zZXRvc2EKNC42LDMuNCwxLjQsMC4zLElyaXMtc2V0b3NhCjUuMCwzLjQsMS41LDAuMixJcmlzLXNldG9zYQo0LjQsMi45LDEuNCwwLjIsSXJpcy1zZXRvc2EKNC45LDMuMSwxLjUsMC4xLElyaXMtc2V0b3NhCjUuNCwzLjcsMS41LDAuMixJcmlzLXNldG9zYQo0LjgsMy40LDEuNiwwLjIsSXJpcy1zZXRvc2EKNC44LDMuMCwxLjQsMC4xLElyaXMtc2V0b3NhCjQuMywzLjAsMS4xLDAuMSxJcmlzLXNldG9zYQo1LjgsNC4wLDEuMiwwLjIsSXJpcy1zZXRvc2EKNS43LDQuNCwxLjUsMC40LElyaXMtc2V0b3NhCjUuNCwzLjksMS4zLDAuNCxJcmlzLXNldG9zYQo1LjEsMy41LDEuNCwwLjMsSXJpcy1zZXRvc2EKNS43LDMuOCwxLjcsMC4zLElyaXMtc2V0b3NhCjUuMSwzLjgsMS41LDAuMyxJcmlzLXNldG9zYQo1LjQsMy40LDEuNywwLjIsSXJpcy1zZXRvc2EKNS4xLDMuNywxLjUsMC40LElyaXMtc2V0b3NhCjQuNiwzLjYsMS4wLDAuMixJcmlzLXNldG9zYQo1LjEsMy4zLDEuNywwLjUsSXJpcy1zZXRvc2EKNC44LDMuNCwxLjksMC4yLElyaXMtc2V0b3NhCjUuMCwzLjAsMS42LDAuMixJcmlzLXNldG9zYQo1LjAsMy40LDEuNiwwLjQsSXJpcy1zZXRvc2EKNS4yLDMuNSwxLjUsMC4yLElyaXMtc2V0b3NhCjUuMiwzLjQsMS40LDAuMixJcmlzLXNldG9zYQo0LjcsMy4yLDEuNiwwLjIsSXJpcy1zZXRvc2EKNC44LDMuMSwxLjYsMC4yLElyaXMtc2V0b3NhCjUuNCwzLjQsMS41LDAuNCxJcmlzLXNldG9zYQo1LjIsNC4xLDEuNSwwLjEsSXJpcy1zZXRvc2EKNS41LDQuMiwxLjQsMC4yLElyaXMtc2V0b3NhCjQuOSwzLjEsMS41LDAuMSxJcmlzLXNldG9zYQo1LjAsMy4yLDEuMiwwLjIsSXJpcy1zZXRvc2EKNS41LDMuNSwxLjMsMC4yLElyaXMtc2V0b3NhCjQuOSwzLjEsMS41LDAuMSxJcmlzLXNldG9zYQo0LjQsMy4wLDEuMywwLjIsSXJpcy1zZXRvc2EKNS4xLDMuNCwxLjUsMC4yLElyaXMtc2V0b3NhCjUuMCwzLjUsMS4zLDAuMyxJcmlzLXNldG9zYQo0LjUsMi4zLDEuMywwLjMsSXJpcy1zZXRvc2EKNC40LDMuMiwxLjMsMC4yLElyaXMtc2V0b3NhCjUuMCwzLjUsMS42LDAuNixJcmlzLXNldG9zYQo1LjEsMy44LDEuOSwwLjQsSXJpcy1zZXRvc2EKNC44LDMuMCwxLjQsMC4zLElyaXMtc2V0b3NhCjUuMSwzLjgsMS42LDAuMixJcmlzLXNldG9zYQo0LjYsMy4yLDEuNCwwLjIsSXJpcy1zZXRvc2EKNS4zLDMuNywxLjUsMC4yLElyaXMtc2V0b3NhCjUuMCwzLjMsMS40LDAuMixJcmlzLXNldG9zYQo3LjAsMy4yLDQuNywxLjQsSXJpcy12ZXJzaWNvbG9yCjYuNCwzLjIsNC41LDEuNSxJcmlzLXZlcnNpY29sb3IKNi45LDMuMSw0LjksMS41LElyaXMtdmVyc2ljb2xvcgo1LjUsMi4zLDQuMCwxLjMsSXJpcy12ZXJzaWNvbG9yCjYuNSwyLjgsNC42LDEuNSxJcmlzLXZlcnNpY29sb3IKNS43LDIuOCw0LjUsMS4zLElyaXMtdmVyc2ljb2xvcgo2LjMsMy4zLDQuNywxLjYsSXJpcy12ZXJzaWNvbG9yCjQuOSwyLjQsMy4zLDEuMCxJcmlzLXZlcnNpY29sb3IKNi42LDIuOSw0LjYsMS4zLElyaXMtdmVyc2ljb2xvcgo1LjIsMi43LDMuOSwxLjQsSXJpcy12ZXJzaWNvbG9yCjUuMCwyLjAsMy41LDEuMCxJcmlzLXZlcnNpY29sb3IKNS45LDMuMCw0LjIsMS41LElyaXMtdmVyc2ljb2xvcgo2LjAsMi4yLDQuMCwxLjAsSXJpcy12ZXJzaWNvbG9yCjYuMSwyLjksNC43LDEuNCxJcmlzLXZlcnNpY29sb3IKNS42LDIuOSwzLjYsMS4zLElyaXMtdmVyc2ljb2xvcgo2LjcsMy4xLDQuNCwxLjQsSXJpcy12ZXJzaWNvbG9yCjUuNiwzLjAsNC41LDEuNSxJcmlzLXZlcnNpY29sb3IKNS44LDIuNyw0LjEsMS4wLElyaXMtdmVyc2ljb2xvcgo2LjIsMi4yLDQuNSwxLjUsSXJpcy12ZXJzaWNvbG9yCjUuNiwyLjUsMy45LDEuMSxJcmlzLXZlcnNpY29sb3IKNS45LDMuMiw0LjgsMS44LElyaXMtdmVyc2ljb2xvcgo2LjEsMi44LDQuMCwxLjMsSXJpcy12ZXJzaWNvbG9yCjYuMywyLjUsNC45LDEuNSxJcmlzLXZlcnNpY29sb3IKNi4xLDIuOCw0LjcsMS4yLElyaXMtdmVyc2ljb2xvcgo2LjQsMi45LDQuMywxLjMsSXJpcy12ZXJzaWNvbG9yCjYuNiwzLjAsNC40LDEuNCxJcmlzLXZlcnNpY29sb3IKNi44LDIuOCw0LjgsMS40LElyaXMtdmVyc2ljb2xvcgo2LjcsMy4wLDUuMCwxLjcsSXJpcy12ZXJzaWNvbG9yCjYuMCwyLjksNC41LDEuNSxJcmlzLXZlcnNpY29sb3IKNS43LDIuNiwzLjUsMS4wLElyaXMtdmVyc2ljb2xvcgo1LjUsMi40LDMuOCwxLjEsSXJpcy12ZXJzaWNvbG9yCjUuNSwyLjQsMy43LDEuMCxJcmlzLXZlcnNpY29sb3IKNS44LDIuNywzLjksMS4yLElyaXMtdmVyc2ljb2xvcgo2LjAsMi43LDUuMSwxLjYsSXJpcy12ZXJzaWNvbG9yCjUuNCwzLjAsNC41LDEuNSxJcmlzLXZlcnNpY29sb3IKNi4wLDMuNCw0LjUsMS42LElyaXMtdmVyc2ljb2xvcgo2LjcsMy4xLDQuNywxLjUsSXJpcy12ZXJzaWNvbG9yCjYuMywyLjMsNC40LDEuMyxJcmlzLXZlcnNpY29sb3IKNS42LDMuMCw0LjEsMS4zLElyaXMtdmVyc2ljb2xvcgo1LjUsMi41LDQuMCwxLjMsSXJpcy12ZXJzaWNvbG9yCjUuNSwyLjYsNC40LDEuMixJcmlzLXZlcnNpY29sb3IKNi4xLDMuMCw0LjYsMS40LElyaXMtdmVyc2ljb2xvcgo1LjgsMi42LDQuMCwxLjIsSXJpcy12ZXJzaWNvbG9yCjUuMCwyLjMsMy4zLDEuMCxJcmlzLXZlcnNpY29sb3IKNS42LDIuNyw0LjIsMS4zLElyaXMtdmVyc2ljb2xvcgo1LjcsMy4wLDQuMiwxLjIsSXJpcy12ZXJzaWNvbG9yCjUuNywyLjksNC4yLDEuMyxJcmlzLXZlcnNpY29sb3IKNi4yLDIuOSw0LjMsMS4zLElyaXMtdmVyc2ljb2xvcgo1LjEsMi41LDMuMCwxLjEsSXJpcy12ZXJzaWNvbG9yCjUuNywyLjgsNC4xLDEuMyxJcmlzLXZlcnNpY29sb3IKNi4zLDMuMyw2LjAsMi41LElyaXMtdmlyZ2luaWNhCjUuOCwyLjcsNS4xLDEuOSxJcmlzLXZpcmdpbmljYQo3LjEsMy4wLDUuOSwyLjEsSXJpcy12aXJnaW5pY2EKNi4zLDIuOSw1LjYsMS44LElyaXMtdmlyZ2luaWNhCjYuNSwzLjAsNS44LDIuMixJcmlzLXZpcmdpbmljYQo3LjYsMy4wLDYuNiwyLjEsSXJpcy12aXJnaW5pY2EKNC45LDIuNSw0LjUsMS43LElyaXMtdmlyZ2luaWNhCjcuMywyLjksNi4zLDEuOCxJcmlzLXZpcmdpbmljYQo2LjcsMi41LDUuOCwxLjgsSXJpcy12aXJnaW5pY2EKNy4yLDMuNiw2LjEsMi41LElyaXMtdmlyZ2luaWNhCjYuNSwzLjIsNS4xLDIuMCxJcmlzLXZpcmdpbmljYQo2LjQsMi43LDUuMywxLjksSXJpcy12aXJnaW5pY2EKNi44LDMuMCw1LjUsMi4xLElyaXMtdmlyZ2luaWNhCjUuNywyLjUsNS4wLDIuMCxJcmlzLXZpcmdpbmljYQo1LjgsMi44LDUuMSwyLjQsSXJpcy12aXJnaW5pY2EKNi40LDMuMiw1LjMsMi4zLElyaXMtdmlyZ2luaWNhCjYuNSwzLjAsNS41LDEuOCxJcmlzLXZpcmdpbmljYQo3LjcsMy44LDYuNywyLjIsSXJpcy12aXJnaW5pY2EKNy43LDIuNiw2LjksMi4zLElyaXMtdmlyZ2luaWNhCjYuMCwyLjIsNS4wLDEuNSxJcmlzLXZpcmdpbmljYQo2LjksMy4yLDUuNywyLjMsSXJpcy12aXJnaW5pY2EKNS42LDIuOCw0LjksMi4wLElyaXMtdmlyZ2luaWNhCjcuNywyLjgsNi43LDIuMCxJcmlzLXZpcmdpbmljYQo2LjMsMi43LDQuOSwxLjgsSXJpcy12aXJnaW5pY2EKNi43LDMuMyw1LjcsMi4xLElyaXMtdmlyZ2luaWNhCjcuMiwzLjIsNi4wLDEuOCxJcmlzLXZpcmdpbmljYQo2LjIsMi44LDQuOCwxLjgsSXJpcy12aXJnaW5pY2EKNi4xLDMuMCw0LjksMS44LElyaXMtdmlyZ2luaWNhCjYuNCwyLjgsNS42LDIuMSxJcmlzLXZpcmdpbmljYQo3LjIsMy4wLDUuOCwxLjYsSXJpcy12aXJnaW5pY2EKNy40LDIuOCw2LjEsMS45LElyaXMtdmlyZ2luaWNhCjcuOSwzLjgsNi40LDIuMCxJcmlzLXZpcmdpbmljYQo2LjQsMi44LDUuNiwyLjIsSXJpcy12aXJnaW5pY2EKNi4zLDIuOCw1LjEsMS41LElyaXMtdmlyZ2luaWNhCjYuMSwyLjYsNS42LDEuNCxJcmlzLXZpcmdpbmljYQo3LjcsMy4wLDYuMSwyLjMsSXJpcy12aXJnaW5pY2EKNi4zLDMuNCw1LjYsMi40LElyaXMtdmlyZ2luaWNhCjYuNCwzLjEsNS41LDEuOCxJcmlzLXZpcmdpbmljYQo2LjAsMy4wLDQuOCwxLjgsSXJpcy12aXJnaW5pY2EKNi45LDMuMSw1LjQsMi4xLElyaXMtdmlyZ2luaWNhCjYuNywzLjEsNS42LDIuNCxJcmlzLXZpcmdpbmljYQo2LjksMy4xLDUuMSwyLjMsSXJpcy12aXJnaW5pY2EKNS44LDIuNyw1LjEsMS45LElyaXMtdmlyZ2luaWNhCjYuOCwzLjIsNS45LDIuMyxJcmlzLXZpcmdpbmljYQo2LjcsMy4zLDUuNywyLjUsSXJpcy12aXJnaW5pY2EKNi43LDMuMCw1LjIsMi4zLElyaXMtdmlyZ2luaWNhCjYuMywyLjUsNS4wLDEuOSxJcmlzLXZpcmdpbmljYQo2LjUsMy4wLDUuMiwyLjAsSXJpcy12aXJnaW5pY2EKNi4yLDMuNCw1LjQsMi4zLElyaXMtdmlyZ2luaWNhCjUuOSwzLjAsNS4xLDEuOCxJcmlzLXZpcmdpbmljYQo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "LSWthyFPv8gaylzd0xFcUg==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F97985C3D\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "CO3YVt51k9s=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/helloworld_component_command.yml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1209", - "Content-MD5": "bfjtgyl7yfwdjy7ZoAJ8bw==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbgpuYW1lOiBtaWNyb3NvZnQuY29tLmF6dXJlbWwuc2FtcGxlcy50cmFpbgp2ZXJzaW9uOiAwLjAuNApkaXNwbGF5X25hbWU6IFRyYWluCnR5cGU6IENvbW1hbmRDb21wb25lbnQKZGVzY3JpcHRpb246IEEgZHVtbXkgdHJhaW5pbmcgbW9kdWxlCnRhZ3M6IHtjYXRlZ29yeTogQ29tcG9uZW50IFR1dG9yaWFsLCBjb250YWN0OiBhbWxkZXNpZ25lckBtaWNyb3NvZnQuY29tfQppbnB1dHM6CiAgdHJhaW5pbmdfZGF0YToKICAgIHR5cGU6IHBhdGgKICAgIGRlc2NyaXB0aW9uOiBUcmFpbmluZyBkYXRhIG9yZ2FuaXplZCBpbiB0aGUgdG9yY2h2aXNpb24gZm9ybWF0L3N0cnVjdHVyZQogICAgb3B0aW9uYWw6IGZhbHNlCiAgbWF4X2Vwb2NoczoKICAgIHR5cGU6IGludGVnZXIKICAgIGRlc2NyaXB0aW9uOiBNYXhpbXVtIG51bWJlciBvZiBlcG9jaHMgZm9yIHRoZSB0cmFpbmluZwogICAgb3B0aW9uYWw6IGZhbHNlCiAgbGVhcm5pbmdfcmF0ZToKICAgIHR5cGU6IGZsb2F0CiAgICBkZXNjcmlwdGlvbjogTGVhcm5pbmcgcmF0ZSwgZGVmYXVsdCBpcyAwLjAxCiAgICAjIFRPRE86IGNhbid0IHBhcnNlIDAuMDEgY29ycmVjdGx5CiAgICBkZWZhdWx0OiAwLjAxICAjIDAuMDEKICAgIG9wdGlvbmFsOiBmYWxzZQpvdXRwdXRzOgogIG1vZGVsX291dHB1dDoKICAgIHR5cGU6IHBhdGgKICAgIGRlc2NyaXB0aW9uOiBUaGUgb3V0cHV0IG1vZGVsCmNvbW1hbmQ6ID4tCiAgcHl0aG9uIHRyYWluLnB5IC0tdHJhaW5pbmdfZGF0YSB7aW5wdXRzLnRyYWluaW5nX2RhdGF9IC0tbWF4X2Vwb2NocyB7aW5wdXRzLm1heF9lcG9jaHN9CiAgLS1sZWFybmluZ19yYXRlIHtpbnB1dHMubGVhcm5pbmdfcmF0ZX0gLS1tb2RlbF9vdXRwdXQge291dHB1dHMubW9kZWxfb3V0cHV0fQplbnZpcm9ubWVudDoKICBjb25kYToKICAgIGNvbmRhX2RlcGVuZGVuY2llczoKICAgICAgbmFtZTogcHJvamVjdF9lbnZpcm9ubWVudAogICAgICBjaGFubmVsczoKICAgICAgLSBkZWZhdWx0cwogICAgICBkZXBlbmRlbmNpZXM6CiAgICAgIC0gcHl0aG9uPTMuNi44CiAgICAgIC0gcGlwPTIwLjAKICAgICAgLSBwaXA6CiAgICAgICAgLSBhenVyZW1sLWRlZmF1bHRzCiAgICAgICAgLSBhenVyZW1sLWRhdGFwcmVwPj0xLjYKICBvczogTGludXgK", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "bfjtgyl7yfwdjy7ZoAJ8bw==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F9799948D\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "02paHXEK3RE=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/hdi-component/component_spec.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "963", - "Content-MD5": "r\u002B9OAttQq8px0dEEOqr9uA==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "IyBDb3B5cmlnaHQgKGMpIE1pY3Jvc29mdCBDb3Jwb3JhdGlvbi4KIyBMaWNlbnNlZCB1bmRlciB0aGUgTUlUIExpY2Vuc2UuCgokc2NoZW1hOiBodHRwczovL2NvbXBvbmVudHNkay5henVyZWVkZ2UubmV0L2pzb25zY2hlbWEvSERJbnNpZ2h0Q29tcG9uZW50Lmpzb24KbmFtZTogdHJhaW5faW5fc3BhcmsKdmVyc2lvbjogMC4wLjEKZGlzcGxheV9uYW1lOiBUcmFpbiBpbiBTcGFyawp0eXBlOiBIREluc2lnaHRDb21wb25lbnQKZGVzY3JpcHRpb246IFRyYWluIGEgU3BhcmsgTUwgbW9kZWwgdXNpbmcgYW4gSERJbnNpZ2h0IFNwYXJrIGNsdXN0ZXIKdGFnczoKICBIREluc2lnaHQ6ICcnCiAgU2FtcGxlOiAnJwogIGNvbnRhY3Q6IE1pY3Jvc29mdCBDb3BvcmF0aW9uIDx4eHhAbWljcm9zb2Z0LmNvbT4KICBoZWxwRG9jdW1lbnQ6IGh0dHBzOi8vYWthLm1zL2hkaW5zaWdodC1tb2R1bGVzCmlucHV0czoKICBpbnB1dF9wYXRoOgogICAgdHlwZTogcGF0aAogICAgZGVzY3JpcHRpb246IElyaXMgY3N2IGZpbGUKICAgIG9wdGlvbmFsOiBmYWxzZQogIHJlZ3VsYXJpemF0aW9uX3JhdGU6CiAgICB0eXBlOiBmbG9hdAogICAgZGVzY3JpcHRpb246IFJlZ3VsYXJpemF0aW9uIHJhdGUgd2hlbiB0cmFpbmluZyB3aXRoIGxvZ2lzdGljIHJlZ3Jlc3Npb24KICAgIG9wdGlvbmFsOiB0cnVlCiAgICBkZWZhdWx0OiAwLjAxCm91dHB1dHM6CiAgb3V0cHV0X3BhdGg6CiAgICB0eXBlOiBwYXRoCiAgICBkZXNjcmlwdGlvbjogVGhlIG91dHB1dCBwYXRoIHRvIHNhdmUgdGhlIHRyYWluZWQgbW9kZWwgdG8KCmhkaW5zaWdodDoKICBmaWxlOiAidHJhaW4tc3BhcmsucHkiCiAgYXJnczogPi0KICAgIC0taW5wdXRfcGF0aCB7aW5wdXRzLmlucHV0X3BhdGh9IFstLXJlZ3VsYXJpemF0aW9uX3JhdGUge2lucHV0cy5yZWd1bGFyaXphdGlvbl9yYXRlfV0gLS1vdXRwdXRfcGF0aCB7b3V0cHV0cy5vdXRwdXRfcGF0aH0K", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "r\u002B9OAttQq8px0dEEOqr9uA==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F97974AF5\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "pdcoi3AfGvo=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/hdi-component/train-spark.py", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "2971", - "Content-MD5": "OoLiY911qUl8wfjWMyUoZg==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "IyAtLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0KIyBDb3B5cmlnaHQgKGMpIE1pY3Jvc29mdCBDb3Jwb3JhdGlvbi4gQWxsIHJpZ2h0cyByZXNlcnZlZC4KIyAtLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0tLS0KCmltcG9ydCBhcmdwYXJzZQppbXBvcnQgb3MKaW1wb3J0IHN5cwoKaW1wb3J0IHB5c3BhcmsKZnJvbSBweXNwYXJrLm1sLmNsYXNzaWZpY2F0aW9uIGltcG9ydCAqCmZyb20gcHlzcGFyay5tbC5ldmFsdWF0aW9uIGltcG9ydCAqCmZyb20gcHlzcGFyay5tbC5mZWF0dXJlIGltcG9ydCAqCmZyb20gcHlzcGFyay5zcWwuZnVuY3Rpb25zIGltcG9ydCAqCmZyb20gcHlzcGFyay5zcWwudHlwZXMgaW1wb3J0IERvdWJsZVR5cGUsIEludGVnZXJUeXBlLCBTdHJpbmdUeXBlLCBTdHJ1Y3RGaWVsZCwgU3RydWN0VHlwZQoKIyBHZXQgYXJncwpwYXJzZXIgPSBhcmdwYXJzZS5Bcmd1bWVudFBhcnNlcigpCnBhcnNlci5hZGRfYXJndW1lbnQoIi0taW5wdXRfcGF0aCIpCnBhcnNlci5hZGRfYXJndW1lbnQoIi0tcmVndWxhcml6YXRpb25fcmF0ZSIpCnBhcnNlci5hZGRfYXJndW1lbnQoIi0tb3V0cHV0X3BhdGgiKQphcmdzLCBfID0gcGFyc2VyLnBhcnNlX2tub3duX2FyZ3MoKQppbnB1dF9wYXRoID0gYXJncy5pbnB1dF9wYXRoCnJlZ3VsYXJpemF0aW9uX3JhdGUgPSBhcmdzLnJlZ3VsYXJpemF0aW9uX3JhdGUKb3V0cHV0X3BhdGggPSBhcmdzLm91dHB1dF9wYXRoCgpwcmludCgiaW5wdXRfcGF0aDoge30iLmZvcm1hdChpbnB1dF9wYXRoKSkKcHJpbnQoInJlZ3VsYXJpemF0aW9uX3JhdGU6IHt9Ii5mb3JtYXQocmVndWxhcml6YXRpb25fcmF0ZSkpCnByaW50KCJvdXRwdXRfcGF0aDoge30iLmZvcm1hdChvdXRwdXRfcGF0aCkpCgojIHN0YXJ0IFNwYXJrIHNlc3Npb24Kc3BhcmsgPSBweXNwYXJrLnNxbC5TcGFya1Nlc3Npb24uYnVpbGRlci5hcHBOYW1lKCJJcmlzIikuZ2V0T3JDcmVhdGUoKQoKIyBwcmludCBydW50aW1lIHZlcnNpb25zCnByaW50KCIqKioqKioqKioqKioqKioqIikKcHJpbnQoIlB5dGhvbiB2ZXJzaW9uOiB7fSIuZm9ybWF0KHN5cy52ZXJzaW9uKSkKcHJpbnQoIlNwYXJrIHZlcnNpb246IHt9Ii5mb3JtYXQoc3BhcmsudmVyc2lvbikpCnByaW50KCIqKioqKioqKioqKioqKioqIikKCiMgbG9hZCBpcmlzLmNzdiBpbnRvIFNwYXJrIGRhdGFmcmFtZQpzY2hlbWEgPSBTdHJ1Y3RUeXBlKAogICAgWwogICAgICAgIFN0cnVjdEZpZWxkKCJzZXBhbC1sZW5ndGgiLCBEb3VibGVUeXBlKCkpLAogICAgICAgIFN0cnVjdEZpZWxkKCJzZXBhbC13aWR0aCIsIERvdWJsZVR5cGUoKSksCiAgICAgICAgU3RydWN0RmllbGQoInBldGFsLWxlbmd0aCIsIERvdWJsZVR5cGUoKSksCiAgICAgICAgU3RydWN0RmllbGQoInBldGFsLXdpZHRoIiwgRG91YmxlVHlwZSgpKSwKICAgICAgICBTdHJ1Y3RGaWVsZCgiY2xhc3MiLCBTdHJpbmdUeXBlKCkpLAogICAgXQopCgpkYXRhID0gc3BhcmsucmVhZC5jc3YoaW5wdXRfcGF0aCwgaGVhZGVyPVRydWUsIHNjaGVtYT1zY2hlbWEpCgpwcmludCgiRmlyc3QgMTAgcm93cyBvZiBJcmlzIGRhdGFzZXQ6IikKZGF0YS5zaG93KDEwKQoKIyB2ZWN0b3JpemUgYWxsIG51bWVyaWNhbCBjb2x1bW5zIGludG8gYSBzaW5nbGUgZmVhdHVyZSBjb2x1bW4KZmVhdHVyZV9jb2xzID0gZGF0YS5jb2x1bW5zWzotMV0KYXNzZW1ibGVyID0gcHlzcGFyay5tbC5mZWF0dXJlLlZlY3RvckFzc2VtYmxlcihpbnB1dENvbHM9ZmVhdHVyZV9jb2xzLCBvdXRwdXRDb2w9ImZlYXR1cmVzIikKZGF0YSA9IGFzc2VtYmxlci50cmFuc2Zvcm0oZGF0YSkKCiMgY29udmVydCB0ZXh0IGxhYmVscyBpbnRvIGluZGljZXMKZGF0YSA9IGRhdGEuc2VsZWN0KFsiZmVhdHVyZXMiLCAiY2xhc3MiXSkKbGFiZWxfaW5kZXhlciA9IHB5c3BhcmsubWwuZmVhdHVyZS5TdHJpbmdJbmRleGVyKGlucHV0Q29sPSJjbGFzcyIsIG91dHB1dENvbD0ibGFiZWwiKS5maXQoZGF0YSkKZGF0YSA9IGxhYmVsX2luZGV4ZXIudHJhbnNmb3JtKGRhdGEpCgojIG9ubHkgc2VsZWN0IHRoZSBmZWF0dXJlcyBhbmQgbGFiZWwgY29sdW1uCmRhdGEgPSBkYXRhLnNlbGVjdChbImZlYXR1cmVzIiwgImxhYmVsIl0pCnByaW50KCJSZWFkaW5nIGZvciBtYWNoaW5lIGxlYXJuaW5nIikKZGF0YS5zaG93KDEwKQoKIyB1c2UgTG9naXN0aWMgUmVncmVzc2lvbiB0byB0cmFpbiBvbiB0aGUgdHJhaW5pbmcgc2V0CnRyYWluLCB0ZXN0ID0gZGF0YS5yYW5kb21TcGxpdChbMC43MCwgMC4zMF0pCnJlZyA9IGZsb2F0KHJlZ3VsYXJpemF0aW9uX3JhdGUpCmxyID0gcHlzcGFyay5tbC5jbGFzc2lmaWNhdGlvbi5Mb2dpc3RpY1JlZ3Jlc3Npb24ocmVnUGFyYW09cmVnKQptb2RlbCA9IGxyLmZpdCh0cmFpbikKCm1vZGVsLnNhdmUob3MucGF0aC5qb2luKG91dHB1dF9wYXRoLCAiaXJpcy5tb2RlbCIpKQoKIyBwcmVkaWN0IG9uIHRoZSB0ZXN0IHNldApwcmVkaWN0aW9uID0gbW9kZWwudHJhbnNmb3JtKHRlc3QpCnByaW50KCJQcmVkaWN0aW9uIikKcHJlZGljdGlvbi5zaG93KDEwKQoKIyBldmFsdWF0ZSB0aGUgYWNjdXJhY3kgb2YgdGhlIG1vZGVsIHVzaW5nIHRoZSB0ZXN0IHNldApldmFsdWF0b3IgPSBweXNwYXJrLm1sLmV2YWx1YXRpb24uTXVsdGljbGFzc0NsYXNzaWZpY2F0aW9uRXZhbHVhdG9yKG1ldHJpY05hbWU9ImFjY3VyYWN5IikKYWNjdXJhY3kgPSBldmFsdWF0b3IuZXZhbHVhdGUocHJlZGljdGlvbikKCnByaW50KCkKcHJpbnQoIiMjIyMjIyMjIyMjIyMjIyMjIyMjIyMjIyMjIyMjIyMjIyMjIyMiKQpwcmludCgiUmVndWxhcml6YXRpb24gcmF0ZSBpcyB7fSIuZm9ybWF0KHJlZykpCnByaW50KCJBY2N1cmFjeSBpcyB7fSIuZm9ybWF0KGFjY3VyYWN5KSkKcHJpbnQoIiMjIyMjIyMjIyMjIyMjIyMjIyMjIyMjIyMjIyMjIyMjIyMjIyMiKQpwcmludCgpCg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "OoLiY911qUl8wfjWMyUoZg==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F979B1AF8\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "ZKYXhin/fMc=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/helloworld_component_scope.yml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1224", - "Content-MD5": "SH/P2z4EkiQMRdbeOHGFsw==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL1Njb3BlQ29tcG9uZW50Lmpzb24KCm5hbWU6IGJpbmdfcmVsZXZhbmNlX2NvbnZlcnQyc3MKdmVyc2lvbjogMC4wLjEKZGlzcGxheV9uYW1lOiBDb252ZXJ0IFRleHQgdG8gU3RydWN0dXJlU3RyZWFtCgp0eXBlOiBTY29wZUNvbXBvbmVudAoKaXNfZGV0ZXJtaW5pc3RpYzogVHJ1ZQoKdGFnczoKICBvcmc6IGJpbmcKICBwcm9qZWN0OiByZWxldmFuY2UKCmRlc2NyaXB0aW9uOiBDb252ZXJ0IEFETFMgdGVzdCBkYXRhIHRvIFNTIGZvcm1hdAoKaW5wdXRzOgogIFRleHREYXRhOgogICAgdHlwZTogc3RyaW5nCiAgICBvcHRpb25hbDogRmFsc2UgICMgVE9ETzogc3VwcG9ydCBGYWxzZSBhcyBkZWZhdWx0IHZhbHVlCiAgICBkZXNjcmlwdGlvbjogdGV4dCBmaWxlIG9uIEFETFMgc3RvcmFnZQogIEV4dHJhY3Rpb25DbGF1c2U6CiAgICB0eXBlOiBzdHJpbmcKICAgIG9wdGlvbmFsOiBGYWxzZQogICAgZGVzY3JpcHRpb246IHRoZSBleHRyYWN0aW9uIGNsYXVzZSwgc29tZXRoaW5nIGxpa2UgImNvbHVtbjE6c3RyaW5nLCBjb2x1bW4yOmludCIKb3V0cHV0czoKICBTU1BhdGg6CiAgICB0eXBlOiBwYXRoCiAgICBkZXNjcmlwdGlvbjogb3V0cHV0IHBhdGggb2Ygc3MKCmNvZGU6IC4vc2NvcGUKCmVudmlyb25tZW50OiBhenVyZW1sOkF6dXJlRW52OjEKCnNjb3BlOgogIHNjcmlwdDogY29udmVydDJzcy5zY3JpcHQKICAjIHRvIHJlZmVyZW5jZSB0aGUgaW5wdXRzL291dHB1dHMgaW4geW91ciBzY3JpcHQKICAjIHlvdSBtdXN0IGRlZmluZSB0aGUgYXJndW1lbnQgbmFtZSBvZiB5b3VyIGludHB1cy9vdXRwdXRzIGluIGFyZ3Mgc2VjdGlvbgogICMgQm90aCAnYXJndW1lbnRfbmFtZSB7aW5wdXRzLmlucHV0X25hbWV9JyBhbmQgJ2FyZ3VtZW50X25hbWU9e2lucHV0cy5pbnB1dF9uYW1lfScgYXJlIHN1cHBvcnRlZAogICMgZm9yIGV4YW1wbGUsIGlmIHlvdSBkZWZpbmUgeW91ciBhcmdzIGFzIGJlbG93LCB5b3UgY2FuIHVzZSBAQElucHV0X1RleHREYXRhQEAgdG8gcmVmZXIgdG8geW91ciBjb21wb25lbnQncyBpbnB1dCBUZXh0RGF0YQogIGFyZ3M6ID4tCiAgICBJbnB1dF9UZXh0RGF0YSB7aW5wdXRzLlRleHREYXRhfQogICAgRXh0cmFjdGlvbkNsYXVzZT17aW5wdXRzLkV4dHJhY3Rpb25DbGF1c2V9CiAgICBPdXRwdXRfU1NQYXRoIHtvdXRwdXRzLlNTUGF0aH0K", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "SH/P2z4EkiQMRdbeOHGFsw==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F979E9CE1\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "IHnr2Io0X2k=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/hemera-component/component.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1843", - "Content-MD5": "l2K141HIJnyTqzT\u002BbCZM8g==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0hlbWVyYUNvbXBvbmVudC5qc29uCm5hbWU6IEFkc0xSRE5OUmF3S2V5c19EdW1teQp2ZXJzaW9uOiAwLjAuMgpkaXNwbGF5X25hbWU6IEFkcyBMUiBETk4gUmF3IEtleXMKdHlwZTogSGVtZXJhQ29tcG9uZW50CmRlc2NyaXB0aW9uOiBBZHMgTFIgRE5OIFJhdyBLZXlzIER1bW15IHNhbXBsZS4KdGFnczoKICBjYXRlZ29yeTogQ29tcG9uZW50IFR1dG9yaWFsCiAgY29udGFjdDogYW1sZGVzaWduZXJAbWljcm9zb2Z0LmNvbQppbnB1dHM6CiAgVHJhaW5pbmdEYXRhRGlyOgogICAgdHlwZTogcGF0aAogICAgb3B0aW9uYWw6IHRydWUKICAgIGlzX3Jlc291cmNlOiB0cnVlCiAgVmFsaWRhdGlvbkRhdGFEaXI6CiAgICB0eXBlOiBwYXRoCiAgICBvcHRpb25hbDogdHJ1ZQogICAgaXNfcmVzb3VyY2U6IHRydWUKICBJbml0aWFsTW9kZWxEaXI6CiAgICB0eXBlOiBwYXRoCiAgICBvcHRpb25hbDogdHJ1ZQogICAgaXNfcmVzb3VyY2U6IHRydWUKICBZYXJuQ2x1c3RlcjoKICAgIHR5cGU6IHN0cmluZwogICAgb3B0aW9uYWw6IGZhbHNlCiAgICBkZWZhdWx0OiBtdHByaW1lLWJuMi0wCiAgSm9iUXVldWU6CiAgICB0eXBlOiBzdHJpbmcKICAgIG9wdGlvbmFsOiBmYWxzZQogICAgZGVmYXVsdDogZGVmYXVsdAogIFdvcmtlckNvdW50OgogICAgdHlwZTogc3RyaW5nCiAgICBvcHRpb25hbDogZmFsc2UKICAgIGRlZmF1bHQ6IDIuMAogIENwdToKICAgIHR5cGU6IHN0cmluZwogICAgb3B0aW9uYWw6IGZhbHNlCiAgICBkZWZhdWx0OiAyLjAKICBNZW1vcnk6CiAgICB0eXBlOiBzdHJpbmcKICAgIG9wdGlvbmFsOiBmYWxzZQogICAgZGVmYXVsdDogMTBnCiAgSGRmc1Jvb3REaXI6CiAgICB0eXBlOiBzdHJpbmcKICAgIG9wdGlvbmFsOiBmYWxzZQogICAgZGVmYXVsdDogL3Byb2plY3RzL2RlZmF1bHQvCiAgQ29zbW9zUm9vdERpcjoKICAgIHR5cGU6IHN0cmluZwogICAgb3B0aW9uYWw6IGZhbHNlCiAgICBkZWZhdWx0OiBodHRwczovL2Nvc21vczA5Lm9zZGluZnJhLm5ldC9jb3Ntb3MvZHVtbXkvbG9jYWwvcm9vdC8Kb3V0cHV0czoKICBvdXRwdXQxOgogICAgdHlwZTogQW55RmlsZQogIG91dHB1dDI6CiAgICB0eXBlOiBBbnlGaWxlCmNvbW1hbmQ6ID4tCiAgcnVuLmJhdCBbLV9UcmFpbmluZ0RhdGFEaXIge2lucHV0cy5UcmFpbmluZ0RhdGFEaXJ9XSBbLV9WYWxpZGF0aW9uRGF0YURpciB7aW5wdXRzLlZhbGlkYXRpb25EYXRhRGlyfV0gWy1fSW5pdGlhbE1vZGVsRGlyIHtpbnB1dHMuSW5pdGlhbE1vZGVsRGlyfV0gLV9Db3Ntb3NSb290RGlyIHtpbnB1dHMuQ29zbW9zUm9vdERpcn0gLV9Qc0NvdW50IDAKICAlQ0xVU1RFUiU9e2lucHV0cy5ZYXJuQ2x1c3Rlcn0gLUpvYlF1ZXVlIHtpbnB1dHMuSm9iUXVldWV9IC1fV29ya2VyQ291bnQge2lucHV0cy5Xb3JrZXJDb3VudH0gLV9DcHUge2lucHV0cy5DcHV9IC1fTWVtb3J5IHtpbnB1dHMuTWVtb3J5fSAtX0hkZnNSb290RGlyIHtpbnB1dHMuSGRmc1Jvb3REaXJ9CiAgLV9FeHBvc2VkUG9ydCAiMzIwMC0zMjEwLDMzMDAtMzMyMSIgLV9Ob2RlTG9zdEJsb2NrZXIgLV9Vc2VQaHlzaWNhbElQIC1fU3luY1dvcmtlciAtX0VudHJhbmNlRmlsZU5hbWUgcnVuLnB5IC1fU3RhcnR1cEFyZ3VtZW50cyAiIiAtX1B5dGhvblppcFBhdGggImh0dHBzOi8vZHVtbXkvZm9vL2Jhci56aXAiCiAgLV9Nb2RlbE91dHB1dERpciB7b3V0cHV0cy5vdXRwdXQxfSAtX1ZhbGlkYXRpb25PdXRwdXREaXIge291dHB1dHMub3V0cHV0Mn0KaGVtZXJhOgogIHJlZl9pZDogMWJkMTUyNWMtMDgyZS00NjUyLWE5YjItOWM2MDc4M2VjNTUxCg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "l2K141HIJnyTqzT\u002BbCZM8g==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F97A10D83\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "e5yr/QTeCN8=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/scope-component/component_spec.loaded_from_rest.json", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "983", - "Content-MD5": "g22P9tlmiYfjYYZqqwEByQ==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "ewogICJkZXNjcmlwdGlvbiI6ICJDb252ZXJ0IGFkbHMgdGVzdCBkYXRhIHRvIFNTIGZvcm1hdCIsCiAgInRhZ3MiOiB7CiAgICAib3JnIjogImJpbmciLAogICAgInByb2plY3QiOiAicmVsZXZhbmNlIgogIH0sCiAgInZlcnNpb24iOiAiMC4wLjEiLAogICIkc2NoZW1hIjogImh0dHBzOi8vY29tcG9uZW50c2RrLmF6dXJlZWRnZS5uZXQvanNvbnNjaGVtYS9TY29wZUNvbXBvbmVudC5qc29uIiwKICAiZGlzcGxheV9uYW1lIjogIkNvbnZlcnQgVGV4dCB0byBTdHJ1Y3R1cmVTdHJlYW0iLAogICJpc19kZXRlcm1pbmlzdGljIjogdHJ1ZSwKICAiaW5wdXRzIjogewogICAgIlRleHREYXRhIjogewogICAgICAidHlwZSI6IFsKICAgICAgICAiQW55RmlsZSIsCiAgICAgICAgIkFueURpcmVjdG9yeSIKICAgICAgXSwKICAgICAgImRlc2NyaXB0aW9uIjogInRleHQgZmlsZSBvbiBBRExTIHN0b3JhZ2UiLAogICAgICAiaXNfcmVzb3VyY2UiOiBmYWxzZQogICAgfSwKICAgICJFeHRyYWN0aW9uQ2xhdXNlIjogewogICAgICAidHlwZSI6ICJzdHJpbmciLAogICAgICAiZGVzY3JpcHRpb24iOiAidGhlIGV4dHJhY3Rpb24gY2xhdXNlLCBzb21ldGhpbmcgbGlrZSBcImNvbHVtbjE6c3RyaW5nLCBjb2x1bW4yOmludFwiIgogICAgfQogIH0sCiAgIm91dHB1dHMiOiB7CiAgICAiU1NQYXRoIjogewogICAgICAidHlwZSI6ICJDb3Ntb3NTdHJ1Y3R1cmVkU3RyZWFtIiwKICAgICAgImRlc2NyaXB0aW9uIjogInRoZSBjb252ZXJ0ZWQgc3RydWN0dXJlZCBzdHJlYW0iCiAgICB9CiAgfSwKICAidHlwZSI6ICJTY29wZUNvbXBvbmVudCIsCiAgInNjb3BlIjogewogICAgImFyZ3MiOiAiSW5wdXRfVGV4dERhdGEge2lucHV0cy5UZXh0RGF0YX0gT3V0cHV0X1NTUGF0aCB7b3V0cHV0cy5TU1BhdGh9IEV4dHJhY3Rpb25DbGF1c2Uge2lucHV0cy5FeHRyYWN0aW9uQ2xhdXNlfSIsCiAgICAic2NyaXB0IjogImNvbnZlcnQyc3Muc2NyaXB0IgogIH0KfQo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "g22P9tlmiYfjYYZqqwEByQ==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F97A48F70\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "5g8WGmFf\u002Bk4=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/scope-component/label_data.tsv", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "41", - "Content-MD5": "A64Bh7bu4vfLZdGBUnRXDQ==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "YQkxCmIJMgphCTMKZAk0CmQJNQpyCTYKcgk3CmkJOAp2CTkKYwkxMAo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "A64Bh7bu4vfLZdGBUnRXDQ==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F97A48F70\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "rncUqfmFs44=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/ipp-component/gpt3finetune.spec.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "2051", - "Content-MD5": "ahavv5OdQpJ2WEr1CQgsGQ==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cDovL2F6dXJlbWwvc2RrLTItMC9EaXN0cmlidXRlZENvbXBvbmVudC5qc29uCm5hbWU6IG1pY3Jvc29mdC5jb20uYXp1cmVtbC5ncHQzLmZpbmV0dW5lCnZlcnNpb246IDAuMC4xCmRpc3BsYXlfbmFtZTogR1BUMyBGaW5lLXR1bmUgdHJhaW5pbmcKaXNfZGV0ZXJtaW5pc3RpYzogVHJ1ZQp0eXBlOiBEaXN0cmlidXRlZENvbXBvbmVudEAxLWxlZ2FjeQpkZXNjcmlwdGlvbjogTW9kdWxlIGZvciBHUFQzIGZpbmUgdHVuZQp0YWdzOgogIGNvbnRhY3Q6IGZlbGkxQG1pY3Jvc29mdC5jb20KaW5wdXRzOgogIGlucHV0X2RhdGFzZXQ6CiAgICB0eXBlOiBwYXRoCiAgICBvcHRpb25hbDogRmFsc2UKICAgIGRlc2NyaXB0aW9uOiBJbnB1dCBmaWxlL3RhYnVsYXIgZGF0YXNldAogIGJhc2VfbW9kZWw6CiAgICB0eXBlOiBwYXRoCiAgICBvcHRpb25hbDogRmFsc2UKICAgIGRlc2NyaXB0aW9uOiBNb2RlbCBkaXJlY3RvcnkgZm9yIHByZXZpb3VzbHkgbW9kZWwgZHVtcCBvciBiYXNlIEdUUC0zIG1vZGVsCiAgbG9yYV93ZWlnaHRzOgogICAgdHlwZTogcGF0aAogICAgb3B0aW9uYWw6IFRydWUKICAgIGRlc2NyaXB0aW9uOiBmaW5lIHR1bmVkIGxvcmEgd2VpZ2h0cyB3aGljaCBjYW4gYmUgdXNlZCB0byBkbyBjb250aW51b3VzIGZpbmUgdHVuaW5nCiAgdHVuaW5nX3R5cGU6CiAgICB0eXBlOiBFbnVtCiAgICBvcHRpb25hbDogVHJ1ZQogICAgZGVmYXVsdDogbG9yYQogICAgZGVzY3JpcHRpb246IFR1bmluZyB0eXBlCiAgICBlbnVtOgogICAgLSBsb3JhCiAgICAtIGZpbmVfdHVuaW5nCiAgbl9lcG9jaHM6CiAgICB0eXBlOiBJbnRlZ2VyCiAgICBvcHRpb25hbDogVHJ1ZQogICAgZGVmYXVsdDogMgogICAgZGVzY3JpcHRpb246IE51bWJlciBvZiBlcG9jaHMgZm9yIHRoZSB0cmFpbmluZwogIGJhdGNoX3NpemU6CiAgICB0eXBlOiBJbnRlZ2VyCiAgICBvcHRpb25hbDogVHJ1ZQogICAgZGVmYXVsdDogMTI4CiAgICBkZXNjcmlwdGlvbjogVGhlIGJhdGNoIHNpemUgdG8gdXNlIGZvciB0cmFpbmluZwogIGxlYXJuaW5nX3JhdGVfbXVsdGlwbGllcjoKICAgIHR5cGU6IEZsb2F0CiAgICBvcHRpb25hbDogVHJ1ZQogICAgZGVmYXVsdDogMC4wMDIKICAgIGRlc2NyaXB0aW9uOiBUaGUgbGVhcm5pbmcgcmF0ZSBtdWx0aXBsaWVyIHRvIHVzZSBmb3IgdHJhaW5pbmcKICB1c2VfcGFja2luZzoKICAgIHR5cGU6IEJvb2xlYW4KICAgIG9wdGlvbmFsOiBUcnVlCiAgICBkZWZhdWx0OiBUcnVlCiAgICBkZXNjcmlwdGlvbjogT24gY2xhc3NpZmljYXRpb24gdGFza3MsIHdlIHJlY29tbWVuZCBzZXR0aW5nIHRoaXMgdG8gRmFsc2UsIE9uIGFsbCBvdGhlciB0YXNrcywgd2UgcmVjb21tZW5kIHNldHRpbmcgdGhpcyB0byBUcnVlLgpvdXRwdXRzOgogIG91dHB1dF9tb2RlbF9jaGVja3BvaW50czoKICAgIHR5cGU6IHBhdGgKICAgIG9wdGlvbmFsOiBGYWxzZQogICAgZGVzY3JpcHRpb246IGRpcmVjdG9yeSBmb3IgbW9kZWwgY2hlY2twb2ludHMKZW52aXJvbm1lbnQ6CiAgZG9ja2VyOgogICAgaW1hZ2U6IGJhYmVsYWNyLmF6dXJlY3IuaW8vbG9yYV9hbWwKc3VjY2Vzc2Z1bF9yZXR1cm5fY29kZTogWmVybwptZXRhOgogIHJlcXVpcmVHcHU6IFRydWUKbGF1bmNoZXI6CiAgdHlwZTogbXBpCiAgYWRkaXRpb25hbF9hcmd1bWVudHM6IHB5dGhvbiB0cmFpbl93cmFwcGVyLnB5IC0taW5wdXRfZGF0YXNldCB7aW5wdXRzLmlucHV0X2RhdGFzZXR9IC0tb3V0cHV0X21vZGVsIHtvdXRwdXRzLm91dHB1dF9tb2RlbF9jaGVja3BvaW50c30gIC0tYmFzZV9tb2RlbCB7aW5wdXRzLmJhc2VfbW9kZWx9IFstLWxvcmFfd2VpZ2h0cyB7aW5wdXRzLmxvcmFfd2VpZ2h0c31dIFstLXR1bmluZ190eXBlIHtpbnB1dHMudHVuaW5nX3R5cGV9XSBbLS1sZWFybmluZ19yYXRlX211bHRpcGxpZXIge2lucHV0cy5sZWFybmluZ19yYXRlX211bHRpcGxpZXJ9XSBbLS1uX2Vwb2NocyB7aW5wdXRzLm5fZXBvY2hzfV0gWy0tYmF0Y2hfc2l6ZSB7aW5wdXRzLmJhdGNoX3NpemV9XSBbLS11c2VfcGFja2luZyB7aW5wdXRzLmJhdGNoX3NpemV9XQo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "ahavv5OdQpJ2WEr1CQgsGQ==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F97A4B678\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "JFS/N5eoWTQ=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/pipeline_jobs/pipeline_job_with_properties.yml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "4896", - "Content-MD5": "Q1Xa0/m6sShGFUrjsd7wjg==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "dHlwZTogcGlwZWxpbmUKCmRlc2NyaXB0aW9uOiBUaGUgaGVsbG8gd29ybGQgcGlwZWxpbmUgam9iCnRhZ3M6CiAgdGFnOiB0YWd2YWx1ZQogIG93bmVyOiBzZGt0ZWFtCgpzZXR0aW5nczoKICBkZWZhdWx0X2NvbXB1dGU6IGF6dXJlbWw6Y3B1LWNsdXN0ZXIKCmlucHV0czoKICAjIGV4YW1wbGVzIG9mIGlucHV0cyB0aGF0IHRha2UgdmFsdWVzIHN1Y2ggYXMgaW50LCBzdHJpbmcsIGV0Yy4KICBjb21wb25lbnRfaW5fbnVtYmVyOiAxMAogIGhlbGxvX3N0cmluZzogaGVsbG8KICBpbnB1dF9kYXRhOgogICAgcGF0aDogaHR0cHM6Ly9kcHJlcGRhdGEuYmxvYi5jb3JlLndpbmRvd3MubmV0L2RlbW8vVGl0YW5pYy5jc3YKICAgIHR5cGU6IHVyaV9maWxlCiAgdGV4dF9uZXJfdHJhaW5pbmdfZGF0YToKICAgIHR5cGU6IG1sdGFibGUKICAgIHBhdGg6IC4uLy4uL2F1dG9tbF9qb2IvdGVzdF9kYXRhc2V0cy9jb25sbDIwMDMvdHJhaW4KICB0ZXh0X25lcl92YWxpZGF0aW9uX2RhdGE6CiAgICB0eXBlOiBtbHRhYmxlCiAgICBwYXRoOiAuLi8uLi9hdXRvbWxfam9iL3Rlc3RfZGF0YXNldHMvY29ubGwyMDAzL3ZhbGlkCgpwcm9wZXJ0aWVzOgogIEFaVVJFX01MX1BhdGhPbkNvbXB1dGVfaW5wdXRfZGF0YTogIi90bXAvdGVzdCIKCmpvYnM6CiAgbm9kZTA6ICAjIGlubGluZSBjb21tYW5kIGpvYiB3aXRoIHByb3BlcnRpZXMKICAgIGNvbW1hbmQ6IGVjaG8gaGVsbG8gJHt7aW5wdXRzLmhlbGxvX3N0cmluZ319CiAgICBlbnZpcm9ubWVudDogYXp1cmVtbDpBenVyZU1MLXNrbGVhcm4tMC4yNC11YnVudHUxOC4wNC1weTM3LWNwdUBsYXRlc3QKICAgIGlucHV0czoKICAgICAgaGVsbG9fc3RyaW5nOiAke3twYXJlbnQuaW5wdXRzLmhlbGxvX3N0cmluZ319CiAgICBwcm9wZXJ0aWVzOgogICAgICBBWlVSRV9NTF9QYXRoT25Db21wdXRlX2hlbGxvX3N0cmluZzogIi90bXAvdGVzdCIKCiAgbm9kZTE6ICAjIGlubGluZSBwYXJhbGxlbCBqb2Igd2l0aCBwcm9wZXJ0aWVzCiAgICB0eXBlOiBwYXJhbGxlbAogICAgY29tcHV0ZTogImF6dXJlbWw6Y3B1LWNsdXN0ZXIiCiAgICBpbnB1dHM6CiAgICAgIHRlc3QxOiAke3twYXJlbnQuaW5wdXRzLmlucHV0X2RhdGF9fQogICAgcmVzb3VyY2VzOgogICAgICBpbnN0YW5jZV9jb3VudDogMwogICAgbWluaV9iYXRjaF9zaXplOiAiMTAwa2IiCiAgICBtaW5pX2JhdGNoX2Vycm9yX3RocmVzaG9sZDogNQogICAgbG9nZ2luZ19sZXZlbDogIkRFQlVHIgogICAgaW5wdXRfZGF0YTogJHt7aW5wdXRzLmlucHV0X2RhdGF9fQogICAgbWF4X2NvbmN1cnJlbmN5X3Blcl9pbnN0YW5jZTogMgogICAgdGFzazoKICAgICAgdHlwZTogcnVuX2Z1bmN0aW9uCiAgICAgIGNvZGU6ICIuLi9weXRob24iCiAgICAgIGVudHJ5X3NjcmlwdDogcGFzc190aHJvdWdoLnB5CiAgICAgIGFwcGVuZF9yb3dfdG86ICR7e291dHB1dHMuc2NvcmVkX3Jlc3VsdH19ICMgb3B0aW9uYWwsIElmIE51bGwsIGVxdWFscyB0byBzdW1tYXJ5X29ubHkgbW9kZSBpbiB2MS4KICAgICAgZW52aXJvbm1lbnQ6IGF6dXJlbWw6bXktZW52OjEKICAgIHByb3BlcnRpZXM6CiAgICAgIEFaVVJFX01MX1BhdGhPbkNvbXB1dGVfaW5wdXRfZGF0YTogIi90bXAvdGVzdCIKCiAgbm9kZTI6ICAjIGlubGluZSBpbXBvcnQgam9iIHdpdGggcHJvcGVydGllcwogICAgdHlwZTogaW1wb3J0CiAgICBzb3VyY2U6CiAgICAgIHR5cGU6IGF6dXJlc3FsZGIKICAgICAgcXVlcnk6ID4tCiAgICAgICAgc2VsZWN0ICogZnJvbSBSRUdJT04KICAgICAgY29ubmVjdGlvbjogYXp1cmVtbDpteV91c2VybmFtZV9wYXNzd29yZAogICAgb3V0cHV0OgogICAgICB0eXBlOiBtbHRhYmxlCiAgICAgIHBhdGg6IGF6dXJlbWw6Ly9kYXRhc3RvcmVzL3dvcmtzcGFjZWJsb2JzdG9yZS9wYXRocy9vdXRwdXRfZGlyLwogICAgcHJvcGVydGllczoKICAgICAgQVpVUkVfTUxfUGF0aE9uQ29tcHV0ZV9vdXRwdXQ6ICIvdG1wL3Rlc3QiCgogIG5vZGUzOiAgIyBpbmxpbmUgc3Bhcmsgam9iIHdpdGggcHJvcGVydGllcwogICAgdHlwZTogc3BhcmsKICAgIGlucHV0czoKICAgICAgdGVzdDE6ICR7e3BhcmVudC5pbnB1dHMuaW5wdXRfZGF0YX19CiAgICAgIGZpbGVfaW5wdXQyOiAke3twYXJlbnQuaW5wdXRzLmlucHV0X2RhdGF9fQogICAgY29kZTogLi4vZHNsX3BpcGVsaW5lL3NwYXJrX2pvYl9pbl9waXBlbGluZS9zcmMKICAgIGVudHJ5OgogICAgICBmaWxlOiBlbnRyeS5weSAjIGZpbGUgcGF0aCBvZiB0aGUgZW50cnkgZmlsZSByZWxhdGl2ZSB0byB0aGUgY29kZSByb290IGZvbGRlcgogICAgcHlfZmlsZXM6CiAgICAgIC0gdXRpbHMuemlwCiAgICBqYXJzOgogICAgICAtIHNjYWxhcHJvai5qYXIKICAgIGZpbGVzOgogICAgICAtIG15X2ZpbGVzLnR4dAogICAgYXJnczogPi0KICAgICAgLS1maWxlX2lucHV0MSAke3tpbnB1dHMudGVzdDF9fQogICAgICAtLWZpbGVfaW5wdXQyICR7e2lucHV0cy5maWxlX2lucHV0Mn19CiAgICAgIC0tb3V0cHV0ICR7e291dHB1dHMub3V0cHV0fX0KICAgIGNvbXB1dGU6IGF6dXJlbWw6cmV6YXMtc3luYXBzZS0xMAogICAgY29uZjoKICAgICAgc3BhcmsuZHJpdmVyLmNvcmVzOiAyCiAgICAgIHNwYXJrLmRyaXZlci5tZW1vcnk6ICIxZyIKICAgICAgc3BhcmsuZXhlY3V0b3IuY29yZXM6IDEKICAgICAgc3BhcmsuZXhlY3V0b3IubWVtb3J5OiAiMWciCiAgICAgIHNwYXJrLmV4ZWN1dG9yLmluc3RhbmNlczogMQogICAgcHJvcGVydGllczoKICAgICAgQVpVUkVfTUxfUGF0aE9uQ29tcHV0ZV9pbnB1dF9kYXRhOiAiL3RtcC90ZXN0IgoKICBub2RlNDogICMgaW5saW5lIGF1dG9tbCBqb2Igd2l0aCBwcm9wZXJ0aWVzCiAgICB0eXBlOiBhdXRvbWwKICAgIHRhc2s6IHRleHRfbmVyCiAgICBsb2dfdmVyYm9zaXR5OiBpbmZvCiAgICBwcmltYXJ5X21ldHJpYzogYWNjdXJhY3kKICAgIGxpbWl0czoKICAgICAgbWF4X3RyaWFsczogMQogICAgICB0aW1lb3V0X21pbnV0ZXM6IDYwCiAgICB0cmFpbmluZ19kYXRhOiAke3twYXJlbnQuaW5wdXRzLnRleHRfbmVyX3RyYWluaW5nX2RhdGF9fQogICAgdmFsaWRhdGlvbl9kYXRhOiAke3twYXJlbnQuaW5wdXRzLnRleHRfbmVyX3ZhbGlkYXRpb25fZGF0YX19CiAgICBwcm9wZXJ0aWVzOgogICAgICBBWlVSRV9NTF9QYXRoT25Db21wdXRlX3RyYWluaW5nX2RhdGE6ICIvdG1wL3Rlc3QiCgogIG5vZGU1OiAgIyBpbmxpbmUgc3dlZXAgam9iIHdpdGggcHJvcGVydGllcwogICAgdHlwZTogc3dlZXAKICAgIHNlYXJjaF9zcGFjZToKICAgICAgY29tcG9uZW50X2luX251bWJlcjoKICAgICAgICB0eXBlOiBjaG9pY2UKICAgICAgICB2YWx1ZXM6CiAgICAgICAgICAtIDI1CiAgICAgICAgICAtIDM1CiAgICBsaW1pdHM6CiAgICAgIG1heF90b3RhbF90cmlhbHM6IDMKICAgIHNhbXBsaW5nX2FsZ29yaXRobTogcmFuZG9tCiAgICBvYmplY3RpdmU6CiAgICAgIGdvYWw6IG1heGltaXplCiAgICAgIHByaW1hcnlfbWV0cmljOiBhY2N1cmFjeQogICAgdHJpYWw6IGF6dXJlbWw6bWljcm9zb2Z0c2FtcGxlc2NvbW1hbmRjb21wb25lbnRiYXNpY19ub3BhdGhzX3Rlc3Q6MQogICAgcHJvcGVydGllczoKICAgICAgQVpVUkVfTUxfUGF0aE9uQ29tcHV0ZV9pbnB1dDogIi90bXAvdGVzdCIKCiAgbm9kZTY6ICAjIHBhcmFsbGVsIG5vZGUgd2l0aCBwcm9wZXJ0aWVzIGFzIGEgdHlwaWNhbCBpbXBsZW1lbnQgb2YgYmFzZSBub2RlLgogICAgdHlwZTogcGFyYWxsZWwKICAgIGNvbXB1dGU6IGF6dXJlbWw6Y3B1LWNsdXN0ZXIKICAgIGNvbXBvbmVudDogLi4vY29tcG9uZW50cy9wYXJhbGxlbF9jb21wb25lbnRfd2l0aF9maWxlX2lucHV0LnltbAogICAgaW5wdXRzOgogICAgICBqb2JfZGF0YV9wYXRoOiAke3twYXJlbnQuaW5wdXRzLnBpcGVsaW5lX2pvYl9kYXRhX3BhdGh9fQogICAgb3V0cHV0czoKICAgICAgam9iX291dHB1dF9wYXRoOgogICAgbWluaV9iYXRjaF9zaXplOiAiMSIKICAgIG1pbmlfYmF0Y2hfZXJyb3JfdGhyZXNob2xkOiAxCiAgICBtYXhfY29uY3VycmVuY3lfcGVyX2luc3RhbmNlOiAxCiAgICBwcm9wZXJ0aWVzOgogICAgICBBWlVSRV9NTF9QYXRoT25Db21wdXRlX2pvYl9kYXRhX3BhdGg6ICIvdG1wL3Rlc3QiCgojIENvbW1lbnQgdGhlc2UgbGluZXMgb3V0IGFzIGludGVybmFsIG5vZGUgaXMgbm90IHdlbGwgc3VwcG9ydGVkIGluIHlhbWwgbm93LgojICBub2RlNzogICMgaW50ZXJuYWwgY29tbWFuZCBub2RlIHdpdGggcHJvcGVydGllcyBhcyBhIHR5cGljYWwgaW1wbGVtZW50IG9mIGludGVybmFsIGJhc2Ugbm9kZS4KIyAgICB0eXBlOiBDb21tYW5kQ29tcG9uZW50CiMgICAgY29tcHV0ZTogYXp1cmVtbDpjcHUtY2x1c3RlcgojICAgIGNvbXBvbmVudDogLi4vaW50ZXJuYWwvaGVsbG93b3JsZF9jb21wb25lbnRfY29tbWFuZC55bWwKIyAgICBpbnB1dHM6CiMgICAgICB0cmFpbmluZ19kYXRhOiAke3twYXJlbnQuaW5wdXRzLmlucHV0X2RhdGF9fQojICAgICAgbWF4X2Vwb2NoczogMTAKIyAgICAgIGxlYXJuaW5nX3JhdGU6IDAuMDEKIyAgICBwcm9wZXJ0aWVzOgojICAgICAgQVpVUkVfTUxfUGF0aE9uQ29tcHV0ZV9qb2JfdHJhaW5pbmdfZGF0YTogIi90bXAvdGVzdCIKCiAgbm9kZTg6ICAjIHBpcGVsaW5lIG5vZGUgd2l0aCBwcm9wZXJ0aWVzCiAgICB0eXBlOiBwaXBlbGluZQogICAgaW5wdXRzOgogICAgICBjb21wb25lbnRfaW5fbnVtYmVyOiAxMQogICAgICBjb21wb25lbnRfaW5fcGF0aDogJHt7cGFyZW50LmlucHV0cy5pbnB1dF9kYXRhfX0KCiAgICBjb21wb25lbnQ6IC4uL2NvbXBvbmVudHMvaGVsbG93b3JsZF9waXBlbGluZV9jb21wb25lbnQueW1sCiAgICBwcm9wZXJ0aWVzOgogICAgICBBWlVSRV9NTF9QYXRoT25Db21wdXRlX2pvYl9jb21wb25lbnRfaW5fcGF0aDogIi90bXAvdGVzdCIK", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "Q1Xa0/m6sShGFUrjsd7wjg==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F97A5529E\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "uC0ezM\u002Bnul4=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/ipp-component/train_wrapper.py", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "4540", - "Content-MD5": "US6XLJGM3Tu1l7QVonFVqA==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "aW1wb3J0IGFyZ3BhcnNlCmltcG9ydCBqc29uCmltcG9ydCBvcwppbXBvcnQgc2h1dGlsCmltcG9ydCBzeXMKCmZyb20gcmNhbGwuYXp1cmVtbCBpbXBvcnQgc3RhcnRfZ3B0M19ydW4KCgpkZWYgZ2V0X25fcHJvYmxlbXMoY29uZmlnX2pzb25fcGF0aCk6CiAgICBwYXRoID0gb3MucGF0aC5qb2luKGNvbmZpZ19qc29uX3BhdGgsICJjb25maWcuanNvbiIpCiAgICB3aXRoIG9wZW4ocGF0aCwgInIiKSBhcyBmOgogICAgICAgIGNvbmZpZyA9IGpzb24ubG9hZChmKQoKICAgIHJldHVybiBjb25maWdbIm5fcHJvYmxlbXMiXVsidHJhaW4iXQoKCmlmIF9fbmFtZV9fID09ICJfX21haW5fXyI6CiAgICByYW5rID0gb3MuZW52aXJvblsiT01QSV9DT01NX1dPUkxEX1JBTksiXQogICAgbm9kZV9jb3VudCA9IG9zLmVudmlyb25bIkFaVVJFTUxfUEFSQU1FVEVSX05vZGVfQ291bnQiXQogICAgcHJvY2Vzc2VzX3Blcl9ub2RlID0gb3MuZW52aXJvblsiQVpVUkVNTF9QQVJBTUVURVJfTXBpX1Byb2Nlc3NfQ291bnRfUGVyX05vZGUiXQogICAgcHJpbnQoIm5vZGUgY291bnQge30sIHByb2Nlc3NlcyB7fSIuZm9ybWF0KG5vZGVfY291bnQsIHByb2Nlc3Nlc19wZXJfbm9kZSkpCgogICAgcGFyc2VyID0gYXJncGFyc2UuQXJndW1lbnRQYXJzZXIoKQogICAgcGFyc2VyLmFkZF9hcmd1bWVudCgiLS1vdXRwdXRfbW9kZWwiKQogICAgcGFyc2VyLmFkZF9hcmd1bWVudCgiLS1pbnB1dF9kYXRhc2V0IikKICAgIHBhcnNlci5hZGRfYXJndW1lbnQoIi0tYmFzZV9tb2RlbCIpCiAgICBwYXJzZXIuYWRkX2FyZ3VtZW50KCItLWxvcmFfd2VpZ2h0cyIpCiAgICBwYXJzZXIuYWRkX2FyZ3VtZW50KCItLXR1bmluZ190eXBlIikKICAgIHBhcnNlci5hZGRfYXJndW1lbnQoIi0tZW5naW5lIikKICAgIHBhcnNlci5hZGRfYXJndW1lbnQoIi0tbl9lcG9jaHMiLCB0eXBlPWludCkKICAgIHBhcnNlci5hZGRfYXJndW1lbnQoIi0tYmF0Y2hfc2l6ZSIsIHR5cGU9aW50KQogICAgcGFyc2VyLmFkZF9hcmd1bWVudCgiLS1sZWFybmluZ19yYXRlX211bHRpcGxpZXIiLCB0eXBlPWZsb2F0KQogICAgcGFyc2VyLmFkZF9hcmd1bWVudCgiLS11c2VfcGFja2luZyIpCiAgICBhcmdzLCB1bnBhcnNlZCA9IHBhcnNlci5wYXJzZV9rbm93bl9hcmdzKCkKCiAgICAjIHZhbGlkYXRpb24KICAgIGFzc2VydCBhcmdzLmJhc2VfbW9kZWwgaXMgbm90IE5vbmUKICAgIGFzc2VydCBhcmdzLm91dHB1dF9tb2RlbCBpcyBub3QgTm9uZQoKICAgIHRvdGFsZ3B1cyA9IGludChub2RlX2NvdW50KSAqIGludChwcm9jZXNzZXNfcGVyX25vZGUpCiAgICBwaXBlX2RlcHRoID0gaW50KG5vZGVfY291bnQpCiAgICBuX3NoYXJkcyA9IGludCh0b3RhbGdwdXMgLyBwaXBlX2RlcHRoKQoKICAgICMgcGlwZV9kZXB0aCA9IGludChub2RlX2NvdW50KSAqIGludChwcm9jZXNzZXNfcGVyX25vZGUpCiAgICBhc3NlcnQgOTYgJSBwaXBlX2RlcHRoID09IDAKCiAgICBuX3Byb2JsZW1zID0gZ2V0X25fcHJvYmxlbXMoYXJncy5pbnB1dF9kYXRhc2V0KQogICAgbWF4X3RvdGFsX3N0ZXBzID0gKGludChuX3Byb2JsZW1zKSAqIGFyZ3Mubl9lcG9jaHMpIC8gYXJncy5iYXRjaF9zaXplCiAgICBhc3NlcnQgbWF4X3RvdGFsX3N0ZXBzID4gMAoKICAgIGVuY29kaW5nX3BhdGggPSBhcmdzLmJhc2VfbW9kZWwgKyAiL2VuY29kaW5nIgogICAgYmFzZV9tb2RlbF9wYXRoID0gYXJncy5iYXNlX21vZGVsICsgIi8yMDBiX3YyIgoKICAgIGFyZ3VtZW50cyA9IFsKICAgICAgICAiLS1ocHMiLAogICAgICAgICJuZXN0LDIwMGJfdjIsZmluZXR1bmVfdjMsYXJjaF92MyIsCiAgICAgICAgIi0tbl9zaGFyZHMiLAogICAgICAgIG5fc2hhcmRzLAogICAgICAgICItLXN0ZXBzX3Blcl9zYXZlIiwKICAgICAgICA1MDAsCiAgICAgICAgIi0tc3RlcHNfcGVyX2V2YWwiLAogICAgICAgIDIwLAogICAgICAgICItLWxyX3dhcm11cF90b2tlbnMiLAogICAgICAgIDI1MDAwMCwKICAgICAgICAiLS1hbm5lYWxfbHJfdG9femVybyIsCiAgICAgICAgIi0tc2VlZCIsCiAgICAgICAgMSwKICAgICAgICAiLS1lbmNvZGluZ19iYXNlX3BhdGgiLAogICAgICAgIGVuY29kaW5nX3BhdGgsCiAgICAgICAgIi0tc25hcHNob3QiLAogICAgICAgIGJhc2VfbW9kZWxfcGF0aCwKICAgICAgICAiLS1nY3Nfcm9vdF9sb2dkaXIiLAogICAgICAgIGFyZ3Mub3V0cHV0X21vZGVsICsgIi9nY3Nfcm9vdF9sb2dkaXIiLAogICAgICAgICItLWdjc19iYWNrdXBfcm9vdCIsCiAgICAgICAgYXJncy5vdXRwdXRfbW9kZWwgKyAiL2djc19iYWNrdXBfbG9nZGlyIiwKICAgICAgICAiLS1uYW1lIiwKICAgICAgICAiYW1sIiwKICAgIF0KCiAgICBwcmludCgicGlwZSBkZXB0aCBpcyAiLCBwaXBlX2RlcHRoKQogICAgaWYgYXJncy50dW5pbmdfdHlwZSA9PSAiZmluZV90dW5pbmciOgogICAgICAgIHByaW50KCJVc2UgZ3B0LTMgcmF3IikKICAgICAgICBhcmd1bWVudHMgKz0gWwogICAgICAgICAgICAiLS1waXBlX2RlcHRoIiwKICAgICAgICAgICAgcGlwZV9kZXB0aCwKICAgICAgICAgICAgIi0tYXR0bl9sb3JhX2RpbSIsCiAgICAgICAgICAgIDAsCiAgICAgICAgXQogICAgZWxpZiBhcmdzLnR1bmluZ190eXBlID09ICJsb3JhIjoKICAgICAgICBwcmludCgiVXNlIGdwdC0zIGxvcmEiKQogICAgICAgIGFyZ3VtZW50cyArPSBbCiAgICAgICAgICAgICItLXBpcGVfZGVwdGgiLAogICAgICAgICAgICBwaXBlX2RlcHRoLAogICAgICAgICAgICAiLS1hdHRuX2xvcmFfZGltIiwKICAgICAgICAgICAgMzIsCiAgICAgICAgICAgICItLW5fY3R4IiwKICAgICAgICAgICAgMjU2LAogICAgICAgICAgICAiLS1tYXhfbl9jdHgiLAogICAgICAgICAgICAyNTYsCiAgICAgICAgICAgICItLWRlZGljYXRlZF91bmVtYmVkIiwKICAgICAgICAgICAgRmFsc2UsCiAgICAgICAgXQogICAgICAgIGlmIGFyZ3MubG9yYV93ZWlnaHRzOgogICAgICAgICAgICBwcmludCgiVXNlIHByb3ZpZGVkIG1vZGVsIHNuYXBzaG90IikKICAgICAgICAgICAgYXJndW1lbnRzICs9IFsiLS1zbmFwc2hvdF9sb3JhIiwgYXJncy5sb3JhX3dlaWdodHNdCgogICAgaWYgYXJncy5uX2Vwb2NoczoKICAgICAgICBwcmludCgibWF4X2Vwb2NocyIsIGFyZ3Mubl9lcG9jaHMpCiAgICAgICAgYXJndW1lbnRzICs9IFsiLS1tYXhfZXBvY2hzIiwgYXJncy5uX2Vwb2Noc10KCiAgICBpZiBhcmdzLmJhdGNoX3NpemU6CiAgICAgICAgcHJpbnQoImV4YW1wbGVzX3Blcl9nbG9iYWxfYmF0Y2giLCBhcmdzLmJhdGNoX3NpemUpCiAgICAgICAgYXJndW1lbnRzICs9IFsiLS1leGFtcGxlc19wZXJfZ2xvYmFsX2JhdGNoIiwgYXJncy5iYXRjaF9zaXplXQogICAgICAgIGFyZ3VtZW50cyArPSBbIi0tZXZhbF9leGFtcGxlc19wZXJfZ2xvYmFsX2JhdGNoIiwgMjAgKiBhcmdzLmJhdGNoX3NpemVdCgogICAgaWYgYXJncy5sZWFybmluZ19yYXRlX211bHRpcGxpZXI6CiAgICAgICAgcHJpbnQoImxyIiwgYXJncy5sZWFybmluZ19yYXRlX211bHRpcGxpZXIpCiAgICAgICAgYXJndW1lbnRzICs9IFsiLS1sciIsIGFyZ3MubGVhcm5pbmdfcmF0ZV9tdWx0aXBsaWVyXQoKICAgIGlmIGFyZ3MudXNlX3BhY2tpbmcgPT0gIlRydWUiOgogICAgICAgIGFyZ3VtZW50cyArPSBbIi0tZGF0YXNldF9ocGFyYW1zIiwgJ3sicGFja19jb250ZXh0IjpUcnVlfSddCgogICAgcHJpbnQoImFyZ3VtZW50cyIsIGFyZ3VtZW50cykKICAgIGZvciBhcmcgaW4gYXJndW1lbnRzOgogICAgICAgIHN5cy5hcmd2LmFwcGVuZChzdHIoYXJnKSkKCiAgICAjIHJlbW92ZSB1bnVzZWQgYXJncwogICAgcmVtb3ZlX2xpc3QgPSBbCiAgICAgICAgIi0tb3V0cHV0X21vZGVsIiwKICAgICAgICAiLS1iYXNlX21vZGVsIiwKICAgICAgICAiLS1sb3JhX3dlaWdodHMiLAogICAgICAgICItLXR1bmluZ190eXBlIiwKICAgICAgICAiLS1lbmdpbmUiLAogICAgICAgICItLW5fZXBvY2hzIiwKICAgICAgICAiLS1iYXRjaF9zaXplIiwKICAgICAgICAiLS1sZWFybmluZ19yYXRlX211bHRpcGxpZXIiLAogICAgICAgICItLXVzZV9wYWNraW5nIiwKICAgIF0KICAgIGZvciBhcmd1bWVudCBpbiByZW1vdmVfbGlzdDoKICAgICAgICBpZiBhcmd1bWVudCBpbiBzeXMuYXJndjoKICAgICAgICAgICAgaWR4ID0gc3lzLmFyZ3YuaW5kZXgoYXJndW1lbnQpCiAgICAgICAgICAgIHN5cy5hcmd2LnBvcChpZHgpICAjIHJlbW92ZSBrZXkKICAgICAgICAgICAgc3lzLmFyZ3YucG9wKGlkeCkgICMgcmVtb3ZlIHZhbHVlCgogICAgc3RhcnRfZ3B0M19ydW4oKQoKICAgICMjIGNvcHkgYmFzZSB3ZWlnaHRzIGFuZCBlbmNvZGluZ3MgdG8gb3V0cHV0cwogICAgaWYgcmFuayA9PSAiMCI6CiAgICAgICAgdXBsb2FkX2RpciA9IGFyZ3Mub3V0cHV0X21vZGVsICsgIi9lbmNvZGluZyIKICAgICAgICBpZiBub3Qgb3MucGF0aC5leGlzdHModXBsb2FkX2Rpcik6CiAgICAgICAgICAgIHByaW50KCJVcGxvYWQgZW5jb2RpbmciKQogICAgICAgICAgICBzaHV0aWwuY29weXRyZWUoYXJncy5iYXNlX21vZGVsICsgIi9lbmNvZGluZyIsIHVwbG9hZF9kaXIpCg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "US6XLJGM3Tu1l7QVonFVqA==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F97A579B0\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "LwbFLmqeH7I=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/scope-component/convert2ss.script", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "227", - "Content-MD5": "\u002BCWeQqiTTZiMS76jgH4yLA==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "I0RFQ0xBUkUgT3V0cHV0X3N0cmVhbSBzdHJpbmcgPSBAQE91dHB1dF9TU1BhdGhAQDsKI0RFQ0xBUkUgSW5fRGF0YSBzdHJpbmcgPUAiQEBJbnB1dF9UZXh0RGF0YUBAIjsKClJhd0RhdGEgPSBFWFRSQUNUIEBARXh0cmFjdGlvbkNsYXVzZUBAIEZST00gQEluX0RhdGEKVVNJTkcgRGVmYXVsdFRleHRFeHRyYWN0b3IoKTsKCgpPVVRQVVQgUmF3RGF0YSBUTyBTU1RSRUFNIEBPdXRwdXRfc3RyZWFtOwo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "\u002BCWeQqiTTZiMS76jgH4yLA==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F97A5C7C2\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "Xo84bVHKTF8=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/ipp-component/spec.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "922", - "Content-MD5": "qm/WzvY9yl\u002BxyZzdLmxJ/w==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cDovL2F6dXJlbWwvc2RrLTEtNS9JbnRlbGxlY3R1YWxQcm9wZXJ0eVByb3RlY3RlZENvbXBvbmVudC5qc29uCiMgbWV0YSBkYXRhIG9mIHRoZSBJUC1Qcm90ZWN0ZWQgY29tcG9uZW50Cm5hbWU6IG1pY3Jvc29mdC5jb20uYXp1cmVtbC5ncHQzLmZpbmV0dW5lCnZlcnNpb246IDAuMC4yCmRpc3BsYXlfbmFtZTogR1BUMyBJUCBwcm90ZWN0ZWQgRmluZS10dW5lIHRyYWluaW5nCmlzX2RldGVybWluaXN0aWM6IFRydWUKdHlwZTogSW50ZWxsZWN0dWFsUHJvcGVydHlQcm90ZWN0ZWRDb21wb25lbnQKZGVzY3JpcHRpb246IEludGVsbGVjdHVhbCBQcm9wZXJ0eSBQcm90ZWN0ZWQgTW9kdWxlIGZvciBHUFQzIGZpbmUgdHVuZQp0YWdzOgogIGNvbnRhY3Q6IHh4eHh4eEBtaWNyb3NvZnQuY29tCgojIFNURVAgMS4gcmVmZXJlbmNlIGFuIGV4aXN0aW5nIGNvbXBvbmVudCB5YW1sLCB3aGljaCBpbXBsZW1lbnQgdGhlIGxvZ2ljCnJlZmVyZW5jZTogZmlsZTpncHQzZmluZXR1bmUuc3BlYy55YW1sCgojIFNURVAgMi4gRGVmaW5lIHRoZSAiSW50ZWxsZWN0dWFsIFByb3BlcnR5IFB1Ymxpc2hlciIgZm9yIHRoZSAiSVAtUHJvdGVjdGVkIiBjb21wb25lbnQKaW50ZWxsZWN0dWFsX3Byb3BlcnR5X3B1Ymxpc2hlcjogQ29udG9zbwoKIyBTVEVQIDMuIFNwZWNpZnkgIkludGVsbGVjdHVhbCBQcm9wZXJ0eSBQcm90ZWN0ZWQiIGlucHV0IGFuZCBvdXRwdXQgcG9ydHMsIG5vdCBsaXN0ZWQgcG9ydHMgYXJlIGlwLXByb3RlY3RlZAppbnRlbGxlY3R1YWxfcHJvcGVydHlfcHJvdGVjdGVkX2lucHV0czoKICAtIGlucHV0cy5iYXNlX21vZGVsCiAgLSBpbnB1dHMubG9yYV93ZWlnaHRzCmludGVsbGVjdHVhbF9wcm9wZXJ0eV9wcm90ZWN0ZWRfb3V0cHV0czoKICAtIG91dHB1dHMub3V0cHV0X21vZGVsX2NoZWNrcG9pbnRzCg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "qm/WzvY9yl\u002BxyZzdLmxJ/w==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F97A5A0B4\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "g\u002BbfCWh/rlQ=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/scope-component/component_spec.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "915", - "Content-MD5": "ZAH3/WG2u71wrX6Ja2MoFw==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL1Njb3BlQ29tcG9uZW50Lmpzb24KCm5hbWU6IGNvbnZlcnQyc3MKdmVyc2lvbjogMC4wLjEKZGlzcGxheV9uYW1lOiBDb252ZXJ0IFRleHQgdG8gU3RydWN0dXJlU3RyZWFtCgp0eXBlOiBTY29wZUNvbXBvbmVudAoKaXNfZGV0ZXJtaW5pc3RpYzogVHJ1ZQoKdGFnczoKICBvcmc6IGJpbmcKICBwcm9qZWN0OiByZWxldmFuY2UKCmRlc2NyaXB0aW9uOiBDb252ZXJ0IGFkbHMgdGVzdCBkYXRhIHRvIFNTIGZvcm1hdAoKaW5wdXRzOgogIFRleHREYXRhOgogICAgdHlwZTogW0FueUZpbGUsIEFueURpcmVjdG9yeV0KICAgIGRlc2NyaXB0aW9uOiB0ZXh0IGZpbGUgb24gQURMUyBzdG9yYWdlCiAgRXh0cmFjdGlvbkNsYXVzZToKICAgIHR5cGU6IHN0cmluZwogICAgZGVzY3JpcHRpb246IHRoZSBleHRyYWN0aW9uIGNsYXVzZSwgc29tZXRoaW5nIGxpa2UgImNvbHVtbjE6c3RyaW5nLCBjb2x1bW4yOmludCIKb3V0cHV0czoKICBTU1BhdGg6CiAgICB0eXBlOiBDb3Ntb3NTdHJ1Y3R1cmVkU3RyZWFtCiAgICBkZXNjcmlwdGlvbjogdGhlIGNvbnZlcnRlZCBzdHJ1Y3R1cmVkIHN0cmVhbQoKY29kZTogLi8KCnNjb3BlOgogIHNjcmlwdDogY29udmVydDJzcy5zY3JpcHQKICAjIHRvIHJlZmVyZW5jZSB0aGUgaW5wdXRzL291dHB1dHMgaW4geW91ciBzY3JpcHQKICAjIHlvdSBtdXN0IGRlZmluZSB0aGUgYXJndW1lbnQgbmFtZSBvZiB5b3VyIGludHB1cy9vdXRwdXRzIGluIGFyZ3Mgc2VjdGlvbgogIGFyZ3M6ID4tCiAgICBPdXRwdXRfU1NQYXRoIHtvdXRwdXRzLlNTUGF0aH0KICAgIElucHV0X1RleHREYXRhIHtpbnB1dHMuVGV4dERhdGF9CiAgICBFeHRyYWN0aW9uQ2xhdXNlIHtpbnB1dHMuRXh0cmFjdGlvbkNsYXVzZX0K", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "ZAH3/WG2u71wrX6Ja2MoFw==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F97A579B0\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "iG9jAkbtotk=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/hemera-component/component.loaded_from_rest.json", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "2111", - "Content-MD5": "fg6Sw2/hSLsRvJqiWdMLXQ==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "ewogICJkZXNjcmlwdGlvbiI6ICJBZHMgTFIgRE5OIFJhdyBLZXlzIER1bW15IHNhbXBsZS4iLAogICJ0YWdzIjogewogICAgImNhdGVnb3J5IjogIkNvbXBvbmVudCBUdXRvcmlhbCIsCiAgICAiY29udGFjdCI6ICJhbWxkZXNpZ25lckBtaWNyb3NvZnQuY29tIgogIH0sCiAgInZlcnNpb24iOiAiMC4wLjIiLAogICIkc2NoZW1hIjogImh0dHBzOi8vY29tcG9uZW50c2RrLmF6dXJlZWRnZS5uZXQvanNvbnNjaGVtYS9IZW1lcmFDb21wb25lbnQuanNvbiIsCiAgImRpc3BsYXlfbmFtZSI6ICJBZHMgTFIgRE5OIFJhdyBLZXlzIiwKICAiaXNfZGV0ZXJtaW5pc3RpYyI6IHRydWUsCiAgImlucHV0cyI6IHsKICAgICJUcmFpbmluZ0RhdGFEaXIiOiB7CiAgICAgICJ0eXBlIjogInBhdGgiLAogICAgICAib3B0aW9uYWwiOiB0cnVlLAogICAgICAiaXNfcmVzb3VyY2UiOiB0cnVlCiAgICB9LAogICAgIlZhbGlkYXRpb25EYXRhRGlyIjogewogICAgICAidHlwZSI6ICJwYXRoIiwKICAgICAgIm9wdGlvbmFsIjogdHJ1ZSwKICAgICAgImlzX3Jlc291cmNlIjogdHJ1ZQogICAgfSwKICAgICJJbml0aWFsTW9kZWxEaXIiOiB7CiAgICAgICJ0eXBlIjogInBhdGgiLAogICAgICAib3B0aW9uYWwiOiB0cnVlLAogICAgICAiaXNfcmVzb3VyY2UiOiB0cnVlCiAgICB9LAogICAgIllhcm5DbHVzdGVyIjogewogICAgICAidHlwZSI6ICJzdHJpbmciLAogICAgICAiZGVmYXVsdCI6ICJtdHByaW1lLWJuMi0wIgogICAgfSwKICAgICJKb2JRdWV1ZSI6IHsKICAgICAgInR5cGUiOiAic3RyaW5nIiwKICAgICAgImRlZmF1bHQiOiAiZGVmYXVsdCIKICAgIH0sCiAgICAiV29ya2VyQ291bnQiOiB7CiAgICAgICJ0eXBlIjogInN0cmluZyIsCiAgICAgICJkZWZhdWx0IjogIjIuMCIKICAgIH0sCiAgICAiQ3B1IjogewogICAgICAidHlwZSI6ICJzdHJpbmciLAogICAgICAiZGVmYXVsdCI6ICIyLjAiCiAgICB9LAogICAgIk1lbW9yeSI6IHsKICAgICAgInR5cGUiOiAic3RyaW5nIiwKICAgICAgImRlZmF1bHQiOiAiMTBnIgogICAgfSwKICAgICJIZGZzUm9vdERpciI6IHsKICAgICAgInR5cGUiOiAic3RyaW5nIiwKICAgICAgImRlZmF1bHQiOiAiL3Byb2plY3RzL2RlZmF1bHQvIgogICAgfSwKICAgICJDb3Ntb3NSb290RGlyIjogewogICAgICAidHlwZSI6ICJzdHJpbmciLAogICAgICAiZGVmYXVsdCI6ICJodHRwczovL2Nvc21vczA5Lm9zZGluZnJhLm5ldC9jb3Ntb3MvZHVtbXkvbG9jYWwvcm9vdC8iCiAgICB9CiAgfSwKICAib3V0cHV0cyI6IHsKICAgICJvdXRwdXQxIjogewogICAgICAidHlwZSI6ICJBbnlGaWxlIgogICAgfSwKICAgICJvdXRwdXQyIjogewogICAgICAidHlwZSI6ICJBbnlGaWxlIgogICAgfQogIH0sCiAgInR5cGUiOiAiSGVtZXJhQ29tcG9uZW50IiwKICAiY29tbWFuZCI6ICJydW4uYmF0IFstX1RyYWluaW5nRGF0YURpciB7aW5wdXRzLlRyYWluaW5nRGF0YURpcn1dIFstX1ZhbGlkYXRpb25EYXRhRGlyIHtpbnB1dHMuVmFsaWRhdGlvbkRhdGFEaXJ9XSBbLV9Jbml0aWFsTW9kZWxEaXIge2lucHV0cy5Jbml0aWFsTW9kZWxEaXJ9XSAtX0Nvc21vc1Jvb3REaXIge2lucHV0cy5Db3Ntb3NSb290RGlyfSAtX1BzQ291bnQgMCAlQ0xVU1RFUiU9e2lucHV0cy5ZYXJuQ2x1c3Rlcn0gLUpvYlF1ZXVlIHtpbnB1dHMuSm9iUXVldWV9IC1fV29ya2VyQ291bnQge2lucHV0cy5Xb3JrZXJDb3VudH0gLV9DcHUge2lucHV0cy5DcHV9IC1fTWVtb3J5IHtpbnB1dHMuTWVtb3J5fSAtX0hkZnNSb290RGlyIHtpbnB1dHMuSGRmc1Jvb3REaXJ9IC1fRXhwb3NlZFBvcnQgXCIzMjAwLTMyMTAsMzMwMC0zMzIxXCIgLV9Ob2RlTG9zdEJsb2NrZXIgLV9Vc2VQaHlzaWNhbElQIC1fU3luY1dvcmtlciAtX0VudHJhbmNlRmlsZU5hbWUgcnVuLnB5IC1fU3RhcnR1cEFyZ3VtZW50cyBcIlwiIC1fUHl0aG9uWmlwUGF0aCBcImh0dHBzOi8vZHVtbXkvZm9vL2Jhci56aXBcIiAtX01vZGVsT3V0cHV0RGlyIHtvdXRwdXRzLm91dHB1dDF9IC1fVmFsaWRhdGlvbk91dHB1dERpciB7b3V0cHV0cy5vdXRwdXQyfSIsCiAgImhlbWVyYSI6IHsKICAgICJyZWZfaWQiOiAiMWJkMTUyNWMtMDgyZS00NjUyLWE5YjItOWM2MDc4M2VjNTUxIgogIH0KfQo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "fg6Sw2/hSLsRvJqiWdMLXQ==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F97A615CF\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "gavG0eE4U8c=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/ls_command_component.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "234", - "Content-MD5": "UrxIkzZNuLtqksFOP/IPuw==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbgpuYW1lOiBsc19jb21tYW5kCmRpc3BsYXlfbmFtZTogTHMgQ29tbWFuZAp2ZXJzaW9uOiAwLjAuMQp0eXBlOiBDb21tYW5kQ29tcG9uZW50CmlzX2RldGVybWluaXN0aWM6IHRydWUKY29tbWFuZDogPi0KICBscwplbnZpcm9ubWVudDoKICBuYW1lOiBBenVyZU1MLURlc2lnbmVy", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "UrxIkzZNuLtqksFOP/IPuw==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F97A5C7C2\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "dVaj34\u002B0MGs=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/ls_command_component.loaded_from_rest.json", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "375", - "Content-MD5": "9taMO58glKO0w3yp/LHNtw==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "ewogICJ0YWdzIjoge30sCiAgInZlcnNpb24iOiAiMC4wLjEiLAogICIkc2NoZW1hIjogImh0dHBzOi8vY29tcG9uZW50c2RrLmF6dXJlZWRnZS5uZXQvanNvbnNjaGVtYS9Db21tYW5kQ29tcG9uZW50Lmpzb24iLAogICJkaXNwbGF5X25hbWUiOiAiTHMgQ29tbWFuZCIsCiAgImlzX2RldGVybWluaXN0aWMiOiB0cnVlLAogICJpbnB1dHMiOiB7fSwKICAib3V0cHV0cyI6IHt9LAogICJ0eXBlIjogIkNvbW1hbmRDb21wb25lbnQiLAogICJlbnZpcm9ubWVudCI6IHsKICAgICJvcyI6ICJMaW51eCIsCiAgICAibmFtZSI6ICJBenVyZU1MLURlc2lnbmVyIgogIH0sCiAgInN1Y2Nlc3NmdWxfcmV0dXJuX2NvZGUiOiAiWmVybyIsCiAgImNvbW1hbmQiOiAibHMiCn0K", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "9taMO58glKO0w3yp/LHNtw==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F97A997BC\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "g34Wfl24QMw=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/scope/convert2ss.script", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "226", - "Content-MD5": "CvM7SyD2EE7wM\u002BN12vDf3Q==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "I0RFQ0xBUkUgT3V0cHV0X3N0cmVhbSBzdHJpbmcgPSBAQE91dHB1dF9TU1BhdGhAQDsKI0RFQ0xBUkUgSW5fRGF0YSBzdHJpbmcgPUAiQEBJbnB1dF9UZXh0RGF0YUBAIjsKClJhd0RhdGEgPSBFWFRSQUNUIEBARXh0cmFjdGlvbkNsYXVzZUBAIEZST00gQEluX0RhdGEKVVNJTkcgRGVmYXVsdFRleHRFeHRyYWN0b3IoKTsKCk9VVFBVVCBSYXdEYXRhIFRPIFNTVFJFQU0gQE91dHB1dF9zdHJlYW07Cg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "CvM7SyD2EE7wM\u002BN12vDf3Q==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F97AB6C3B\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "YY2DpEi/zBQ=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/starlite-component/component_spec.loaded_from_rest.json", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1378", - "Content-MD5": "QZZ4ksHzXirVR6YT4PpEKg==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "ewogICJkZXNjcmlwdGlvbiI6ICJBbGxvd3MgdG8gZG93bmxvYWQgZmlsZXMgZnJvbSBTZWFyY2hHb2xkIHRvIGNvc21vcyBhbmQgZ2V0IHRoZWlyIHJldmlzaW9uIGluZm9ybWF0aW9uLiAnRmlsZUxpc3QnIGlucHV0IGlzIGEgZmlsZSB3aXRoIHNvdXJjZSBkZXBvdCBwYXRocywgb25lIHBlciBsaW5lLiIsCiAgInRhZ3MiOiB7CiAgICAiY2F0ZWdvcnkiOiAiQ29tcG9uZW50IFR1dG9yaWFsIiwKICAgICJjb250YWN0IjogImFtbGRlc2lnbmVyQG1pY3Jvc29mdC5jb20iCiAgfSwKICAidmVyc2lvbiI6ICIwLjAuMSIsCiAgIiRzY2hlbWEiOiAiaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL1N0YXJsaXRlQ29tcG9uZW50Lmpzb24iLAogICJkaXNwbGF5X25hbWUiOiAiU3RhcmxpdGUgU2VhcmNoR29sZCBHZXQgRmlsZXMiLAogICJpc19kZXRlcm1pbmlzdGljIjogdHJ1ZSwKICAiaW5wdXRzIjogewogICAgIkZpbGVMaXN0IjogewogICAgICAidHlwZSI6ICJBbnlGaWxlIgogICAgfSwKICAgICJVcGxvYWRUb0Nvc21vcyI6IHsKICAgICAgInR5cGUiOiAiZW51bSIsCiAgICAgICJkZWZhdWx0IjogIkZhbHNlIiwKICAgICAgImVudW0iOiBbCiAgICAgICAgIlRydWUiLAogICAgICAgICJGYWxzZSIKICAgICAgXQogICAgfSwKICAgICJSdW5JZCI6IHsKICAgICAgInR5cGUiOiAic3RyaW5nIiwKICAgICAgIm9wdGlvbmFsIjogdHJ1ZSwKICAgICAgImRlc2NyaXB0aW9uIjogImEgcGFyYW1ldGVyIHZhbHVlIgogICAgfSwKICAgICJGaWxlTGlzdEZpbGVOYW1lIjogewogICAgICAidHlwZSI6ICJzdHJpbmciLAogICAgICAiZGVmYXVsdCI6ICJcXFxcb3V0cHV0LnRzdiIKICAgIH0KICB9LAogICJvdXRwdXRzIjogewogICAgIkZpbGVzIjogewogICAgICAidHlwZSI6ICJBbnlEaXJlY3RvcnkiCiAgICB9LAogICAgIkNvc21vc1BhdGgiOiB7CiAgICAgICJ0eXBlIjogIkFueUZpbGUiCiAgICB9LAogICAgIlJlc3VsdEluZm8iOiB7CiAgICAgICJ0eXBlIjogIkFueUZpbGUiCiAgICB9CiAgfSwKICAidHlwZSI6ICJTdGFybGl0ZUNvbXBvbmVudCIsCiAgImNvbW1hbmQiOiAiU3RhcmxpdGUuQ2xvdWQuU291cmNlRGVwb3RHZXQuZXhlIC9VcGxvYWRUb0Nvc21vczp7aW5wdXRzLlVwbG9hZFRvQ29zbW9zfSAvRmlsZUxpc3Q6e2lucHV0cy5GaWxlTGlzdH17aW5wdXRzLkZpbGVMaXN0RmlsZU5hbWV9IC9GaWxlczp7b3V0cHV0cy5GaWxlc30gL0Nvc21vc1BhdGg6e291dHB1dHMuQ29zbW9zUGF0aH0gL1Jlc3VsdEluZm86e291dHB1dHMuUmVzdWx0SW5mb30gXCJcIiIsCiAgInN0YXJsaXRlIjogewogICAgInJlZl9pZCI6ICJiZDE0MGY0ZC03Nzc1LTQyNDYtYTc1Yy0xYzg2ZGY5NTM2ZmIiCiAgfQp9Cg==", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "QZZ4ksHzXirVR6YT4PpEKg==", - "Date": "Fri, 30 Sep 2022 02:58:02 GMT", - "ETag": "\u00220x8DAA28F97AEA012\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "zfHdkhbZpzM=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/starlite-component/component_spec.yaml", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "1193", - "Content-MD5": "P27tAGWij0pzhTcS9\u002BKvLQ==", - "Content-Type": "application/octet-stream", - "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-version": "2021-08-06" - }, - "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL1N0YXJsaXRlQ29tcG9uZW50Lmpzb24KbmFtZTogbWljcm9zb2Z0X2NvbV9henVyZW1sX3NhbXBsZXNfc3RhcmxpdGVfX3NlYXJjaF9nb2xkX2dldF9maWxlcwp2ZXJzaW9uOiAwLjAuMQpkaXNwbGF5X25hbWU6IFN0YXJsaXRlIFNlYXJjaEdvbGQgR2V0IEZpbGVzCnR5cGU6IFN0YXJsaXRlQ29tcG9uZW50CmRlc2NyaXB0aW9uOiBBbGxvd3MgdG8gZG93bmxvYWQgZmlsZXMgZnJvbSBTZWFyY2hHb2xkIHRvIGNvc21vcyBhbmQgZ2V0IHRoZWlyIHJldmlzaW9uIGluZm9ybWF0aW9uLiAnRmlsZUxpc3QnIGlucHV0IGlzIGEgZmlsZSB3aXRoIHNvdXJjZSBkZXBvdCBwYXRocywgb25lIHBlciBsaW5lLgp0YWdzOiB7Y2F0ZWdvcnk6IENvbXBvbmVudCBUdXRvcmlhbCwgY29udGFjdDogYW1sZGVzaWduZXJAbWljcm9zb2Z0LmNvbX0KaW5wdXRzOgogIFVwbG9hZFRvQ29zbW9zOgogICAgdHlwZTogZW51bQogICAgZW51bToKICAgIC0gdHJ1ZQogICAgLSBmYWxzZQogICAgZGVmYXVsdDogZmFsc2UKICAgIG9wdGlvbmFsOiBmYWxzZQogIEZpbGVMaXN0OgogICAgdHlwZTogQW55RmlsZQogICAgb3B0aW9uYWw6IGZhbHNlCiAgUnVuSWQ6CiAgICB0eXBlOiBzdHJpbmcKICAgIGRlc2NyaXB0aW9uOiBhIHBhcmFtZXRlciB2YWx1ZQogICAgb3B0aW9uYWw6IHRydWUKICBGaWxlTGlzdEZpbGVOYW1lOgogICAgdHlwZTogc3RyaW5nCiAgICBkZWZhdWx0OiBcXG91dHB1dC50c3YKICAgIG9wdGlvbmFsOiBmYWxzZQpvdXRwdXRzOgogIEZpbGVzOgogICAgdHlwZTogQW55RGlyZWN0b3J5CiAgQ29zbW9zUGF0aDoKICAgIHR5cGU6IEFueUZpbGUKICBSZXN1bHRJbmZvOgogICAgdHlwZTogQW55RmlsZQpjb21tYW5kOiA\u002BLQogIFN0YXJsaXRlLkNsb3VkLlNvdXJjZURlcG90R2V0LmV4ZSAvVXBsb2FkVG9Db3Ntb3M6e2lucHV0cy5VcGxvYWRUb0Nvc21vc30KICAvRmlsZUxpc3Q6e2lucHV0cy5GaWxlTGlzdH17aW5wdXRzLkZpbGVMaXN0RmlsZU5hbWV9CiAgL0ZpbGVzOntvdXRwdXRzLkZpbGVzfSAvQ29zbW9zUGF0aDp7b3V0cHV0cy5Db3Ntb3NQYXRofSAvUmVzdWx0SW5mbzp7b3V0cHV0cy5SZXN1bHRJbmZvfSAiIgpzdGFybGl0ZToKICByZWZfaWQ6IGJkMTQwZjRkLTc3NzUtNDI0Ni1hNzVjLTFjODZkZjk1MzZmYgo=", - "StatusCode": 201, - "ResponseHeaders": { - "Content-Length": "0", - "Content-MD5": "P27tAGWij0pzhTcS9\u002BKvLQ==", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F97A970B5\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-content-crc64": "QdhJN3pb86A=", - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/.gitattributes?comp=metadata", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/xml", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "0", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Fri, 30 Sep 2022 02:58:03 GMT", - "x-ms-meta-name": "000000000000000000000", - "x-ms-meta-upload_status": "completed", - "x-ms-meta-version": "1", - "x-ms-version": "2021-08-06" - }, - "RequestBody": null, - "StatusCode": 200, - "ResponseHeaders": { - "Content-Length": "0", - "Date": "Fri, 30 Sep 2022 02:58:03 GMT", - "ETag": "\u00220x8DAA28F97D27677\u0022", - "Last-Modified": "Fri, 30 Sep 2022 02:58:03 GMT", - "Server": [ - "Windows-Azure-Blob/1.0", - "Microsoft-HTTPAPI/2.0" - ], - "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-08-06" - }, - "ResponseBody": null - }, - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1?api-version=2022-05-01", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/json", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "297", - "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.13 (Windows-10-10.0.22621-SP0)" - }, - "RequestBody": { - "properties": { - "properties": { - "hash_sha256": "0000000000000", - "hash_version": "0000000000000" - }, - "isAnonymous": true, - "isArchived": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal" - } - }, - "StatusCode": 201, - "ResponseHeaders": { - "Cache-Control": "no-cache", - "Content-Length": "812", - "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 02:58:04 GMT", - "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1?api-version=2022-05-01", - "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-f53180862d7d60ee017c552469c9e7c9-027130b41acaf1b1-01\u0022", - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-01", - "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "518040a9-ad10-4d75-950f-8a75d7d729ed", - "x-ms-ratelimit-remaining-subscription-writes": "1198", - "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20220930T025805Z:518040a9-ad10-4d75-950f-8a75d7d729ed", - "x-request-time": "1.477" - }, - "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1", - "name": "1", - "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", - "properties": { - "description": null, - "tags": {}, - "properties": { - "hash_sha256": "0000000000000", - "hash_version": "0000000000000" - }, - "isArchived": false, - "isAnonymous": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal" - }, - "systemData": { - "createdAt": "2022-09-30T02:58:05.2528391\u002B00:00", - "createdBy": "Zhengfei Wang", - "createdByType": "User", - "lastModifiedAt": "2022-09-30T02:58:05.2528391\u002B00:00", - "lastModifiedBy": "Zhengfei Wang", - "lastModifiedByType": "User" - } - } - }, - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_930510325622/versions/0.0.1?api-version=2022-05-01", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/json", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "630", - "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.13 (Windows-10-10.0.22621-SP0)" - }, - "RequestBody": { - "properties": { - "properties": {}, - "tags": {}, - "isAnonymous": false, - "isArchived": false, - "componentSpec": { - "name": "test_930510325622", - "tags": {}, - "version": "0.0.1", - "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", - "display_name": "Ls Command", - "is_deterministic": true, - "inputs": {}, - "outputs": {}, - "type": "CommandComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1", - "environment": { - "os": "Linux", - "name": "AzureML-Designer" - }, - "command": "ls" - } - } - }, - "StatusCode": 429, - "ResponseHeaders": { - "Cache-Control": "no-cache", - "Connection": "close", - "Content-Length": "1116", - "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 02:58:05 GMT", - "Expires": "-1", - "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-01", - "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "e217441e-861c-4337-8c74-888b2090f659", - "x-ms-ratelimit-remaining-subscription-writes": "1197", - "x-ms-response-type": "error", - "x-ms-routing-request-id": "JAPANEAST:20220930T025806Z:e217441e-861c-4337-8c74-888b2090f659", - "x-request-time": "0.490" - }, - "ResponseBody": { - "error": { - "code": "UserError", - "message": "Received too many requests in a short amount of time. Retry again after 20 seconds.", - "details": [], - "additionalInfo": [ - { - "type": "ComponentName", - "info": { - "value": "managementfrontend" - } - }, - { - "type": "Correlation", - "info": { - "value": { - "operation": "96c0bb6a8a0cb21b313cb84d9582ede4", - "request": "b5d9afec6481a2ae" - } - } - }, - { - "type": "Environment", - "info": { - "value": "master" - } - }, - { - "type": "Location", - "info": { - "value": "westus2" - } - }, - { - "type": "Time", - "info": { - "value": "2022-09-30T02:58:06.6718595\u002B00:00" - } - }, - { - "type": "InnerError", - "info": { - "value": { - "code": "QuotaExceeded", - "innerError": { - "code": "TooManyRequests", - "innerError": null - } - } - } - } - ] - } - } - }, - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_930510325622/versions/0.0.1?api-version=2022-05-01", - "RequestMethod": "PUT", - "RequestHeaders": { - "Accept": "application/json", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Content-Length": "630", - "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.13 (Windows-10-10.0.22621-SP0)" - }, - "RequestBody": { - "properties": { - "properties": {}, - "tags": {}, - "isAnonymous": false, - "isArchived": false, - "componentSpec": { - "name": "test_930510325622", - "tags": {}, - "version": "0.0.1", - "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", - "display_name": "Ls Command", - "is_deterministic": true, - "inputs": {}, - "outputs": {}, - "type": "CommandComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1", - "environment": { - "os": "Linux", - "name": "AzureML-Designer" - }, - "command": "ls" - } - } - }, - "StatusCode": 201, - "ResponseHeaders": { - "Cache-Control": "no-cache", - "Content-Length": "1322", - "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 02:58:11 GMT", - "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_930510325622/versions/0.0.1?api-version=2022-05-01", - "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-f441c953a92bc317f79beb977c1fdf61-7fc69b2cfee524dd-01\u0022", - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", - "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "885c5658-02f3-4677-8edb-e9e07b5232a3", - "x-ms-ratelimit-remaining-subscription-writes": "1199", - "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20220930T025811Z:885c5658-02f3-4677-8edb-e9e07b5232a3", - "x-request-time": "2.905" - }, - "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_930510325622/versions/0.0.1", - "name": "0.0.1", - "type": "Microsoft.MachineLearningServices/workspaces/components/versions", - "properties": { - "description": null, - "tags": {}, - "properties": {}, - "isArchived": false, - "isAnonymous": false, - "componentSpec": { - "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", - "name": "test_930510325622", - "version": "0.0.1", - "display_name": "Ls Command", - "is_deterministic": "True", - "type": "CommandComponent", - "environment": { - "name": "AzureML-Designer", - "os": "Linux" - }, - "successful_return_code": "Zero", - "command": "ls", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1" - } - }, - "systemData": { - "createdAt": "2022-09-30T02:58:10.5758866\u002B00:00", - "createdBy": "Zhengfei Wang", - "createdByType": "User", - "lastModifiedAt": "2022-09-30T02:58:11.2143775\u002B00:00", - "lastModifiedBy": "Zhengfei Wang", - "lastModifiedByType": "User" - } - } - }, - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_930510325622/versions/0.0.1?api-version=2022-05-01", - "RequestMethod": "GET", - "RequestHeaders": { - "Accept": "application/json", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.13 (Windows-10-10.0.22621-SP0)" - }, - "RequestBody": null, - "StatusCode": 200, - "ResponseHeaders": { - "Cache-Control": "no-cache", - "Content-Encoding": "gzip", - "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 02:58:11 GMT", - "Expires": "-1", - "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-bd1e08886fc6acbcd4b3ae1c96ac35bf-1d5012e7a33bd018-01\u0022", - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Transfer-Encoding": "chunked", - "Vary": [ - "Accept-Encoding", - "Accept-Encoding" - ], - "x-aml-cluster": "vienna-test-westus2-02", - "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "c824e6d9-af07-4773-abe0-c93fde8407bf", - "x-ms-ratelimit-remaining-subscription-reads": "11987", - "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20220930T025812Z:c824e6d9-af07-4773-abe0-c93fde8407bf", - "x-request-time": "0.337" - }, - "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_930510325622/versions/0.0.1", - "name": "0.0.1", - "type": "Microsoft.MachineLearningServices/workspaces/components/versions", - "properties": { - "description": null, - "tags": {}, - "properties": {}, - "isArchived": false, - "isAnonymous": false, - "componentSpec": { - "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", - "name": "test_930510325622", - "version": "0.0.1", - "display_name": "Ls Command", - "is_deterministic": "True", - "type": "CommandComponent", - "environment": { - "name": "AzureML-Designer", - "os": "Linux" - }, - "successful_return_code": "Zero", - "command": "ls", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1" - } - }, - "systemData": { - "createdAt": "2022-09-30T02:58:10.5758866\u002B00:00", - "createdBy": "Zhengfei Wang", - "createdByType": "User", - "lastModifiedAt": "2022-09-30T02:58:11.2143775\u002B00:00", - "lastModifiedBy": "Zhengfei Wang", - "lastModifiedByType": "User" - } - } - } - ], - "Variables": { - "component_name": "test_930510325622" - } -} diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/scope-component/component_spec.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/scope-component/component_spec.yaml].json index 4b569a9c86f9..a8ec1ee86031 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/scope-component/component_spec.yaml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/scope-component/component_spec.yaml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:40 GMT", + "Date": "Mon, 10 Oct 2022 08:21:57 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-7ac7b3d9fb6d5c2ae9298850c1c0d3d9-449ef1b44d5c90a3-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-fc57dbaf77ccb7454ad29b5946a6ad2f-7b11e5d5c745eb72-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "da77128f-0c7e-4636-a6a2-dfd7d1c95495", + "x-ms-correlation-request-id": "50ee7283-bdba-4d16-b29b-e1823f1918fb", "x-ms-ratelimit-remaining-subscription-reads": "11993", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151441Z:da77128f-0c7e-4636-a6a2-dfd7d1c95495", - "x-request-time": "0.089" + "x-ms-routing-request-id": "JAPANEAST:20221010T082157Z:50ee7283-bdba-4d16-b29b-e1823f1918fb", + "x-request-time": "0.114" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sawcdivl5vo3cem", - "containerName": "azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-19T00:10:19.4497254\u002B00:00", + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-19T00:10:20.0957203\u002B00:00", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:40 GMT", + "Date": "Mon, 10 Oct 2022 08:21:58 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-d4344e16295382bbade211f3a83dfb12-5d44e3192706b1f7-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-4e761931712173c852a1dffe5226bc88-5fd7c87ee3dfd5db-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "7078494b-84be-4c1c-975f-4e902d687b15", + "x-ms-correlation-request-id": "e2d924d1-58ed-455b-978e-308cf7bc63a5", "x-ms-ratelimit-remaining-subscription-writes": "1196", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151441Z:7078494b-84be-4c1c-975f-4e902d687b15", - "x-request-time": "0.102" + "x-ms-routing-request-id": "JAPANEAST:20221010T082158Z:e2d924d1-58ed-455b-978e-308cf7bc63a5", + "x-request-time": "0.089" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,26 +101,26 @@ } }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/scope-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/scope-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:14:41 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 08:21:58 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Accept-Ranges": "bytes", - "Content-Length": "1019", - "Content-MD5": "i97q7IVRlx2GMLweS1KokQ==", + "Content-Length": "953", + "Content-MD5": "nzd\u002BWLaPsJr2Y3ztm3VoLA==", "Content-Type": "application/octet-stream", - "Date": "Mon, 19 Sep 2022 15:14:41 GMT", - "ETag": "\u00220x8DA99D377064E0F\u0022", - "Last-Modified": "Mon, 19 Sep 2022 00:11:14 GMT", + "Date": "Mon, 10 Oct 2022 08:21:58 GMT", + "ETag": "\u00220x8DAAA6EF7A050E5\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:24:40 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 19 Sep 2022 00:11:13 GMT", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:24:40 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "4b4bf3c2-e55f-4063-847f-199c6dad33e2", + "x-ms-meta-name": "4e34db7e-7e36-4abd-a6c8-3d7fd02cc1c2", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/az-ml-artifacts/00000000000000000000000000000000/scope-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/scope-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:14:41 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 08:21:58 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 19 Sep 2022 15:14:41 GMT", + "Date": "Mon, 10 Oct 2022 08:21:58 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4b4bf3c2-e55f-4063-847f-199c6dad33e2/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4e34db7e-7e36-4abd-a6c8-3d7fd02cc1c2/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "304", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/scope-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/scope-component" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:41 GMT", + "Date": "Mon, 10 Oct 2022 08:21:59 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-fec257cee326207fa447c776497d1775-2b4a6e6c3469670b-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-f6252ed8956eaf87b54dc19d49a4e3e4-8bfbeb74b1d7285e-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "91ec91bf-2814-45e0-8890-91887cb645d3", + "x-ms-correlation-request-id": "71f9ff72-c865-42f1-9b24-2b8474918648", "x-ms-ratelimit-remaining-subscription-writes": "1193", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151442Z:91ec91bf-2814-45e0-8890-91887cb645d3", - "x-request-time": "0.085" + "x-ms-routing-request-id": "JAPANEAST:20221010T082159Z:71f9ff72-c865-42f1-9b24-2b8474918648", + "x-request-time": "0.242" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4b4bf3c2-e55f-4063-847f-199c6dad33e2/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4e34db7e-7e36-4abd-a6c8-3d7fd02cc1c2/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,20 +225,20 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/scope-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/scope-component" }, "systemData": { - "createdAt": "2022-09-19T00:11:14.7337825\u002B00:00", - "createdBy": "10832f61-6ea1-44eb-9622-85f30271eec4", - "createdByType": "Application", - "lastModifiedAt": "2022-09-19T15:14:42.0287013\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:24:41.2456668\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T08:21:59.3568258\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_447212415404/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_412496731883/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "1242", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -259,7 +259,7 @@ "isAnonymous": false, "isArchived": false, "componentSpec": { - "name": "test_447212415404", + "name": "test_412496731883", "description": "Convert adls test data to SS format", "tags": { "org": "bing", @@ -289,7 +289,7 @@ } }, "type": "ScopeComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4b4bf3c2-e55f-4063-847f-199c6dad33e2/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4e34db7e-7e36-4abd-a6c8-3d7fd02cc1c2/versions/1", "scope": { "script": "convert2ss.script", "args": "Output_SSPath {outputs.SSPath} Input_TextData {inputs.TextData} ExtractionClause {inputs.ExtractionClause}" @@ -300,25 +300,25 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2205", + "Content-Length": "2203", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:42 GMT", + "Date": "Mon, 10 Oct 2022 08:22:01 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_447212415404/versions/0.0.1?api-version=2022-05-01", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_412496731883/versions/0.0.1?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-aabc4368fb7ef984f292f0a409aa4985-8ec568d7c7c165f0-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-8fa3863c8076166a150a027ccdedc897-1dd4cbfe717a60c3-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "c708220a-c341-41e6-ba33-01cba9abfa1f", + "x-ms-correlation-request-id": "f554bf0f-d495-498c-8e60-2f84c5b5963d", "x-ms-ratelimit-remaining-subscription-writes": "1192", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151442Z:c708220a-c341-41e6-ba33-01cba9abfa1f", - "x-request-time": "0.623" + "x-ms-routing-request-id": "JAPANEAST:20221010T082201Z:f554bf0f-d495-498c-8e60-2f84c5b5963d", + "x-request-time": "1.664" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_447212415404/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_412496731883/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -332,7 +332,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/ScopeComponent.json", - "name": "test_447212415404", + "name": "test_412496731883", "version": "0.0.1", "display_name": "Convert Text to StructureStream", "is_deterministic": "True", @@ -368,27 +368,27 @@ "args": "Input_TextData {inputs.TextData} Output_SSPath {outputs.SSPath} ExtractionClause {inputs.ExtractionClause}", "script": "convert2ss.script" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4b4bf3c2-e55f-4063-847f-199c6dad33e2/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4e34db7e-7e36-4abd-a6c8-3d7fd02cc1c2/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:14:42.5014067\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T08:22:00.4438863\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:14:42.7115958\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T08:22:01.0776662\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_447212415404/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_412496731883/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "GET", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -396,27 +396,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:42 GMT", + "Date": "Mon, 10 Oct 2022 08:22:02 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-7c259328b93d7531b64ed7990d2eaeec-8a15fb8b7fddfe9b-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-e33b00dff137686bbcc836591c84c917-f486e99590ad3c9c-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "016978c7-7334-451b-a02c-b379df7ea96c", + "x-ms-correlation-request-id": "6aaa885d-7d54-4758-8a80-9d95b1331de2", "x-ms-ratelimit-remaining-subscription-reads": "11992", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151443Z:016978c7-7334-451b-a02c-b379df7ea96c", - "x-request-time": "0.126" + "x-ms-routing-request-id": "JAPANEAST:20221010T082202Z:6aaa885d-7d54-4758-8a80-9d95b1331de2", + "x-request-time": "0.332" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_447212415404/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_412496731883/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -430,7 +430,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/ScopeComponent.json", - "name": "test_447212415404", + "name": "test_412496731883", "version": "0.0.1", "display_name": "Convert Text to StructureStream", "is_deterministic": "True", @@ -466,21 +466,21 @@ "args": "Input_TextData {inputs.TextData} Output_SSPath {outputs.SSPath} ExtractionClause {inputs.ExtractionClause}", "script": "convert2ss.script" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4b4bf3c2-e55f-4063-847f-199c6dad33e2/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4e34db7e-7e36-4abd-a6c8-3d7fd02cc1c2/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:14:42.5014067\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T08:22:00.4438863\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:14:42.7115958\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T08:22:01.0776662\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } } ], "Variables": { - "component_name": "test_447212415404" + "component_name": "test_412496731883" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/starlite-component/component_spec.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/starlite-component/component_spec.yaml].json index b59260d7315f..21145e43394a 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/starlite-component/component_spec.yaml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_create[tests/test_configs/internal/starlite-component/component_spec.yaml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:14:59 GMT", + "Date": "Mon, 10 Oct 2022 08:22:27 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-b38a6181caff95c9b6aca074eee47205-d151ef952a2e0dc9-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-4f4314081412d110f2b78330ce3a9ddc-4e8f991430c8de0c-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "268ba05a-4017-470f-be23-428ffd195c65", + "x-ms-correlation-request-id": "91715e5c-070c-40ea-a0ba-28d87dba2ee8", "x-ms-ratelimit-remaining-subscription-reads": "11985", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151459Z:268ba05a-4017-470f-be23-428ffd195c65", - "x-request-time": "0.091" + "x-ms-routing-request-id": "JAPANEAST:20221010T082227Z:91715e5c-070c-40ea-a0ba-28d87dba2ee8", + "x-request-time": "0.101" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sawcdivl5vo3cem", - "containerName": "azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-19T00:10:19.4497254\u002B00:00", + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-19T00:10:20.0957203\u002B00:00", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:15:01 GMT", + "Date": "Mon, 10 Oct 2022 08:22:27 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-5e9db71e3015fcd8a596df230b59d161-8d09f2514cb642c6-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-25fea502af5641768b83925d29f5ea79-c39ba6f63f9a5fa6-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "b96c5ea0-e354-4264-a45d-d36c45f2f53b", + "x-ms-correlation-request-id": "c740a320-e056-4cdf-8859-ded46508f2e6", "x-ms-ratelimit-remaining-subscription-writes": "1192", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151501Z:b96c5ea0-e354-4264-a45d-d36c45f2f53b", - "x-request-time": "0.092" + "x-ms-routing-request-id": "JAPANEAST:20221010T082228Z:c740a320-e056-4cdf-8859-ded46508f2e6", + "x-request-time": "0.088" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,26 +101,26 @@ } }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/starlite-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/starlite-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:15:01 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 08:22:28 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Accept-Ranges": "bytes", - "Content-Length": "1427", - "Content-MD5": "ZRCutAxRih0\u002BenvTNIIfbw==", + "Content-Length": "1232", + "Content-MD5": "qEc1N\u002BFt8RxWIrBMsd03jw==", "Content-Type": "application/octet-stream", - "Date": "Mon, 19 Sep 2022 15:15:00 GMT", - "ETag": "\u00220x8DA99D3774B8A71\u0022", - "Last-Modified": "Mon, 19 Sep 2022 00:11:14 GMT", + "Date": "Mon, 10 Oct 2022 08:22:28 GMT", + "ETag": "\u00220x8DAAA6F0BD94188\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:25:14 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 19 Sep 2022 00:11:14 GMT", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:25:14 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "3a36feb7-dd71-4290-8c0b-4232ea316e59", + "x-ms-meta-name": "f70de239-c1fe-4f08-ad76-2fdcd854c468", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/az-ml-artifacts/00000000000000000000000000000000/starlite-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/starlite-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:15:01 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 08:22:28 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 19 Sep 2022 15:15:00 GMT", + "Date": "Mon, 10 Oct 2022 08:22:28 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3a36feb7-dd71-4290-8c0b-4232ea316e59/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f70de239-c1fe-4f08-ad76-2fdcd854c468/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "307", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/starlite-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/starlite-component" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:15:02 GMT", + "Date": "Mon, 10 Oct 2022 08:22:28 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-da27bb74462535b2c0ae3028a7b06f62-9f27352738577243-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-b2c07ce8660473501578a72321ad7560-9f6719d77e536039-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "582427bf-d1c1-4826-9f7f-25458a45ab3e", + "x-ms-correlation-request-id": "60b9255f-8458-4598-9a59-0a29dcc5b8db", "x-ms-ratelimit-remaining-subscription-writes": "1185", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151502Z:582427bf-d1c1-4826-9f7f-25458a45ab3e", - "x-request-time": "0.063" + "x-ms-routing-request-id": "JAPANEAST:20221010T082229Z:60b9255f-8458-4598-9a59-0a29dcc5b8db", + "x-request-time": "0.251" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3a36feb7-dd71-4290-8c0b-4232ea316e59/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f70de239-c1fe-4f08-ad76-2fdcd854c468/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,20 +225,20 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/starlite-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/starlite-component" }, "systemData": { - "createdAt": "2022-09-19T00:11:15.1195181\u002B00:00", - "createdBy": "10832f61-6ea1-44eb-9622-85f30271eec4", - "createdByType": "Application", - "lastModifiedAt": "2022-09-19T15:15:02.6392373\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:25:15.1852932\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T08:22:29.226308\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_522598369413/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_101750798587/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "1717", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -259,7 +259,7 @@ "isAnonymous": false, "isArchived": false, "componentSpec": { - "name": "test_522598369413", + "name": "test_101750798587", "description": "Allows to download files from SearchGold to cosmos and get their revision information. \u0027FileList\u0027 input is a file with source depot paths, one per line.", "tags": { "category": "Component Tutorial", @@ -302,7 +302,7 @@ } }, "type": "StarliteComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3a36feb7-dd71-4290-8c0b-4232ea316e59/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f70de239-c1fe-4f08-ad76-2fdcd854c468/versions/1", "command": "Starlite.Cloud.SourceDepotGet.exe /UploadToCosmos:{inputs.UploadToCosmos} /FileList:{inputs.FileList}{inputs.FileListFileName} /Files:{outputs.Files} /CosmosPath:{outputs.CosmosPath} /ResultInfo:{outputs.ResultInfo} \u0022\u0022", "starlite": { "ref_id": "bd140f4d-7775-4246-a75c-1c86df9536fb" @@ -313,25 +313,25 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2718", + "Content-Length": "2716", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:15:04 GMT", + "Date": "Mon, 10 Oct 2022 08:22:30 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_522598369413/versions/0.0.1?api-version=2022-05-01", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_101750798587/versions/0.0.1?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-3ce7686daf7afba3e00e7c68a8fd3251-39e9b320f9075dc3-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-22b2646076960b4eedc2335b800c8e85-ab44bf37cbbb347a-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "9281e3fb-2c21-4f2c-837e-b77335e5f649", + "x-ms-correlation-request-id": "a409ae9e-26fa-4d06-99a7-bc6c197e5ca7", "x-ms-ratelimit-remaining-subscription-writes": "1184", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151504Z:9281e3fb-2c21-4f2c-837e-b77335e5f649", - "x-request-time": "0.785" + "x-ms-routing-request-id": "JAPANEAST:20221010T082231Z:a409ae9e-26fa-4d06-99a7-bc6c197e5ca7", + "x-request-time": "1.645" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_522598369413/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_101750798587/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -345,7 +345,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/StarliteComponent.json", - "name": "test_522598369413", + "name": "test_101750798587", "version": "0.0.1", "display_name": "Starlite SearchGold Get Files", "is_deterministic": "True", @@ -395,27 +395,27 @@ "starlite": { "ref_id": "bd140f4d-7775-4246-a75c-1c86df9536fb" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3a36feb7-dd71-4290-8c0b-4232ea316e59/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f70de239-c1fe-4f08-ad76-2fdcd854c468/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:15:04.0599488\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T08:22:30.2793268\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:15:04.3042917\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T08:22:30.9352941\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_522598369413/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_101750798587/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "GET", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -423,27 +423,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:15:04 GMT", + "Date": "Mon, 10 Oct 2022 08:22:31 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-6a6dfa7ba90539217d2dc5f9b22e14aa-ab04d30b67bb387d-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-8ab01fb8bc955eefe5db43283d4792a7-6c750d22824dc043-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "3d72d812-839c-469d-9b3d-cba1c13c3e32", + "x-ms-correlation-request-id": "f82c16ee-f764-480a-beba-dbc4f124b358", "x-ms-ratelimit-remaining-subscription-reads": "11984", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151504Z:3d72d812-839c-469d-9b3d-cba1c13c3e32", - "x-request-time": "0.117" + "x-ms-routing-request-id": "JAPANEAST:20221010T082232Z:f82c16ee-f764-480a-beba-dbc4f124b358", + "x-request-time": "0.489" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_522598369413/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_101750798587/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -457,7 +457,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/StarliteComponent.json", - "name": "test_522598369413", + "name": "test_101750798587", "version": "0.0.1", "display_name": "Starlite SearchGold Get Files", "is_deterministic": "True", @@ -507,21 +507,21 @@ "starlite": { "ref_id": "bd140f4d-7775-4246-a75c-1c86df9536fb" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3a36feb7-dd71-4290-8c0b-4232ea316e59/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f70de239-c1fe-4f08-ad76-2fdcd854c468/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:15:04.0599488\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T08:22:30.2793268\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:15:04.3042917\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T08:22:30.9352941\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } } ], "Variables": { - "component_name": "test_522598369413" + "component_name": "test_101750798587" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/ae365exepool-component/component_spec.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/ae365exepool-component/component_spec.yaml].json index f82b58a5bdd5..9cd95e13a187 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/ae365exepool-component/component_spec.yaml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/ae365exepool-component/component_spec.yaml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:46 GMT", + "Date": "Mon, 10 Oct 2022 03:38:13 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-2e22e18d86c75dc100f4f8c20a59cda0-313fe31720febe90-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-741fd5531d0ea824426ca3448317834e-9ff266b61f802be8-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "22fd315d-d5e5-42d0-b1d0-bbc9af699d3a", - "x-ms-ratelimit-remaining-subscription-reads": "11983", + "x-ms-correlation-request-id": "0ac1a59b-2ced-402d-a9ea-387b582df96d", + "x-ms-ratelimit-remaining-subscription-reads": "11957", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151747Z:22fd315d-d5e5-42d0-b1d0-bbc9af699d3a", - "x-request-time": "0.094" + "x-ms-routing-request-id": "JAPANEAST:20221010T033814Z:0ac1a59b-2ced-402d-a9ea-387b582df96d", + "x-request-time": "0.090" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sawcdivl5vo3cem", - "containerName": "azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-19T00:10:19.4497254\u002B00:00", + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-19T00:10:20.0957203\u002B00:00", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:46 GMT", + "Date": "Mon, 10 Oct 2022 03:38:14 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-812a10636e30d5cd2f3ac5b024f4a02d-08cacc857a52f676-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-0e80a200e4218d87a2b03c2ad9586c62-e819f662ea0b1477-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "4ce355a1-c61c-4ee8-a534-0a27d1abd2a7", - "x-ms-ratelimit-remaining-subscription-writes": "1191", + "x-ms-correlation-request-id": "83c36789-ccaf-44dd-8e9b-bce731456d74", + "x-ms-ratelimit-remaining-subscription-writes": "1182", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151747Z:4ce355a1-c61c-4ee8-a534-0a27d1abd2a7", - "x-request-time": "0.102" + "x-ms-routing-request-id": "JAPANEAST:20221010T033814Z:83c36789-ccaf-44dd-8e9b-bce731456d74", + "x-request-time": "0.117" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,26 +101,26 @@ } }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/ae365exepool-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/ae365exepool-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:17:47 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:38:14 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Accept-Ranges": "bytes", - "Content-Length": "3535", - "Content-MD5": "QqW25JGnycTHblw25UymFQ==", + "Content-Length": "3037", + "Content-MD5": "BJNWwWLteiyAJHIsUtiV1g==", "Content-Type": "application/octet-stream", - "Date": "Mon, 19 Sep 2022 15:17:47 GMT", - "ETag": "\u00220x8DA99D3774A7925\u0022", - "Last-Modified": "Mon, 19 Sep 2022 00:11:14 GMT", + "Date": "Mon, 10 Oct 2022 03:38:14 GMT", + "ETag": "\u00220x8DAAA6F10D672F5\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:25:22 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 19 Sep 2022 00:11:14 GMT", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:25:22 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "16c2bd31-0d3e-4f21-9349-1d46c3e16c4c", + "x-ms-meta-name": "c9319d9f-12c0-4f61-8318-7186e19eb493", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/az-ml-artifacts/00000000000000000000000000000000/ae365exepool-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/ae365exepool-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:17:47 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:38:14 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 19 Sep 2022 15:17:47 GMT", + "Date": "Mon, 10 Oct 2022 03:38:14 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/16c2bd31-0d3e-4f21-9349-1d46c3e16c4c/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/c9319d9f-12c0-4f61-8318-7186e19eb493/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "311", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/ae365exepool-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/ae365exepool-component" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:48 GMT", + "Date": "Mon, 10 Oct 2022 03:38:15 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-f7f3fc98d9c7b4bbd6b62178f6c0cb3b-da9c5c33c2b8ff91-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-31b72b28cf2863c77637a6867232d1ec-80f732e357c19e34-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "2d010f8b-6e93-4568-9fc6-8ab71758ecda", - "x-ms-ratelimit-remaining-subscription-writes": "1183", + "x-ms-correlation-request-id": "e3a8e111-cdc6-49e2-ac8e-b295b3ee7b91", + "x-ms-ratelimit-remaining-subscription-writes": "1165", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151748Z:2d010f8b-6e93-4568-9fc6-8ab71758ecda", - "x-request-time": "0.069" + "x-ms-routing-request-id": "JAPANEAST:20221010T033815Z:e3a8e111-cdc6-49e2-ac8e-b295b3ee7b91", + "x-request-time": "0.201" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/16c2bd31-0d3e-4f21-9349-1d46c3e16c4c/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/c9319d9f-12c0-4f61-8318-7186e19eb493/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,20 +225,20 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/ae365exepool-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/ae365exepool-component" }, "systemData": { - "createdAt": "2022-09-19T00:11:15.2254943\u002B00:00", - "createdBy": "10832f61-6ea1-44eb-9622-85f30271eec4", - "createdByType": "Application", - "lastModifiedAt": "2022-09-19T15:17:47.9727389\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:25:23.2533498\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:38:15.7118173\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_123464532728/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_351330425679/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "3431", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -259,7 +259,7 @@ "isAnonymous": false, "isArchived": false, "componentSpec": { - "name": "test_123464532728", + "name": "test_351330425679", "description": "Use this auto-approved module to download data on EyesOn machine and interact with it for Compliant Annotation purpose.", "tags": { "category": "Component Tutorial", @@ -365,7 +365,7 @@ } }, "type": "AE365ExePoolComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/16c2bd31-0d3e-4f21-9349-1d46c3e16c4c/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/c9319d9f-12c0-4f61-8318-7186e19eb493/versions/1", "command": "cax.eyesonmodule.exe input={inputs.DataToLookAt} inputGoldHitRta=[{inputs.GoldHitRTAData}] localoutputfolderEnc=[{inputs.localoutputfolderEnc}] localoutputfolderDec=[{inputs.localoutputfolderDec}] timeoutSeconds=[{inputs.TimeoutSeconds}] hitappid=[{inputs.hitappid}] projectname=[{inputs.projectname}] judges=[{inputs.judges}] outputfolderEnc={outputs.outputfolderEnc} outputfolderDec={outputs.outputfolderDec} annotationsMayIncludeCustomerContent=[{inputs.annotationsMayIncludeCustomerContent}] taskGroupId=[{inputs.TaskGroupId}] goldHitRTADataType=[{inputs.GoldHitRTADataType}] outputfolderForOriginalHitData={outputs.OriginalHitData} taskFileTimestamp=[{inputs.taskFileTimestamp}]", "ae365exepool": { "ref_id": "654ec0ba-bed3-48eb-a594-efd0e9275e0d" @@ -376,25 +376,25 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "5005", + "Content-Length": "5003", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:50 GMT", + "Date": "Mon, 10 Oct 2022 03:38:17 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_123464532728/versions/0.0.1?api-version=2022-05-01", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_351330425679/versions/0.0.1?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-20d7996f4c9d44a94505f794a4d6278f-18f71155fc086a8c-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-7b70dca92a060ff0c14a10bbfb12df19-bcc80c2169ccf72f-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "03a6d1bf-628a-4576-b922-e99f8011c0a2", - "x-ms-ratelimit-remaining-subscription-writes": "1182", + "x-ms-correlation-request-id": "ad91f6bb-8124-481c-86e1-d3186d7066d0", + "x-ms-ratelimit-remaining-subscription-writes": "1164", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151750Z:03a6d1bf-628a-4576-b922-e99f8011c0a2", - "x-request-time": "0.785" + "x-ms-routing-request-id": "JAPANEAST:20221010T033818Z:ad91f6bb-8124-481c-86e1-d3186d7066d0", + "x-request-time": "1.791" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_123464532728/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_351330425679/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -408,7 +408,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/AE365ExePoolComponent.json", - "name": "test_123464532728", + "name": "test_351330425679", "version": "0.0.1", "display_name": "CAX EyesOn Module [ND] v1.6", "is_deterministic": "True", @@ -517,27 +517,27 @@ "ae365exepool": { "ref_id": "654ec0ba-bed3-48eb-a594-efd0e9275e0d" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/16c2bd31-0d3e-4f21-9349-1d46c3e16c4c/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/c9319d9f-12c0-4f61-8318-7186e19eb493/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:17:49.7648872\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:38:16.8965258\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:17:50.0084995\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T03:38:17.5892343\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_123464532728/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_351330425679/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "GET", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -545,27 +545,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:50 GMT", + "Date": "Mon, 10 Oct 2022 03:38:18 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-d147fdf285c99aa97af0590e6d619243-929361f2bac8fe25-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-796ae089fb81822d62368c4711fd4682-dcbcc9ee001ecdfd-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "fa1a868e-4574-4b2a-b9d4-abc3255009d4", - "x-ms-ratelimit-remaining-subscription-reads": "11982", + "x-ms-correlation-request-id": "8f556ff8-2b5e-4e57-88d6-81c1628846ed", + "x-ms-ratelimit-remaining-subscription-reads": "11956", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151750Z:fa1a868e-4574-4b2a-b9d4-abc3255009d4", - "x-request-time": "0.139" + "x-ms-routing-request-id": "JAPANEAST:20221010T033819Z:8f556ff8-2b5e-4e57-88d6-81c1628846ed", + "x-request-time": "0.375" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_123464532728/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_351330425679/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -579,7 +579,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/AE365ExePoolComponent.json", - "name": "test_123464532728", + "name": "test_351330425679", "version": "0.0.1", "display_name": "CAX EyesOn Module [ND] v1.6", "is_deterministic": "True", @@ -688,21 +688,21 @@ "ae365exepool": { "ref_id": "654ec0ba-bed3-48eb-a594-efd0e9275e0d" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/16c2bd31-0d3e-4f21-9349-1d46c3e16c4c/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/c9319d9f-12c0-4f61-8318-7186e19eb493/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:17:49.7648872\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:38:16.8965258\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:17:50.0084995\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T03:38:17.5892343\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } } ], "Variables": { - "component_name": "test_123464532728" + "component_name": "test_351330425679" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/batch_inference/batch_score.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/batch_inference/batch_score.yaml].json index c4fb704e71bc..ac4957edb9b6 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/batch_inference/batch_score.yaml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/batch_inference/batch_score.yaml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:18 GMT", + "Date": "Mon, 10 Oct 2022 03:37:26 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-e999a4c2f98160d35cb0e8c8b90766b8-d89f69a1c0445ee3-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-c159c154aaadf58d1b45231edfaa80dd-af4224b3daffc9c4-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "3d7c716e-c065-495a-8be1-922004ece434", - "x-ms-ratelimit-remaining-subscription-reads": "11995", + "x-ms-correlation-request-id": "7ec9d72b-5c45-4f7c-b514-7aacea905006", + "x-ms-ratelimit-remaining-subscription-reads": "11969", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151719Z:3d7c716e-c065-495a-8be1-922004ece434", - "x-request-time": "0.095" + "x-ms-routing-request-id": "JAPANEAST:20221010T033726Z:7ec9d72b-5c45-4f7c-b514-7aacea905006", + "x-request-time": "0.100" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sawcdivl5vo3cem", - "containerName": "azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-19T00:10:19.4497254\u002B00:00", + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-19T00:10:20.0957203\u002B00:00", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:19 GMT", + "Date": "Mon, 10 Oct 2022 03:37:26 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-88e0737359dd1b6867366944fed50b33-8f7070a4ea4f07f6-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-d3077cf0150fc4c30e7c8af2e4f669f0-b4a43b9afb3a2acd-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "5d2022b0-85d1-4aec-93c5-449d0e2b8b3a", - "x-ms-ratelimit-remaining-subscription-writes": "1197", + "x-ms-correlation-request-id": "67357e3b-831a-4e9e-93f2-bad0dedac5eb", + "x-ms-ratelimit-remaining-subscription-writes": "1188", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151719Z:5d2022b0-85d1-4aec-93c5-449d0e2b8b3a", - "x-request-time": "0.094" + "x-ms-routing-request-id": "JAPANEAST:20221010T033727Z:67357e3b-831a-4e9e-93f2-bad0dedac5eb", + "x-request-time": "0.099" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,26 +101,26 @@ } }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/batch_inference/batch_score.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/batch_inference/batch_score.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:17:19 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:37:27 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Accept-Ranges": "bytes", - "Content-Length": "1785", - "Content-MD5": "49mgDMscslXyD\u002BqKAzbAWQ==", + "Content-Length": "1890", + "Content-MD5": "Nsal/dhEjjdoIJBn7yWG7Q==", "Content-Type": "application/octet-stream", - "Date": "Mon, 19 Sep 2022 15:17:19 GMT", - "ETag": "\u00220x8DA99D37733C020\u0022", - "Last-Modified": "Mon, 19 Sep 2022 00:11:14 GMT", + "Date": "Mon, 10 Oct 2022 03:37:27 GMT", + "ETag": "\u00220x8DAAA6EF2CC2544\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:24:32 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 19 Sep 2022 00:11:14 GMT", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:24:32 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "3f55b831-c769-40ed-be03-c7a574b42b38", + "x-ms-meta-name": "12a3d416-e2ad-465d-9896-ebaf6bf0b49e", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/az-ml-artifacts/00000000000000000000000000000000/batch_inference/batch_score.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/batch_inference/batch_score.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:17:19 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:37:27 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 19 Sep 2022 15:17:19 GMT", + "Date": "Mon, 10 Oct 2022 03:37:27 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3f55b831-c769-40ed-be03-c7a574b42b38/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/12a3d416-e2ad-465d-9896-ebaf6bf0b49e/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "304", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/batch_inference" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/batch_inference" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:19 GMT", + "Date": "Mon, 10 Oct 2022 03:37:27 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-61f1afb3039f5056e722c10293995b9b-6c182786e7d97a83-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-e7d5e14a15bdc9d5defb84a7de50c2ae-a8f6ffda3fc493fe-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "cfa98d41-8ac6-417a-a420-db5163b0d9d6", - "x-ms-ratelimit-remaining-subscription-writes": "1195", + "x-ms-correlation-request-id": "31717566-982e-4a28-9610-527af9e8424a", + "x-ms-ratelimit-remaining-subscription-writes": "1177", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151720Z:cfa98d41-8ac6-417a-a420-db5163b0d9d6", - "x-request-time": "0.070" + "x-ms-routing-request-id": "JAPANEAST:20221010T033728Z:31717566-982e-4a28-9610-527af9e8424a", + "x-request-time": "0.231" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3f55b831-c769-40ed-be03-c7a574b42b38/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/12a3d416-e2ad-465d-9896-ebaf6bf0b49e/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,20 +225,20 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/batch_inference" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/batch_inference" }, "systemData": { - "createdAt": "2022-09-19T00:11:14.955282\u002B00:00", - "createdBy": "10832f61-6ea1-44eb-9622-85f30271eec4", - "createdByType": "Application", - "lastModifiedAt": "2022-09-19T15:17:20.1959811\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:24:32.8523963\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:37:28.4214759\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_843326603341/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_766670020581/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "1828", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -261,7 +261,7 @@ "isAnonymous": false, "isArchived": false, "componentSpec": { - "name": "test_843326603341", + "name": "test_766670020581", "description": "Score images with MNIST image classification model.", "tags": { "Parallel": "", @@ -289,7 +289,7 @@ } }, "type": "ParallelComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3f55b831-c769-40ed-be03-c7a574b42b38/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/12a3d416-e2ad-465d-9896-ebaf6bf0b49e/versions/1", "environment": { "docker": { "image": "mcr.microsoft.com/azureml/openmpi3.1.2-cuda10.1-cudnn7-ubuntu18.04" @@ -329,25 +329,25 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "3237", + "Content-Length": "3235", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:20 GMT", + "Date": "Mon, 10 Oct 2022 03:37:29 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_843326603341/versions/0.0.1?api-version=2022-05-01", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_766670020581/versions/0.0.1?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-12e61d56f85c1f51286d2317bf43d274-51a57427a394c04d-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-233b2f24c802a7ac45e233db602586cc-6cd74d5892e5ea5c-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "a4e8720f-26f0-44f7-8b32-237bae5d07ed", - "x-ms-ratelimit-remaining-subscription-writes": "1194", + "x-ms-correlation-request-id": "da543810-3c45-490f-8adc-9ff13b69bc69", + "x-ms-ratelimit-remaining-subscription-writes": "1176", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151721Z:a4e8720f-26f0-44f7-8b32-237bae5d07ed", - "x-request-time": "0.784" + "x-ms-routing-request-id": "JAPANEAST:20221010T033730Z:da543810-3c45-490f-8adc-9ff13b69bc69", + "x-request-time": "1.676" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_843326603341/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_766670020581/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -363,7 +363,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/ParallelComponent.json", - "name": "test_843326603341", + "name": "test_766670020581", "version": "0.0.1", "display_name": "Parallel Score Image Classification with MNIST", "is_deterministic": "True", @@ -429,27 +429,27 @@ "output_data": "outputs.scored_dataset", "entry": "batch_score.py" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3f55b831-c769-40ed-be03-c7a574b42b38/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/12a3d416-e2ad-465d-9896-ebaf6bf0b49e/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:17:20.7797551\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:37:29.5239088\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:17:21.0271639\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T03:37:30.1571452\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_843326603341/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_766670020581/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "GET", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -457,27 +457,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:20 GMT", + "Date": "Mon, 10 Oct 2022 03:37:30 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-9ce4af131664c2354de28dcace8093f7-d0711939e4898e38-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-90372539d9629144703e11e39428b280-dad06416b7640fd5-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "1a9411b7-340d-4834-ae70-a0e0c3bdbfad", - "x-ms-ratelimit-remaining-subscription-reads": "11994", + "x-ms-correlation-request-id": "5001da22-72fa-4e01-a428-4e77ec472bdc", + "x-ms-ratelimit-remaining-subscription-reads": "11968", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151721Z:1a9411b7-340d-4834-ae70-a0e0c3bdbfad", - "x-request-time": "0.123" + "x-ms-routing-request-id": "JAPANEAST:20221010T033731Z:5001da22-72fa-4e01-a428-4e77ec472bdc", + "x-request-time": "0.361" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_843326603341/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_766670020581/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -493,7 +493,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/ParallelComponent.json", - "name": "test_843326603341", + "name": "test_766670020581", "version": "0.0.1", "display_name": "Parallel Score Image Classification with MNIST", "is_deterministic": "True", @@ -559,21 +559,21 @@ "output_data": "outputs.scored_dataset", "entry": "batch_score.py" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3f55b831-c769-40ed-be03-c7a574b42b38/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/12a3d416-e2ad-465d-9896-ebaf6bf0b49e/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:17:20.7797551\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:37:29.5239088\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:17:21.0271639\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T03:37:30.1571452\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } } ], "Variables": { - "component_name": "test_843326603341" + "component_name": "test_766670020581" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/ls_command_component.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/command-component-ls/ls_command_component.yaml].json similarity index 70% rename from sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/ls_command_component.yaml].json rename to sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/command-component-ls/ls_command_component.yaml].json index 475bd3d3cb34..0d45ce9f8dfb 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/ls_command_component.yaml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/command-component-ls/ls_command_component.yaml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.13 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,11 +15,11 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 07:04:35 GMT", + "Date": "Mon, 10 Oct 2022 03:37:09 GMT", "Expires": "-1", "Pragma": "no-cache", "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-dcb531cd5dac04fbed9b1ce9f748ce5d-7fadbda5f28b1ad2-01\u0022", + "Server-Timing": "traceparent;desc=\u002200-dd23324ff477565f66df0089780b42c2-f2a2101f7c4f882c-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ @@ -28,11 +28,11 @@ ], "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "334e56cd-16d6-4e4b-a1da-eb9d08ca5f24", - "x-ms-ratelimit-remaining-subscription-reads": "11995", + "x-ms-correlation-request-id": "7c6f2a5b-116d-4c61-9f5d-b0c9c1c8de00", + "x-ms-ratelimit-remaining-subscription-reads": "11973", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "SOUTHEASTASIA:20220929T070436Z:334e56cd-16d6-4e4b-a1da-eb9d08ca5f24", - "x-request-time": "0.126" + "x-ms-routing-request-id": "JAPANEAST:20221010T033710Z:7c6f2a5b-116d-4c61-9f5d-b0c9c1c8de00", + "x-request-time": "0.093" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.13 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 07:04:37 GMT", + "Date": "Mon, 10 Oct 2022 03:37:10 GMT", "Expires": "-1", "Pragma": "no-cache", "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-fe9b50af45400abe696723b18ea256e6-94965a5b67e56389-01\u0022", + "Server-Timing": "traceparent;desc=\u002200-0c70696173f0dfbf7b9f32b9124beff2-d8adaf30ef266757-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "b22305ca-d250-4bf7-ab26-3b2dcb609b64", - "x-ms-ratelimit-remaining-subscription-writes": "1199", + "x-ms-correlation-request-id": "e3aa9c34-e104-4d9f-b977-2acf5a4ae87b", + "x-ms-ratelimit-remaining-subscription-writes": "1190", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "SOUTHEASTASIA:20220929T070437Z:b22305ca-d250-4bf7-ab26-3b2dcb609b64", - "x-request-time": "0.094" + "x-ms-routing-request-id": "JAPANEAST:20221010T033710Z:e3aa9c34-e104-4d9f-b977-2acf5a4ae87b", + "x-request-time": "0.093" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,26 +101,26 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal/.gitattributes", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/command-component-ls/ls_command_component.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 07:04:38 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:37:10 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Accept-Ranges": "bytes", - "Content-Length": "20", - "Content-MD5": "y8Rm4nvb8obccSH2GkCKJw==", + "Content-Length": "234", + "Content-MD5": "UrxIkzZNuLtqksFOP/IPuw==", "Content-Type": "application/octet-stream", - "Date": "Thu, 29 Sep 2022 07:04:38 GMT", - "ETag": "\u00220x8DAA1E8C8D58441\u0022", - "Last-Modified": "Thu, 29 Sep 2022 07:04:00 GMT", + "Date": "Mon, 10 Oct 2022 03:37:10 GMT", + "ETag": "\u00220x8DAAA704BF59F5F\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:34:11 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,10 +129,10 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Thu, 29 Sep 2022 07:03:58 GMT", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:34:11 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "b654147a-f814-4776-92ed-d3aa49be367c", + "x-ms-meta-name": "79148717-5f10-44c7-83de-7b53696b6795", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", @@ -141,20 +141,20 @@ "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/internal/.gitattributes", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/command-component-ls/ls_command_component.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.9.13 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 07:04:39 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:37:11 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Thu, 29 Sep 2022 07:04:39 GMT", + "Date": "Mon, 10 Oct 2022 03:37:10 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -167,15 +167,15 @@ "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/b654147a-f814-4776-92ed-d3aa49be367c/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/79148717-5f10-44c7-83de-7b53696b6795/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "297", + "Content-Length": "309", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.13 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/command-component-ls" } }, "StatusCode": 200, @@ -193,11 +193,11 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 07:04:40 GMT", + "Date": "Mon, 10 Oct 2022 03:37:11 GMT", "Expires": "-1", "Pragma": "no-cache", "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-eaf833d07c87de9e2597c2cf7b62049b-928c87fb7813a96b-01\u0022", + "Server-Timing": "traceparent;desc=\u002200-73cfa2ddd9be1f6cc0a316cdfdafea66-1263d7bd4a74ac54-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ @@ -206,14 +206,14 @@ ], "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "d358f851-a49a-4938-bf4b-23947d8f7d0c", - "x-ms-ratelimit-remaining-subscription-writes": "1199", + "x-ms-correlation-request-id": "adf0ba4c-31f8-4e9f-8c40-a9d33746e138", + "x-ms-ratelimit-remaining-subscription-writes": "1181", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "SOUTHEASTASIA:20220929T070440Z:d358f851-a49a-4938-bf4b-23947d8f7d0c", - "x-request-time": "0.272" + "x-ms-routing-request-id": "JAPANEAST:20221010T033712Z:adf0ba4c-31f8-4e9f-8c40-a9d33746e138", + "x-request-time": "0.184" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/b654147a-f814-4776-92ed-d3aa49be367c/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/79148717-5f10-44c7-83de-7b53696b6795/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,20 +225,20 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/internal" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/command-component-ls" }, "systemData": { - "createdAt": "2022-09-29T07:04:02.2522821\u002B00:00", - "createdBy": "Zhengfei Wang", + "createdAt": "2022-10-10T03:34:12.2357175\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-29T07:04:40.6488353\u002B00:00", - "lastModifiedBy": "Zhengfei Wang", + "lastModifiedAt": "2022-10-10T03:37:12.0773137\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_471295466192/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_794020523681/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "645", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.13 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -255,7 +255,7 @@ "isAnonymous": false, "isArchived": false, "componentSpec": { - "name": "test_471295466192", + "name": "test_794020523681", "tags": {}, "version": "0.0.1", "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", @@ -264,7 +264,7 @@ "inputs": {}, "outputs": {}, "type": "CommandComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/b654147a-f814-4776-92ed-d3aa49be367c/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/79148717-5f10-44c7-83de-7b53696b6795/versions/1", "environment": { "os": "Linux", "name": "AzureML-Designer" @@ -278,23 +278,23 @@ "Cache-Control": "no-cache", "Content-Length": "1337", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 07:04:45 GMT", + "Date": "Mon, 10 Oct 2022 03:37:14 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_471295466192/versions/0.0.1?api-version=2022-05-01", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_794020523681/versions/0.0.1?api-version=2022-05-01", "Pragma": "no-cache", "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-4efe9dca1816e6b36180b87cbb278d3d-89c73cb4c1a2c7d7-01\u0022", + "Server-Timing": "traceparent;desc=\u002200-8fe7fbcbd5a9033342101b99ca45e24a-efe96c1d70a6e03c-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "534ecf76-b28b-4bb8-b377-dd2ff1818b4e", - "x-ms-ratelimit-remaining-subscription-writes": "1198", + "x-ms-correlation-request-id": "9173d429-49d4-49af-ad63-b54575836c9e", + "x-ms-ratelimit-remaining-subscription-writes": "1180", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "SOUTHEASTASIA:20220929T070446Z:534ecf76-b28b-4bb8-b377-dd2ff1818b4e", - "x-request-time": "4.207" + "x-ms-routing-request-id": "JAPANEAST:20221010T033714Z:9173d429-49d4-49af-ad63-b54575836c9e", + "x-request-time": "2.126" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_471295466192/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_794020523681/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -305,7 +305,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", - "name": "test_471295466192", + "name": "test_794020523681", "version": "0.0.1", "display_name": "Ls Command", "is_deterministic": "True", @@ -316,27 +316,27 @@ }, "successful_return_code": "Zero", "command": "ls", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/b654147a-f814-4776-92ed-d3aa49be367c/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/79148717-5f10-44c7-83de-7b53696b6795/versions/1" } }, "systemData": { - "createdAt": "2022-09-29T07:04:44.8400735\u002B00:00", - "createdBy": "Zhengfei Wang", + "createdAt": "2022-10-10T03:37:13.7304563\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-29T07:04:45.4756315\u002B00:00", - "lastModifiedBy": "Zhengfei Wang", + "lastModifiedAt": "2022-10-10T03:37:14.3297669\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_471295466192/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_794020523681/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "GET", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.13 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -344,11 +344,11 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 07:04:46 GMT", + "Date": "Mon, 10 Oct 2022 03:37:14 GMT", "Expires": "-1", "Pragma": "no-cache", "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-fcf4979974e8651181da0aa6d4b4c452-4a4f0eb9138a557f-01\u0022", + "Server-Timing": "traceparent;desc=\u002200-f3c456f67a01d6a1a565080c5552e7aa-51ec51ca3f05c0b7-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ @@ -357,14 +357,14 @@ ], "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "b689c013-fa7e-4821-901f-edfd4fac4e19", - "x-ms-ratelimit-remaining-subscription-reads": "11994", + "x-ms-correlation-request-id": "24029dfc-0513-4e34-99d8-592559ef19b9", + "x-ms-ratelimit-remaining-subscription-reads": "11972", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "SOUTHEASTASIA:20220929T070446Z:b689c013-fa7e-4821-901f-edfd4fac4e19", - "x-request-time": "0.368" + "x-ms-routing-request-id": "JAPANEAST:20221010T033715Z:24029dfc-0513-4e34-99d8-592559ef19b9", + "x-request-time": "0.320" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_471295466192/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_794020523681/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -375,7 +375,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", - "name": "test_471295466192", + "name": "test_794020523681", "version": "0.0.1", "display_name": "Ls Command", "is_deterministic": "True", @@ -386,21 +386,21 @@ }, "successful_return_code": "Zero", "command": "ls", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/b654147a-f814-4776-92ed-d3aa49be367c/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/79148717-5f10-44c7-83de-7b53696b6795/versions/1" } }, "systemData": { - "createdAt": "2022-09-29T07:04:44.8400735\u002B00:00", - "createdBy": "Zhengfei Wang", + "createdAt": "2022-10-10T03:37:13.7304563\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-29T07:04:45.4756315\u002B00:00", - "lastModifiedBy": "Zhengfei Wang", + "lastModifiedAt": "2022-10-10T03:37:14.3297669\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } } ], "Variables": { - "component_name": "test_471295466192" + "component_name": "test_794020523681" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/data-transfer-component/component_spec.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/data-transfer-component/component_spec.yaml].json index e05ab4791875..03fe321dac3f 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/data-transfer-component/component_spec.yaml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/data-transfer-component/component_spec.yaml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:36 GMT", + "Date": "Mon, 10 Oct 2022 03:37:58 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-55e2bff7640d570ac8872a29f2b1ef25-44380c5238c581e8-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-040e2546bccce7d72d3dd2306ce2eb2b-17a0d2ba39a75b40-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "56c0a70b-d173-4c20-94f0-5e81eab6a5da", - "x-ms-ratelimit-remaining-subscription-reads": "11987", + "x-ms-correlation-request-id": "67a50b43-3f66-483c-9226-840b003eddda", + "x-ms-ratelimit-remaining-subscription-reads": "11961", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151737Z:56c0a70b-d173-4c20-94f0-5e81eab6a5da", - "x-request-time": "0.090" + "x-ms-routing-request-id": "JAPANEAST:20221010T033758Z:67a50b43-3f66-483c-9226-840b003eddda", + "x-request-time": "0.104" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sawcdivl5vo3cem", - "containerName": "azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-19T00:10:19.4497254\u002B00:00", + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-19T00:10:20.0957203\u002B00:00", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:37 GMT", + "Date": "Mon, 10 Oct 2022 03:37:58 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-05f6f69a1be378997f258fd8ef378bd9-86928247e0ab3c4b-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-b68e9c7c68b06fab4411f6311548be0f-8c849e057d45db11-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "2a337022-da83-4740-803a-d578cf3f73fc", - "x-ms-ratelimit-remaining-subscription-writes": "1193", + "x-ms-correlation-request-id": "a15072cc-536f-4bbc-8821-c279eeb822dd", + "x-ms-ratelimit-remaining-subscription-writes": "1184", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151738Z:2a337022-da83-4740-803a-d578cf3f73fc", - "x-request-time": "0.118" + "x-ms-routing-request-id": "JAPANEAST:20221010T033758Z:a15072cc-536f-4bbc-8821-c279eeb822dd", + "x-request-time": "0.096" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,26 +101,26 @@ } }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/data-transfer-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/data-transfer-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:17:38 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:37:58 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Accept-Ranges": "bytes", - "Content-Length": "662", - "Content-MD5": "MKNy0eziOSgx4bMOiS4wuw==", + "Content-Length": "534", + "Content-MD5": "AGevjuGj0u\u002BzWFtkFxspxA==", "Content-Type": "application/octet-stream", - "Date": "Mon, 19 Sep 2022 15:17:37 GMT", - "ETag": "\u00220x8DA99D376E5D274\u0022", - "Last-Modified": "Mon, 19 Sep 2022 00:11:13 GMT", + "Date": "Mon, 10 Oct 2022 03:37:58 GMT", + "ETag": "\u00220x8DAAA6F0716787F\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:25:06 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 19 Sep 2022 00:11:13 GMT", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:25:06 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "adbb1689-e476-4344-8db5-2e4c692f650a", + "x-ms-meta-name": "e4143c07-53b4-4159-a962-a0c3efc68cc3", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/az-ml-artifacts/00000000000000000000000000000000/data-transfer-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/data-transfer-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:17:38 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:37:59 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 19 Sep 2022 15:17:37 GMT", + "Date": "Mon, 10 Oct 2022 03:37:58 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/adbb1689-e476-4344-8db5-2e4c692f650a/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/e4143c07-53b4-4159-a962-a0c3efc68cc3/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "312", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/data-transfer-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/data-transfer-component" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:37 GMT", + "Date": "Mon, 10 Oct 2022 03:37:59 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-f8d2fc0c6d54a0c956722864bf2b954b-1e71614b880fc8e7-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-dc15773988c6fe1ed27cb8018034bc93-4d9d0320caed27ec-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "f450a64f-99d2-4920-bf89-73c60cbafbd4", - "x-ms-ratelimit-remaining-subscription-writes": "1187", + "x-ms-correlation-request-id": "f7a67a42-0cb0-46fe-bca7-aebc8ff9f763", + "x-ms-ratelimit-remaining-subscription-writes": "1169", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151738Z:f450a64f-99d2-4920-bf89-73c60cbafbd4", - "x-request-time": "0.062" + "x-ms-routing-request-id": "JAPANEAST:20221010T033759Z:f7a67a42-0cb0-46fe-bca7-aebc8ff9f763", + "x-request-time": "0.186" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/adbb1689-e476-4344-8db5-2e4c692f650a/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/e4143c07-53b4-4159-a962-a0c3efc68cc3/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,28 +225,28 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/data-transfer-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/data-transfer-component" }, "systemData": { - "createdAt": "2022-09-19T00:11:14.7354197\u002B00:00", - "createdBy": "10832f61-6ea1-44eb-9622-85f30271eec4", - "createdByType": "Application", - "lastModifiedAt": "2022-09-19T15:17:38.7506532\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:25:06.8837744\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:37:59.764735\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_998170986493/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_77799589773/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "1075", + "Content-Length": "1074", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -259,7 +259,7 @@ "isAnonymous": false, "isArchived": false, "componentSpec": { - "name": "test_998170986493", + "name": "test_77799589773", "description": "transfer data between common storage types such as Azure Blob Storage and Azure Data Lake.", "tags": { "category": "Component Tutorial", @@ -282,32 +282,32 @@ } }, "type": "DataTransferComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/adbb1689-e476-4344-8db5-2e4c692f650a/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/e4143c07-53b4-4159-a962-a0c3efc68cc3/versions/1" } } }, "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1881", + "Content-Length": "1877", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:39 GMT", + "Date": "Mon, 10 Oct 2022 03:38:01 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_998170986493/versions/0.0.1?api-version=2022-05-01", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_77799589773/versions/0.0.1?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-94a2c809bf5e673d1b5b0762dcb86c6d-77916ce62d832e43-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-5caf3c9010936c34f523074bf651e284-b6b8c0695a1d1d4a-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "a6fdeacf-c62e-4e4f-8ba6-c15d91c2d1ad", - "x-ms-ratelimit-remaining-subscription-writes": "1186", + "x-ms-correlation-request-id": "eb53e9ed-de16-42b9-be0f-d76825d9ea98", + "x-ms-ratelimit-remaining-subscription-writes": "1168", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151739Z:a6fdeacf-c62e-4e4f-8ba6-c15d91c2d1ad", - "x-request-time": "0.628" + "x-ms-routing-request-id": "JAPANEAST:20221010T033801Z:eb53e9ed-de16-42b9-be0f-d76825d9ea98", + "x-request-time": "1.629" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_998170986493/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_77799589773/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -321,7 +321,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/DataTransferComponent.json", - "name": "test_998170986493", + "name": "test_77799589773", "version": "0.0.1", "display_name": "Data Transfer", "is_deterministic": "True", @@ -347,27 +347,27 @@ "datatransfer": { "allow_overwrite": "True" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/adbb1689-e476-4344-8db5-2e4c692f650a/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/e4143c07-53b4-4159-a962-a0c3efc68cc3/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:17:39.6196727\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:38:00.8173523\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:17:39.8126339\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T03:38:01.4696741\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_998170986493/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_77799589773/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "GET", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -375,27 +375,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:39 GMT", + "Date": "Mon, 10 Oct 2022 03:38:02 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-1ca54673d22cad10dfd27eaf8a3e40ac-ca3f9c602b35f61c-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-ca5dbe5dbfaaae37a9c6e3f20b0896b9-aab31ddc67af66f8-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "f5fcb48a-fb49-4e9f-9359-36281c6c5acd", - "x-ms-ratelimit-remaining-subscription-reads": "11986", + "x-ms-correlation-request-id": "de46581d-d660-47cf-a28c-9a341bf6a335", + "x-ms-ratelimit-remaining-subscription-reads": "11960", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151740Z:f5fcb48a-fb49-4e9f-9359-36281c6c5acd", - "x-request-time": "0.137" + "x-ms-routing-request-id": "JAPANEAST:20221010T033802Z:de46581d-d660-47cf-a28c-9a341bf6a335", + "x-request-time": "0.306" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_998170986493/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_77799589773/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -409,7 +409,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/DataTransferComponent.json", - "name": "test_998170986493", + "name": "test_77799589773", "version": "0.0.1", "display_name": "Data Transfer", "is_deterministic": "True", @@ -435,21 +435,21 @@ "datatransfer": { "allow_overwrite": "True" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/adbb1689-e476-4344-8db5-2e4c692f650a/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/e4143c07-53b4-4159-a962-a0c3efc68cc3/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:17:39.6196727\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:38:00.8173523\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:17:39.8126339\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T03:38:01.4696741\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } } ], "Variables": { - "component_name": "test_998170986493" + "component_name": "test_77799589773" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/distribution-component/component_spec.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/distribution-component/component_spec.yaml].json index adaebfa88b51..7a99157f9502 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/distribution-component/component_spec.yaml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/distribution-component/component_spec.yaml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:12 GMT", + "Date": "Mon, 10 Oct 2022 03:37:17 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-c5416543248de72ee050acce86b15f88-4e4ee10502353b5f-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-9f1bc9bfcdffe835f46519eb5656e274-76e0e343a657d227-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "a3c84bd2-c878-4b11-ba1f-c42fb07031fc", - "x-ms-ratelimit-remaining-subscription-reads": "11997", + "x-ms-correlation-request-id": "c58687ea-dbd5-40a3-bbad-f9d41eb898df", + "x-ms-ratelimit-remaining-subscription-reads": "11971", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151713Z:a3c84bd2-c878-4b11-ba1f-c42fb07031fc", - "x-request-time": "0.088" + "x-ms-routing-request-id": "JAPANEAST:20221010T033718Z:c58687ea-dbd5-40a3-bbad-f9d41eb898df", + "x-request-time": "0.084" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sawcdivl5vo3cem", - "containerName": "azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-19T00:10:19.4497254\u002B00:00", + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-19T00:10:20.0957203\u002B00:00", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:13 GMT", + "Date": "Mon, 10 Oct 2022 03:37:18 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-43081114ee91850cc0e4e83b795f3d86-c6b257db2d894144-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-a5bc60a7140798044d2176601f0c003d-8dec73fc3fe28996-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "47540569-e5e6-41fd-b97c-3864917b4f52", - "x-ms-ratelimit-remaining-subscription-writes": "1198", + "x-ms-correlation-request-id": "e302e0dd-a888-45d5-94dc-a13d0a84a618", + "x-ms-ratelimit-remaining-subscription-writes": "1189", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151713Z:47540569-e5e6-41fd-b97c-3864917b4f52", - "x-request-time": "0.086" + "x-ms-routing-request-id": "JAPANEAST:20221010T033719Z:e302e0dd-a888-45d5-94dc-a13d0a84a618", + "x-request-time": "0.109" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,26 +101,26 @@ } }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/distribution-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/distribution-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:17:13 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:37:19 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Accept-Ranges": "bytes", - "Content-Length": "958", - "Content-MD5": "eBpew2DsgVPNUdWwo1Ymyg==", + "Content-Length": "758", + "Content-MD5": "btu6HWM/OieNWo2NW/ZsWA==", "Content-Type": "application/octet-stream", - "Date": "Mon, 19 Sep 2022 15:17:13 GMT", - "ETag": "\u00220x8DA99D37719D33D\u0022", - "Last-Modified": "Mon, 19 Sep 2022 00:11:14 GMT", + "Date": "Mon, 10 Oct 2022 03:37:18 GMT", + "ETag": "\u00220x8DAAA6EED25D44D\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:24:22 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 19 Sep 2022 00:11:14 GMT", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:24:22 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "de780bcc-4585-439e-9768-8971bc5798cf", + "x-ms-meta-name": "d6667388-5223-4184-8359-e2929a825e06", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/az-ml-artifacts/00000000000000000000000000000000/distribution-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/distribution-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:17:13 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:37:19 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 19 Sep 2022 15:17:13 GMT", + "Date": "Mon, 10 Oct 2022 03:37:18 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/de780bcc-4585-439e-9768-8971bc5798cf/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "311", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/distribution-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/distribution-component" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:14 GMT", + "Date": "Mon, 10 Oct 2022 03:37:19 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-0d7ca7787ece7b380a574718a1ad01c2-7d7bbae064da180d-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-28366894c0b6f06ef0a74dd3be7ffe7f-3cb25a59db60870f-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "9bfe1307-ed53-4a93-a51f-7f926917b81c", - "x-ms-ratelimit-remaining-subscription-writes": "1197", + "x-ms-correlation-request-id": "294c0b45-520e-4089-bf86-a334cea15b63", + "x-ms-ratelimit-remaining-subscription-writes": "1179", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151715Z:9bfe1307-ed53-4a93-a51f-7f926917b81c", - "x-request-time": "0.065" + "x-ms-routing-request-id": "JAPANEAST:20221010T033720Z:294c0b45-520e-4089-bf86-a334cea15b63", + "x-request-time": "0.177" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/de780bcc-4585-439e-9768-8971bc5798cf/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,20 +225,20 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/distribution-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/distribution-component" }, "systemData": { - "createdAt": "2022-09-19T00:11:14.8305647\u002B00:00", - "createdBy": "10832f61-6ea1-44eb-9622-85f30271eec4", - "createdByType": "Application", - "lastModifiedAt": "2022-09-19T15:17:15.0820131\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:24:23.5013448\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:37:20.0338169\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_201577231156/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_126361557276/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "1078", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -255,7 +255,7 @@ "isAnonymous": false, "isArchived": false, "componentSpec": { - "name": "test_201577231156", + "name": "test_126361557276", "tags": {}, "version": "0.0.1", "$schema": "https://componentsdk.azureedge.net/jsonschema/DistributedComponent.json", @@ -278,7 +278,7 @@ } }, "type": "DistributedComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/de780bcc-4585-439e-9768-8971bc5798cf/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1", "environment": { "os": "Linux", "name": "AzureML-Minimal" @@ -293,25 +293,25 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2071", + "Content-Length": "2069", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:17 GMT", + "Date": "Mon, 10 Oct 2022 03:37:22 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_201577231156/versions/0.0.1?api-version=2022-05-01", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_126361557276/versions/0.0.1?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-b3023ec40c2bf0f9dc136cf8a1b1a226-f3a1449f8ca8a92b-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-6dc4e393cfc3fa73441cd570eff2576b-986970d8cbb68b75-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "33f9593c-9121-41f3-8550-19dc063e28a1", - "x-ms-ratelimit-remaining-subscription-writes": "1196", + "x-ms-correlation-request-id": "af6ff58b-b49b-4201-9efa-e246e5bd7373", + "x-ms-ratelimit-remaining-subscription-writes": "1178", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151717Z:33f9593c-9121-41f3-8550-19dc063e28a1", - "x-request-time": "0.673" + "x-ms-routing-request-id": "JAPANEAST:20221010T033723Z:af6ff58b-b49b-4201-9efa-e246e5bd7373", + "x-request-time": "2.288" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_201577231156/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_126361557276/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -322,7 +322,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/DistributedComponent.json", - "name": "test_201577231156", + "name": "test_126361557276", "version": "0.0.1", "display_name": "MPI Example", "is_deterministic": "True", @@ -355,27 +355,27 @@ "type": "mpi", "additional_arguments": "python train.py --input-path {inputs.input_path} [--string-parameter {inputs.string_parameter}] --output-path {outputs.output_path}" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/de780bcc-4585-439e-9768-8971bc5798cf/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:17:17.4457921\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:37:21.9743931\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:17:17.6557793\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T03:37:22.5683181\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_201577231156/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_126361557276/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "GET", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -383,27 +383,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:17 GMT", + "Date": "Mon, 10 Oct 2022 03:37:22 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-4099ab8acc81dc3d04e01ce779db6dd9-ceb2e3d2e5921889-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-d3549a1014b778c27188bea7a32a27dd-586fd4e2030674b2-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "75e42eac-1885-46c3-b8a6-e18118ff3186", - "x-ms-ratelimit-remaining-subscription-reads": "11996", + "x-ms-correlation-request-id": "f31dc110-24d0-4da0-b893-80812c9a8382", + "x-ms-ratelimit-remaining-subscription-reads": "11970", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151718Z:75e42eac-1885-46c3-b8a6-e18118ff3186", - "x-request-time": "0.134" + "x-ms-routing-request-id": "JAPANEAST:20221010T033723Z:f31dc110-24d0-4da0-b893-80812c9a8382", + "x-request-time": "0.325" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_201577231156/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_126361557276/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -414,7 +414,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/DistributedComponent.json", - "name": "test_201577231156", + "name": "test_126361557276", "version": "0.0.1", "display_name": "MPI Example", "is_deterministic": "True", @@ -447,21 +447,21 @@ "type": "mpi", "additional_arguments": "python train.py --input-path {inputs.input_path} [--string-parameter {inputs.string_parameter}] --output-path {outputs.output_path}" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/de780bcc-4585-439e-9768-8971bc5798cf/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:17:17.4457921\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:37:21.9743931\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:17:17.6557793\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T03:37:22.5683181\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } } ], "Variables": { - "component_name": "test_201577231156" + "component_name": "test_126361557276" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/hdi-component/component_spec.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/hdi-component/component_spec.yaml].json index 2394e1b83d3b..84dcbdee9b8c 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/hdi-component/component_spec.yaml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/hdi-component/component_spec.yaml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:27 GMT", + "Date": "Mon, 10 Oct 2022 03:37:41 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-5d3c40d4d5f3003c787f3dbe7c1391a7-acbda337784ef435-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-3930948679723a099a2962f56dd22f69-c7a8df68d638ebf3-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "b6600dfe-c4fd-496d-b142-63d1e3e10f13", - "x-ms-ratelimit-remaining-subscription-reads": "11991", + "x-ms-correlation-request-id": "00cd93a5-2480-404f-8129-294f2057d9e8", + "x-ms-ratelimit-remaining-subscription-reads": "11965", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151728Z:b6600dfe-c4fd-496d-b142-63d1e3e10f13", - "x-request-time": "0.080" + "x-ms-routing-request-id": "JAPANEAST:20221010T033742Z:00cd93a5-2480-404f-8129-294f2057d9e8", + "x-request-time": "0.091" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sawcdivl5vo3cem", - "containerName": "azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-19T00:10:19.4497254\u002B00:00", + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-19T00:10:20.0957203\u002B00:00", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:27 GMT", + "Date": "Mon, 10 Oct 2022 03:37:42 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-ab6b7d4b9bdf6d8d405966cc8bdb3b14-e049849978335f96-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-8ac70227270d5ce2188abfd11ee5f63c-cc7b8075bb030f23-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "56f42c8f-fbc5-4f50-858e-d2940449e02e", - "x-ms-ratelimit-remaining-subscription-writes": "1195", + "x-ms-correlation-request-id": "41a1e402-4b57-4d87-adae-fad058fc0727", + "x-ms-ratelimit-remaining-subscription-writes": "1186", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151728Z:56f42c8f-fbc5-4f50-858e-d2940449e02e", - "x-request-time": "0.090" + "x-ms-routing-request-id": "JAPANEAST:20221010T033743Z:41a1e402-4b57-4d87-adae-fad058fc0727", + "x-request-time": "0.475" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,26 +101,26 @@ } }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/hdi-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/hdi-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:17:28 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:37:43 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Accept-Ranges": "bytes", - "Content-Length": "1108", - "Content-MD5": "YwjqftKHRlA4Fjk2RZSO8w==", + "Content-Length": "996", + "Content-MD5": "YQpjQbTaabwHHrCyGPUlDQ==", "Content-Type": "application/octet-stream", - "Date": "Mon, 19 Sep 2022 15:17:28 GMT", - "ETag": "\u00220x8DA99D377591D0C\u0022", - "Last-Modified": "Mon, 19 Sep 2022 00:11:14 GMT", + "Date": "Mon, 10 Oct 2022 03:37:42 GMT", + "ETag": "\u00220x8DAAA7098D2C25D\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:36:20 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 19 Sep 2022 00:11:14 GMT", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:36:19 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "d2c00006-beca-4b1a-a8b3-e9f8a3c02817", + "x-ms-meta-name": "000000000000000000000", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/az-ml-artifacts/00000000000000000000000000000000/hdi-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/hdi-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:17:28 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:37:43 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 19 Sep 2022 15:17:28 GMT", + "Date": "Mon, 10 Oct 2022 03:37:42 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d2c00006-beca-4b1a-a8b3-e9f8a3c02817/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "302", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/hdi-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/hdi-component" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:28 GMT", + "Date": "Mon, 10 Oct 2022 03:37:43 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-db28296c040c5dec77a1fe59bd5c4faf-5b5d39f17947b619-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-1dbe9a0ffe7630b28ab511b109422ddf-90c7b4ef207257b8-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "324b38fb-0492-4315-861b-ae9ed2ada430", - "x-ms-ratelimit-remaining-subscription-writes": "1191", + "x-ms-correlation-request-id": "c14aaba5-eca9-4dc9-bc3a-092a9af4b0a4", + "x-ms-ratelimit-remaining-subscription-writes": "1173", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151728Z:324b38fb-0492-4315-861b-ae9ed2ada430", - "x-request-time": "0.059" + "x-ms-routing-request-id": "JAPANEAST:20221010T033744Z:c14aaba5-eca9-4dc9-bc3a-092a9af4b0a4", + "x-request-time": "0.203" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d2c00006-beca-4b1a-a8b3-e9f8a3c02817/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,28 +225,28 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/hdi-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/hdi-component" }, "systemData": { - "createdAt": "2022-09-19T00:11:15.2501424\u002B00:00", - "createdBy": "10832f61-6ea1-44eb-9622-85f30271eec4", - "createdByType": "Application", - "lastModifiedAt": "2022-09-19T15:17:28.8906206\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:36:21.0505082\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:37:44.0290489\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_931762562786/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_358937268964/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "1454", + "Content-Length": "1439", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -261,7 +261,7 @@ "isAnonymous": false, "isArchived": false, "componentSpec": { - "name": "test_931762562786", + "name": "test_358937268964", "description": "Train a Spark ML model using an HDInsight Spark cluster", "tags": { "HDInsight": "", @@ -291,7 +291,7 @@ } }, "type": "HDInsightComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d2c00006-beca-4b1a-a8b3-e9f8a3c02817/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1", "hdinsight": { "file": "train-spark.py", "args": "--input_path {inputs.input_path} [--regularization_rate {inputs.regularization_rate}] --output_path {outputs.output_path}" @@ -302,25 +302,25 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2374", + "Content-Length": "2356", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:28 GMT", + "Date": "Mon, 10 Oct 2022 03:37:47 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_931762562786/versions/0.0.1?api-version=2022-05-01", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_358937268964/versions/0.0.1?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-29605143d8809c27f546be3178526c22-e2d2042727f2ed07-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-14768b132f953c560a70d7dccb06a436-77d4266c836bc2b1-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "86b7fee4-8022-4db3-9ebe-7f80f1a78c1c", - "x-ms-ratelimit-remaining-subscription-writes": "1190", + "x-ms-correlation-request-id": "55c696d1-67c6-4715-81fc-464a640fb4cc", + "x-ms-ratelimit-remaining-subscription-writes": "1172", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151729Z:86b7fee4-8022-4db3-9ebe-7f80f1a78c1c", - "x-request-time": "0.631" + "x-ms-routing-request-id": "JAPANEAST:20221010T033747Z:55c696d1-67c6-4715-81fc-464a640fb4cc", + "x-request-time": "1.603" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_931762562786/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_358937268964/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -336,7 +336,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/HDInsightComponent.json", - "name": "test_931762562786", + "name": "test_358937268964", "version": "0.0.1", "display_name": "Train in Spark", "is_deterministic": "True", @@ -371,27 +371,27 @@ "args": "--input_path {inputs.input_path} [--regularization_rate {inputs.regularization_rate}] --output_path {outputs.output_path}", "file": "train-spark.py" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d2c00006-beca-4b1a-a8b3-e9f8a3c02817/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:17:29.3876758\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:37:46.0009983\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:17:29.5837427\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T03:37:46.619723\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_931762562786/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_358937268964/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "GET", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -399,27 +399,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:29 GMT", + "Date": "Mon, 10 Oct 2022 03:37:47 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-9ab4dc2521f28a7d283467014ea47806-da2335390d793206-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-a0d766fecc69672194c0d5690b0174be-1f00fe54654ca440-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "1dd42d99-6ebf-4e4b-973e-55559d14f2fc", - "x-ms-ratelimit-remaining-subscription-reads": "11990", + "x-ms-correlation-request-id": "f23b96af-370e-4aa9-b312-497f4f800855", + "x-ms-ratelimit-remaining-subscription-reads": "11964", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151730Z:1dd42d99-6ebf-4e4b-973e-55559d14f2fc", - "x-request-time": "0.135" + "x-ms-routing-request-id": "JAPANEAST:20221010T033747Z:f23b96af-370e-4aa9-b312-497f4f800855", + "x-request-time": "0.316" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_931762562786/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_358937268964/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -435,7 +435,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/HDInsightComponent.json", - "name": "test_931762562786", + "name": "test_358937268964", "version": "0.0.1", "display_name": "Train in Spark", "is_deterministic": "True", @@ -470,21 +470,21 @@ "args": "--input_path {inputs.input_path} [--regularization_rate {inputs.regularization_rate}] --output_path {outputs.output_path}", "file": "train-spark.py" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d2c00006-beca-4b1a-a8b3-e9f8a3c02817/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:17:29.3876758\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:37:46.0009983\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:17:29.5837427\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T03:37:46.619723\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } } ], "Variables": { - "component_name": "test_931762562786" + "component_name": "test_358937268964" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/hemera-component/component.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/hemera-component/component.yaml].json index e12f449ee8fc..99b3f60f7642 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/hemera-component/component.yaml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/hemera-component/component.yaml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:31 GMT", + "Date": "Mon, 10 Oct 2022 03:37:50 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-93e55a1213c1761ecd610266611098ea-dc1df489e868fb20-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-47289cd2bdd64394b6c1d00095f68bcf-d6e667bf6e6a0f21-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "68fb95ae-9ab0-4000-8a18-e44feb5134d9", - "x-ms-ratelimit-remaining-subscription-reads": "11989", + "x-ms-correlation-request-id": "ff017e97-74af-4e13-8afc-8f044a80db69", + "x-ms-ratelimit-remaining-subscription-reads": "11963", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151732Z:68fb95ae-9ab0-4000-8a18-e44feb5134d9", - "x-request-time": "0.084" + "x-ms-routing-request-id": "JAPANEAST:20221010T033750Z:ff017e97-74af-4e13-8afc-8f044a80db69", + "x-request-time": "0.094" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sawcdivl5vo3cem", - "containerName": "azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-19T00:10:19.4497254\u002B00:00", + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-19T00:10:20.0957203\u002B00:00", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:32 GMT", + "Date": "Mon, 10 Oct 2022 03:37:51 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-39f8771141aa95f01e9d05cd99adb335-64aa4bf9c6d262f2-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-3b2a1ac945170812534b53914668d6dc-7a142f0807f5c26a-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "cffbdfbb-5cab-479a-9a12-d4703943d936", - "x-ms-ratelimit-remaining-subscription-writes": "1194", + "x-ms-correlation-request-id": "1ad6f51d-e333-405c-a780-d949b97512f8", + "x-ms-ratelimit-remaining-subscription-writes": "1185", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151733Z:cffbdfbb-5cab-479a-9a12-d4703943d936", - "x-request-time": "0.094" + "x-ms-routing-request-id": "JAPANEAST:20221010T033751Z:1ad6f51d-e333-405c-a780-d949b97512f8", + "x-request-time": "0.107" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,26 +101,26 @@ } }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/hemera-component/component.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/hemera-component/component.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:17:33 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:37:51 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Accept-Ranges": "bytes", - "Content-Length": "2180", - "Content-MD5": "vW/0UQWaDxIzmm/HEeANvA==", + "Content-Length": "1905", + "Content-MD5": "AcQHpefZr524XtHJQHzR7Q==", "Content-Type": "application/octet-stream", - "Date": "Mon, 19 Sep 2022 15:17:32 GMT", - "ETag": "\u00220x8DA99D377487DA0\u0022", - "Last-Modified": "Mon, 19 Sep 2022 00:11:14 GMT", + "Date": "Mon, 10 Oct 2022 03:37:50 GMT", + "ETag": "\u00220x8DAAA6F020D13E0\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:24:57 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 19 Sep 2022 00:11:14 GMT", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:24:57 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "6651a080-8439-48fc-9469-ed56845fb6ea", + "x-ms-meta-name": "efc28047-774b-4de0-8703-4c096cd4319e", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/az-ml-artifacts/00000000000000000000000000000000/hemera-component/component.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/hemera-component/component.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:17:33 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:37:51 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 19 Sep 2022 15:17:32 GMT", + "Date": "Mon, 10 Oct 2022 03:37:50 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/6651a080-8439-48fc-9469-ed56845fb6ea/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/efc28047-774b-4de0-8703-4c096cd4319e/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "305", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/hemera-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/hemera-component" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:32 GMT", + "Date": "Mon, 10 Oct 2022 03:37:52 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-26b8c73f4f4907c62fb66aa3777816da-3ae2df7b53379c0c-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-a0fee97cc672ef961344610a248ddea1-d52a601e499bc1e1-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "243bddfb-f2f7-4e5c-b569-c1ebc2301769", - "x-ms-ratelimit-remaining-subscription-writes": "1189", + "x-ms-correlation-request-id": "8e3e08e4-a796-4433-8aa3-e4d8e002e4a7", + "x-ms-ratelimit-remaining-subscription-writes": "1171", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151733Z:243bddfb-f2f7-4e5c-b569-c1ebc2301769", - "x-request-time": "0.067" + "x-ms-routing-request-id": "JAPANEAST:20221010T033752Z:8e3e08e4-a796-4433-8aa3-e4d8e002e4a7", + "x-request-time": "0.178" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/6651a080-8439-48fc-9469-ed56845fb6ea/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/efc28047-774b-4de0-8703-4c096cd4319e/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,20 +225,20 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/hemera-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/hemera-component" }, "systemData": { - "createdAt": "2022-09-19T00:11:15.1784471\u002B00:00", - "createdBy": "10832f61-6ea1-44eb-9622-85f30271eec4", - "createdByType": "Application", - "lastModifiedAt": "2022-09-19T15:17:33.5822077\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:24:58.5267334\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:37:52.1544761\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_501212454601/versions/0.0.2?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_484451349333/versions/0.0.2?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "2227", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -259,7 +259,7 @@ "isAnonymous": false, "isArchived": false, "componentSpec": { - "name": "test_501212454601", + "name": "test_484451349333", "description": "Ads LR DNN Raw Keys Dummy sample.", "tags": { "category": "Component Tutorial", @@ -322,7 +322,7 @@ } }, "type": "HemeraComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/6651a080-8439-48fc-9469-ed56845fb6ea/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/efc28047-774b-4de0-8703-4c096cd4319e/versions/1", "command": "run.bat [-_TrainingDataDir {inputs.TrainingDataDir}] [-_ValidationDataDir {inputs.ValidationDataDir}] [-_InitialModelDir {inputs.InitialModelDir}] -_CosmosRootDir {inputs.CosmosRootDir} -_PsCount 0 %CLUSTER%={inputs.YarnCluster} -JobQueue {inputs.JobQueue} -_WorkerCount {inputs.WorkerCount} -_Cpu {inputs.Cpu} -_Memory {inputs.Memory} -_HdfsRootDir {inputs.HdfsRootDir} -_ExposedPort \u00223200-3210,3300-3321\u0022 -_NodeLostBlocker -_UsePhysicalIP -_SyncWorker -_EntranceFileName run.py -_StartupArguments \u0022\u0022 -_PythonZipPath \u0022https://dummy/foo/bar.zip\u0022 -_ModelOutputDir {outputs.output1} -_ValidationOutputDir {outputs.output2}", "hemera": { "ref_id": "1bd1525c-082e-4652-a9b2-9c60783ec551" @@ -333,25 +333,25 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "3665", + "Content-Length": "3663", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:34 GMT", + "Date": "Mon, 10 Oct 2022 03:37:54 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_501212454601/versions/0.0.2?api-version=2022-05-01", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_484451349333/versions/0.0.2?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-eaab24504169daea7841c4e612cb4a1a-cfad823cd6ac9727-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-e7b60bc5c270523c2f5e503f0467761d-14b3180fefcc721d-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "82b72c51-8335-4c4c-b4f4-b6d7393f62de", - "x-ms-ratelimit-remaining-subscription-writes": "1188", + "x-ms-correlation-request-id": "bdf49ef8-8d25-48e8-9d4a-a5ddc57a97c6", + "x-ms-ratelimit-remaining-subscription-writes": "1170", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151735Z:82b72c51-8335-4c4c-b4f4-b6d7393f62de", - "x-request-time": "0.807" + "x-ms-routing-request-id": "JAPANEAST:20221010T033754Z:bdf49ef8-8d25-48e8-9d4a-a5ddc57a97c6", + "x-request-time": "1.650" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_501212454601/versions/0.0.2", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_484451349333/versions/0.0.2", "name": "0.0.2", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -365,7 +365,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/HemeraComponent.json", - "name": "test_501212454601", + "name": "test_484451349333", "version": "0.0.2", "display_name": "Ads LR DNN Raw Keys", "is_deterministic": "True", @@ -439,27 +439,27 @@ "hemera": { "ref_id": "1bd1525c-082e-4652-a9b2-9c60783ec551" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/6651a080-8439-48fc-9469-ed56845fb6ea/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/efc28047-774b-4de0-8703-4c096cd4319e/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:17:35.3081241\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:37:53.2369259\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:17:35.5850382\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T03:37:53.8858086\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_501212454601/versions/0.0.2?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_484451349333/versions/0.0.2?api-version=2022-05-01", "RequestMethod": "GET", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -467,27 +467,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:35 GMT", + "Date": "Mon, 10 Oct 2022 03:37:54 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-6f84f5d4202e4597ced55373465f40fc-fe8c1f26048febf4-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-70b2329a17f21843cfcdfe37443b942c-50ed7c0b681250dc-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "b3553b0b-c3be-45a7-8c82-33e1fbe95404", - "x-ms-ratelimit-remaining-subscription-reads": "11988", + "x-ms-correlation-request-id": "6402af45-d389-4d02-8e8c-d55c2520f9df", + "x-ms-ratelimit-remaining-subscription-reads": "11962", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151736Z:b3553b0b-c3be-45a7-8c82-33e1fbe95404", - "x-request-time": "0.127" + "x-ms-routing-request-id": "JAPANEAST:20221010T033755Z:6402af45-d389-4d02-8e8c-d55c2520f9df", + "x-request-time": "0.313" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_501212454601/versions/0.0.2", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_484451349333/versions/0.0.2", "name": "0.0.2", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -501,7 +501,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/HemeraComponent.json", - "name": "test_501212454601", + "name": "test_484451349333", "version": "0.0.2", "display_name": "Ads LR DNN Raw Keys", "is_deterministic": "True", @@ -575,21 +575,21 @@ "hemera": { "ref_id": "1bd1525c-082e-4652-a9b2-9c60783ec551" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/6651a080-8439-48fc-9469-ed56845fb6ea/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/efc28047-774b-4de0-8703-4c096cd4319e/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:17:35.3081241\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:37:53.2369259\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:17:35.5850382\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T03:37:53.8858086\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } } ], "Variables": { - "component_name": "test_501212454601" + "component_name": "test_484451349333" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/scope-component/component_spec.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/scope-component/component_spec.yaml].json index b261e37802d8..583dd7ab9617 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/scope-component/component_spec.yaml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/scope-component/component_spec.yaml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:22 GMT", + "Date": "Mon, 10 Oct 2022 03:37:34 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-b836b006939a739db6e350fed6880d63-81dd7bcf48fa8d4f-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-d14806a32e835f8f2ed8f8420c400271-4f95095e2e0231dc-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "93dc251e-df6f-4a0b-92f8-d1a4f4b70796", - "x-ms-ratelimit-remaining-subscription-reads": "11993", + "x-ms-correlation-request-id": "fb4cb150-4f33-465d-8cda-8c32e723a77c", + "x-ms-ratelimit-remaining-subscription-reads": "11967", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151723Z:93dc251e-df6f-4a0b-92f8-d1a4f4b70796", - "x-request-time": "0.081" + "x-ms-routing-request-id": "JAPANEAST:20221010T033734Z:fb4cb150-4f33-465d-8cda-8c32e723a77c", + "x-request-time": "0.098" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sawcdivl5vo3cem", - "containerName": "azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-19T00:10:19.4497254\u002B00:00", + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-19T00:10:20.0957203\u002B00:00", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:24 GMT", + "Date": "Mon, 10 Oct 2022 03:37:34 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-c2d6f4a2a9bc1c0ff445c404dceafd85-929bb89acd8a5dfb-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-73ceba52ec77913d187c1b8ba49f8c6b-748870a2c7843417-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "7ffc03d3-b629-4cc0-9837-4cfea96cced2", - "x-ms-ratelimit-remaining-subscription-writes": "1196", + "x-ms-correlation-request-id": "df5138f8-1049-4337-853a-cc34e36fb20f", + "x-ms-ratelimit-remaining-subscription-writes": "1187", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151725Z:7ffc03d3-b629-4cc0-9837-4cfea96cced2", - "x-request-time": "0.103" + "x-ms-routing-request-id": "JAPANEAST:20221010T033735Z:df5138f8-1049-4337-853a-cc34e36fb20f", + "x-request-time": "0.172" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,26 +101,26 @@ } }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/scope-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/scope-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:17:25 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:37:35 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Accept-Ranges": "bytes", - "Content-Length": "1019", - "Content-MD5": "i97q7IVRlx2GMLweS1KokQ==", + "Content-Length": "953", + "Content-MD5": "nzd\u002BWLaPsJr2Y3ztm3VoLA==", "Content-Type": "application/octet-stream", - "Date": "Mon, 19 Sep 2022 15:17:24 GMT", - "ETag": "\u00220x8DA99D377064E0F\u0022", - "Last-Modified": "Mon, 19 Sep 2022 00:11:14 GMT", + "Date": "Mon, 10 Oct 2022 03:37:34 GMT", + "ETag": "\u00220x8DAAA6EF7A050E5\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:24:40 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 19 Sep 2022 00:11:13 GMT", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:24:40 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "4b4bf3c2-e55f-4063-847f-199c6dad33e2", + "x-ms-meta-name": "4e34db7e-7e36-4abd-a6c8-3d7fd02cc1c2", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/az-ml-artifacts/00000000000000000000000000000000/scope-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/scope-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:17:25 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:37:35 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 19 Sep 2022 15:17:24 GMT", + "Date": "Mon, 10 Oct 2022 03:37:35 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4b4bf3c2-e55f-4063-847f-199c6dad33e2/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4e34db7e-7e36-4abd-a6c8-3d7fd02cc1c2/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "304", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/scope-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/scope-component" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:24 GMT", + "Date": "Mon, 10 Oct 2022 03:37:35 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-fc33edc0a2ccc734667cb2b05106304b-2856ec10d440157e-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-bfd9fe636a76d5cc346bc2cde7106637-bb3272d9d1084112-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "95fb1515-72fd-41c0-a136-684403ab2918", - "x-ms-ratelimit-remaining-subscription-writes": "1193", + "x-ms-correlation-request-id": "935a0a99-8c81-42f5-8f32-860fe3145751", + "x-ms-ratelimit-remaining-subscription-writes": "1175", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151725Z:95fb1515-72fd-41c0-a136-684403ab2918", - "x-request-time": "0.066" + "x-ms-routing-request-id": "JAPANEAST:20221010T033736Z:935a0a99-8c81-42f5-8f32-860fe3145751", + "x-request-time": "0.175" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4b4bf3c2-e55f-4063-847f-199c6dad33e2/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4e34db7e-7e36-4abd-a6c8-3d7fd02cc1c2/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,20 +225,20 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/scope-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/scope-component" }, "systemData": { - "createdAt": "2022-09-19T00:11:14.7337825\u002B00:00", - "createdBy": "10832f61-6ea1-44eb-9622-85f30271eec4", - "createdByType": "Application", - "lastModifiedAt": "2022-09-19T15:17:25.6357898\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:24:41.2456668\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:37:36.2660038\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_466855443205/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_856504399079/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "1242", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -259,7 +259,7 @@ "isAnonymous": false, "isArchived": false, "componentSpec": { - "name": "test_466855443205", + "name": "test_856504399079", "description": "Convert adls test data to SS format", "tags": { "org": "bing", @@ -289,7 +289,7 @@ } }, "type": "ScopeComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4b4bf3c2-e55f-4063-847f-199c6dad33e2/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4e34db7e-7e36-4abd-a6c8-3d7fd02cc1c2/versions/1", "scope": { "script": "convert2ss.script", "args": "Output_SSPath {outputs.SSPath} Input_TextData {inputs.TextData} ExtractionClause {inputs.ExtractionClause}" @@ -300,25 +300,25 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2204", + "Content-Length": "2203", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:25 GMT", + "Date": "Mon, 10 Oct 2022 03:37:37 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_466855443205/versions/0.0.1?api-version=2022-05-01", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_856504399079/versions/0.0.1?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-b97f995e69b8f6327fecc3fc299689ea-61c6e6f9c0fd9b91-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-cb42fc2da1f587885fadea3dd6631368-cca958f353a1e105-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "97720f93-f5aa-4fe9-9332-3958cf165e70", - "x-ms-ratelimit-remaining-subscription-writes": "1192", + "x-ms-correlation-request-id": "67131b36-0118-4a48-b994-265f15a563b3", + "x-ms-ratelimit-remaining-subscription-writes": "1174", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151726Z:97720f93-f5aa-4fe9-9332-3958cf165e70", - "x-request-time": "0.632" + "x-ms-routing-request-id": "JAPANEAST:20221010T033738Z:67131b36-0118-4a48-b994-265f15a563b3", + "x-request-time": "1.598" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_466855443205/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_856504399079/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -332,7 +332,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/ScopeComponent.json", - "name": "test_466855443205", + "name": "test_856504399079", "version": "0.0.1", "display_name": "Convert Text to StructureStream", "is_deterministic": "True", @@ -368,27 +368,27 @@ "args": "Input_TextData {inputs.TextData} Output_SSPath {outputs.SSPath} ExtractionClause {inputs.ExtractionClause}", "script": "convert2ss.script" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4b4bf3c2-e55f-4063-847f-199c6dad33e2/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4e34db7e-7e36-4abd-a6c8-3d7fd02cc1c2/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:17:26.188144\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:37:37.3956199\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:17:26.3957271\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T03:37:38.0143747\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_466855443205/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_856504399079/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "GET", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -396,27 +396,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:26 GMT", + "Date": "Mon, 10 Oct 2022 03:37:38 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-5e766d62a0c8f4bb9861445cf14b883b-1bf82d9209012709-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-7136abec48890f340407001dd1b5208f-c46643deb7e80040-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "2756e371-ee1d-4ff4-addc-d7cb852b3f5e", - "x-ms-ratelimit-remaining-subscription-reads": "11992", + "x-ms-correlation-request-id": "4152bf27-ca30-4aa2-8a26-f7b2c30706fa", + "x-ms-ratelimit-remaining-subscription-reads": "11966", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151726Z:2756e371-ee1d-4ff4-addc-d7cb852b3f5e", - "x-request-time": "0.167" + "x-ms-routing-request-id": "JAPANEAST:20221010T033739Z:4152bf27-ca30-4aa2-8a26-f7b2c30706fa", + "x-request-time": "0.324" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_466855443205/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_856504399079/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -430,7 +430,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/ScopeComponent.json", - "name": "test_466855443205", + "name": "test_856504399079", "version": "0.0.1", "display_name": "Convert Text to StructureStream", "is_deterministic": "True", @@ -466,21 +466,21 @@ "args": "Input_TextData {inputs.TextData} Output_SSPath {outputs.SSPath} ExtractionClause {inputs.ExtractionClause}", "script": "convert2ss.script" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4b4bf3c2-e55f-4063-847f-199c6dad33e2/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/4e34db7e-7e36-4abd-a6c8-3d7fd02cc1c2/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:17:26.188144\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:37:37.3956199\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:17:26.3957271\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T03:37:38.0143747\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } } ], "Variables": { - "component_name": "test_466855443205" + "component_name": "test_856504399079" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/starlite-component/component_spec.yaml].json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/starlite-component/component_spec.yaml].json index 6764801156a5..fce46a1d81c9 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/starlite-component/component_spec.yaml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_component.pyTestComponenttest_component_load[tests/test_configs/internal/starlite-component/component_spec.yaml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:40 GMT", + "Date": "Mon, 10 Oct 2022 03:38:06 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-9a205ba7a809c76c4673f0c81c07e1c4-a8b0b40cded640dd-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-b18dc08962b5806c7eccf06c53ce5bc9-d11c8ed67f6c18d7-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "c683aff1-b681-476f-b487-611372ff50a6", - "x-ms-ratelimit-remaining-subscription-reads": "11985", + "x-ms-correlation-request-id": "ec6d6e97-3092-4ee1-8b15-f13e95045129", + "x-ms-ratelimit-remaining-subscription-reads": "11959", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151741Z:c683aff1-b681-476f-b487-611372ff50a6", - "x-request-time": "0.082" + "x-ms-routing-request-id": "JAPANEAST:20221010T033806Z:ec6d6e97-3092-4ee1-8b15-f13e95045129", + "x-request-time": "0.103" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sawcdivl5vo3cem", - "containerName": "azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-19T00:10:19.4497254\u002B00:00", + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-19T00:10:20.0957203\u002B00:00", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:43 GMT", + "Date": "Mon, 10 Oct 2022 03:38:06 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-9a6c10d59ecf473a21ce235e444135e2-addaf5971dde9252-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-fb8b71c9fc3c3f6dc348c1a05f711e72-7726d643eef6c9f0-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "d2aee934-ec24-4a82-81ec-fc9f8647a2be", - "x-ms-ratelimit-remaining-subscription-writes": "1192", + "x-ms-correlation-request-id": "7db4f682-b2e2-4a82-83d7-429050ab957e", + "x-ms-ratelimit-remaining-subscription-writes": "1183", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151744Z:d2aee934-ec24-4a82-81ec-fc9f8647a2be", - "x-request-time": "0.186" + "x-ms-routing-request-id": "JAPANEAST:20221010T033806Z:7db4f682-b2e2-4a82-83d7-429050ab957e", + "x-request-time": "0.087" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,26 +101,26 @@ } }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/starlite-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/starlite-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:17:43 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:38:06 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Accept-Ranges": "bytes", - "Content-Length": "1427", - "Content-MD5": "ZRCutAxRih0\u002BenvTNIIfbw==", + "Content-Length": "1232", + "Content-MD5": "qEc1N\u002BFt8RxWIrBMsd03jw==", "Content-Type": "application/octet-stream", - "Date": "Mon, 19 Sep 2022 15:17:43 GMT", - "ETag": "\u00220x8DA99D3774B8A71\u0022", - "Last-Modified": "Mon, 19 Sep 2022 00:11:14 GMT", + "Date": "Mon, 10 Oct 2022 03:38:06 GMT", + "ETag": "\u00220x8DAAA6F0BD94188\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:25:14 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 19 Sep 2022 00:11:14 GMT", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:25:14 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "3a36feb7-dd71-4290-8c0b-4232ea316e59", + "x-ms-meta-name": "f70de239-c1fe-4f08-ad76-2fdcd854c468", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/az-ml-artifacts/00000000000000000000000000000000/starlite-component/component_spec.loaded_from_rest.json", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/starlite-component/component_spec.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Mon, 19 Sep 2022 15:17:43 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:38:06 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 19 Sep 2022 15:17:43 GMT", + "Date": "Mon, 10 Oct 2022 03:38:06 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3a36feb7-dd71-4290-8c0b-4232ea316e59/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f70de239-c1fe-4f08-ad76-2fdcd854c468/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "307", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/starlite-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/starlite-component" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:43 GMT", + "Date": "Mon, 10 Oct 2022 03:38:07 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-3fadc57128131dd39dc436eea0d3f4f3-3eecd8403b5e7204-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-6784836458721ea35a69ecfc1644ed4f-d704b6508dd2b02b-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "ab3a2b37-7c15-42ae-8d3f-0629fa6bfbf8", - "x-ms-ratelimit-remaining-subscription-writes": "1185", + "x-ms-correlation-request-id": "1908a325-89e0-45eb-ad4a-ebbf7291cda6", + "x-ms-ratelimit-remaining-subscription-writes": "1167", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151744Z:ab3a2b37-7c15-42ae-8d3f-0629fa6bfbf8", - "x-request-time": "0.061" + "x-ms-routing-request-id": "JAPANEAST:20221010T033807Z:1908a325-89e0-45eb-ad4a-ebbf7291cda6", + "x-request-time": "0.209" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3a36feb7-dd71-4290-8c0b-4232ea316e59/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f70de239-c1fe-4f08-ad76-2fdcd854c468/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,20 +225,20 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sawcdivl5vo3cem.blob.core.windows.net/azureml-blobstore-e17a3673-0df1-4734-b827-58bdbe7ad5bc/LocalUpload/00000000000000000000000000000000/starlite-component" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/starlite-component" }, "systemData": { - "createdAt": "2022-09-19T00:11:15.1195181\u002B00:00", - "createdBy": "10832f61-6ea1-44eb-9622-85f30271eec4", - "createdByType": "Application", - "lastModifiedAt": "2022-09-19T15:17:44.578145\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:25:15.1852932\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:38:07.4950611\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_467933719687/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_345914782687/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "1717", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -259,7 +259,7 @@ "isAnonymous": false, "isArchived": false, "componentSpec": { - "name": "test_467933719687", + "name": "test_345914782687", "description": "Allows to download files from SearchGold to cosmos and get their revision information. \u0027FileList\u0027 input is a file with source depot paths, one per line.", "tags": { "category": "Component Tutorial", @@ -302,7 +302,7 @@ } }, "type": "StarliteComponent", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3a36feb7-dd71-4290-8c0b-4232ea316e59/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f70de239-c1fe-4f08-ad76-2fdcd854c468/versions/1", "command": "Starlite.Cloud.SourceDepotGet.exe /UploadToCosmos:{inputs.UploadToCosmos} /FileList:{inputs.FileList}{inputs.FileListFileName} /Files:{outputs.Files} /CosmosPath:{outputs.CosmosPath} /ResultInfo:{outputs.ResultInfo} \u0022\u0022", "starlite": { "ref_id": "bd140f4d-7775-4246-a75c-1c86df9536fb" @@ -313,25 +313,25 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2718", + "Content-Length": "2716", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:44 GMT", + "Date": "Mon, 10 Oct 2022 03:38:09 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_467933719687/versions/0.0.1?api-version=2022-05-01", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_345914782687/versions/0.0.1?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-dc9afa76e1d2e96de39a78478c7c4b59-6fe7eeb74bf91668-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-76f392ce8c6f7f1dbc182f185970f995-a444ce23debeb836-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "6604214d-ab37-4245-a772-c23cad07f9ca", - "x-ms-ratelimit-remaining-subscription-writes": "1184", + "x-ms-correlation-request-id": "45d0ad06-c7ed-4618-8bb9-df882572ca28", + "x-ms-ratelimit-remaining-subscription-writes": "1166", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151745Z:6604214d-ab37-4245-a772-c23cad07f9ca", - "x-request-time": "0.646" + "x-ms-routing-request-id": "JAPANEAST:20221010T033809Z:45d0ad06-c7ed-4618-8bb9-df882572ca28", + "x-request-time": "1.643" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_467933719687/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_345914782687/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -345,7 +345,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/StarliteComponent.json", - "name": "test_467933719687", + "name": "test_345914782687", "version": "0.0.1", "display_name": "Starlite SearchGold Get Files", "is_deterministic": "True", @@ -395,27 +395,27 @@ "starlite": { "ref_id": "bd140f4d-7775-4246-a75c-1c86df9536fb" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3a36feb7-dd71-4290-8c0b-4232ea316e59/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f70de239-c1fe-4f08-ad76-2fdcd854c468/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:17:45.1273389\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:38:08.6252166\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:17:45.3403365\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T03:38:09.2635632\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_467933719687/versions/0.0.1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_345914782687/versions/0.0.1?api-version=2022-05-01", "RequestMethod": "GET", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -423,27 +423,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 19 Sep 2022 15:17:44 GMT", + "Date": "Mon, 10 Oct 2022 03:38:10 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-01690e91640d023e95fa30ae4820b4b5-d187df87614cad99-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-5c836afe5f96654efb69ea840c9442ae-6bfbd92732b5af31-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-02", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "06452d00-b50b-4ab9-816f-d90105bba7f2", - "x-ms-ratelimit-remaining-subscription-reads": "11984", + "x-ms-correlation-request-id": "8c15ff22-a541-44c1-915b-50dd919ddb80", + "x-ms-ratelimit-remaining-subscription-reads": "11958", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220919T151745Z:06452d00-b50b-4ab9-816f-d90105bba7f2", - "x-request-time": "0.211" + "x-ms-routing-request-id": "JAPANEAST:20221010T033810Z:8c15ff22-a541-44c1-915b-50dd919ddb80", + "x-request-time": "0.305" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_467933719687/versions/0.0.1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/test_345914782687/versions/0.0.1", "name": "0.0.1", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { @@ -457,7 +457,7 @@ "isAnonymous": false, "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/StarliteComponent.json", - "name": "test_467933719687", + "name": "test_345914782687", "version": "0.0.1", "display_name": "Starlite SearchGold Get Files", "is_deterministic": "True", @@ -507,21 +507,21 @@ "starlite": { "ref_id": "bd140f4d-7775-4246-a75c-1c86df9536fb" }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3a36feb7-dd71-4290-8c0b-4232ea316e59/versions/1" + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f70de239-c1fe-4f08-ad76-2fdcd854c468/versions/1" } }, "systemData": { - "createdAt": "2022-09-19T15:17:45.1273389\u002B00:00", - "createdBy": "Neehar Duvvuri", + "createdAt": "2022-10-10T03:38:08.6252166\u002B00:00", + "createdBy": "Xingzhi Zhang", "createdByType": "User", - "lastModifiedAt": "2022-09-19T15:17:45.3403365\u002B00:00", - "lastModifiedBy": "Neehar Duvvuri", + "lastModifiedAt": "2022-10-10T03:38:09.2635632\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", "lastModifiedByType": "User" } } } ], "Variables": { - "component_name": "test_467933719687" + "component_name": "test_345914782687" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_pipeline_job.pyTestPipelineJobtest_data_as_node_inputs.json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_pipeline_job.pyTestPipelineJobtest_data_as_node_inputs.json new file mode 100644 index 000000000000..f8936644e763 --- /dev/null +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_pipeline_job.pyTestPipelineJobtest_data_as_node_inputs.json @@ -0,0 +1,707 @@ +{ + "Entries": [ + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster?api-version=2022-01-01-preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:46:05 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-2f80a300b38f4b3db8fae2672067a56c-9b83c94d2ea6cd5c-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "590b2f2c-ebd2-4e01-90e7-2dd1c1711eaa", + "x-ms-ratelimit-remaining-subscription-reads": "11910", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034605Z:590b2f2c-ebd2-4e01-90e7-2dd1c1711eaa", + "x-request-time": "0.226" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", + "name": "cpu-cluster", + "type": "Microsoft.MachineLearningServices/workspaces/computes", + "location": "centraluseuap", + "tags": {}, + "properties": { + "createdOn": "2022-09-22T09:02:22.1899959\u002B00:00", + "modifiedOn": "2022-09-23T03:28:18.0066218\u002B00:00", + "disableLocalAuth": false, + "description": null, + "resourceId": null, + "computeType": "AmlCompute", + "computeLocation": "centraluseuap", + "provisioningState": "Succeeded", + "provisioningErrors": null, + "isAttachedCompute": false, + "properties": { + "vmSize": "STANDARD_DS2_V2", + "vmPriority": "Dedicated", + "scaleSettings": { + "maxNodeCount": 4, + "minNodeCount": 1, + "nodeIdleTimeBeforeScaleDown": "PT2M" + }, + "subnet": null, + "currentNodeCount": 1, + "targetNodeCount": 1, + "nodeStateCounts": { + "preparingNodeCount": 0, + "runningNodeCount": 0, + "idleNodeCount": 1, + "unusableNodeCount": 0, + "leavingNodeCount": 0, + "preemptedNodeCount": 0 + }, + "allocationState": "Steady", + "allocationStateTransitionTime": "2022-09-30T08:08:43.647\u002B00:00", + "errors": null, + "remoteLoginPortPublicAccess": "Enabled", + "osType": "Linux", + "virtualMachineImage": null, + "isolatedNetwork": false, + "propertyBag": {} + } + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore?api-version=2022-05-01", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:46:08 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-b16ef382fb0aa3ac07d45b7fc801cb67-d4b5fac66b0f1774-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "fcc16e15-9092-457b-a5a7-a07aa5de0c29", + "x-ms-ratelimit-remaining-subscription-reads": "11909", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034608Z:fcc16e15-9092-457b-a5a7-a07aa5de0c29", + "x-request-time": "0.111" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", + "name": "workspaceblobstore", + "type": "Microsoft.MachineLearningServices/workspaces/datastores", + "properties": { + "description": null, + "tags": null, + "properties": null, + "isDefault": true, + "credentials": { + "credentialsType": "AccountKey" + }, + "datastoreType": "AzureBlob", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "endpoint": "core.windows.net", + "protocol": "https", + "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" + }, + "systemData": { + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "createdByType": "Application", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "lastModifiedByType": "Application" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore/listSecrets?api-version=2022-05-01", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:46:08 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-e2035b577825e84d53b194d0eebcd4a2-6473beefeccc293d-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "425bd12f-bee8-49d1-bfe2-49ba0751431e", + "x-ms-ratelimit-remaining-subscription-writes": "1163", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034609Z:425bd12f-bee8-49d1-bfe2-49ba0751431e", + "x-request-time": "0.092" + }, + "ResponseBody": { + "secretsType": "AccountKey", + "key": "dGhpcyBpcyBmYWtlIGtleQ==" + } + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/distribution-component/component_spec.yaml", + "RequestMethod": "HEAD", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:46:09 GMT", + "x-ms-version": "2021-08-06" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Accept-Ranges": "bytes", + "Content-Length": "758", + "Content-MD5": "btu6HWM/OieNWo2NW/ZsWA==", + "Content-Type": "application/octet-stream", + "Date": "Mon, 10 Oct 2022 03:46:08 GMT", + "ETag": "\u00220x8DAAA6EED25D44D\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:24:22 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "Vary": "Origin", + "x-ms-access-tier": "Hot", + "x-ms-access-tier-inferred": "true", + "x-ms-blob-type": "BlockBlob", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:24:22 GMT", + "x-ms-lease-state": "available", + "x-ms-lease-status": "unlocked", + "x-ms-meta-name": "d6667388-5223-4184-8359-e2929a825e06", + "x-ms-meta-upload_status": "completed", + "x-ms-meta-version": "1", + "x-ms-server-encrypted": "true", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/distribution-component/component_spec.yaml", + "RequestMethod": "HEAD", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:46:09 GMT", + "x-ms-version": "2021-08-06" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Date": "Mon, 10 Oct 2022 03:46:08 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "Transfer-Encoding": "chunked", + "Vary": "Origin", + "x-ms-error-code": "BlobNotFound", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1?api-version=2022-05-01", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "311", + "Content-Type": "application/json", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": { + "properties": { + "properties": { + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" + }, + "isAnonymous": true, + "isArchived": false, + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/distribution-component" + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:46:10 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-733a4b0f250541e3edba8bed577183ee-de1097645e4b8388-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "320fe438-f7b2-40e6-a711-6909dd024823", + "x-ms-ratelimit-remaining-subscription-writes": "1136", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034610Z:320fe438-f7b2-40e6-a711-6909dd024823", + "x-request-time": "0.409" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1", + "name": "1", + "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", + "properties": { + "description": null, + "tags": {}, + "properties": { + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" + }, + "isArchived": false, + "isAnonymous": false, + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/distribution-component" + }, + "systemData": { + "createdAt": "2022-10-10T03:24:23.5013448\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:46:10.2316613\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "1093", + "Content-Type": "application/json", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": { + "properties": { + "properties": {}, + "tags": {}, + "isAnonymous": true, + "isArchived": false, + "componentSpec": { + "name": "azureml_anonymous", + "tags": {}, + "version": "000000000000000000000", + "$schema": "https://componentsdk.azureedge.net/jsonschema/DistributedComponent.json", + "display_name": "MPI Example", + "inputs": { + "input_path": { + "type": "path", + "description": "The directory contains input data." + }, + "string_parameter": { + "type": "String", + "optional": true, + "description": "A parameter accepts a string value." + } + }, + "outputs": { + "output_path": { + "type": "path", + "description": "The directory contains output data." + } + }, + "type": "DistributedComponent", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1", + "environment": { + "os": "Linux", + "name": "AzureML-Minimal" + }, + "launcher": { + "type": "mpi", + "additional_arguments": "python train.py --input-path {inputs.input_path} [--string-parameter {inputs.string_parameter}] --output-path {outputs.output_path}" + } + } + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "2161", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:46:11 GMT", + "Expires": "-1", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-eafe46841287d505eddb08ca33041051-480958c290258977-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "ab060cc9-653d-491b-90d3-0e7e9679c385", + "x-ms-ratelimit-remaining-subscription-writes": "1135", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034612Z:ab060cc9-653d-491b-90d3-0e7e9679c385", + "x-request-time": "1.471" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/069bbbc7-917f-4b78-8d4e-77c4d104e0bc", + "name": "069bbbc7-917f-4b78-8d4e-77c4d104e0bc", + "type": "Microsoft.MachineLearningServices/workspaces/components/versions", + "properties": { + "description": null, + "tags": {}, + "properties": {}, + "isArchived": false, + "isAnonymous": true, + "componentSpec": { + "$schema": "https://componentsdk.azureedge.net/jsonschema/DistributedComponent.json", + "name": "azureml_anonymous", + "version": "069bbbc7-917f-4b78-8d4e-77c4d104e0bc", + "display_name": "MPI Example", + "is_deterministic": "True", + "type": "DistributedComponent", + "inputs": { + "input_path": { + "type": "path", + "optional": "False", + "description": "The directory contains input data.", + "datastore_mode": "Mount" + }, + "string_parameter": { + "type": "String", + "optional": "True", + "description": "A parameter accepts a string value." + } + }, + "outputs": { + "output_path": { + "type": "path", + "description": "The directory contains output data.", + "datastore_mode": "Upload" + } + }, + "environment": { + "name": "AzureML-Minimal", + "os": "Linux" + }, + "launcher": { + "type": "mpi", + "additional_arguments": "python train.py --input-path {inputs.input_path} [--string-parameter {inputs.string_parameter}] --output-path {outputs.output_path}" + }, + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1" + } + }, + "systemData": { + "createdAt": "2022-10-10T03:39:28.5135534\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:39:28.9591694\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "1105", + "Content-Type": "application/json", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": { + "properties": { + "properties": {}, + "tags": {}, + "displayName": "pipeline_func", + "experimentName": "azure-ai-ml", + "isArchived": false, + "jobType": "Pipeline", + "inputs": {}, + "jobs": { + "node": { + "environment": null, + "limits": { + "job_limits_type": "Command" + }, + "resources": { + "properties": {} + }, + "distribution": { + "distribution_type": "Mpi" + }, + "type": "DistributedComponent", + "computeId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", + "inputs": { + "input_path": { + "uri": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_imdb_reviews_train/versions/2", + "job_input_type": "mltable" + } + }, + "outputs": {}, + "properties": {}, + "_source": "YAML.COMPONENT", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/069bbbc7-917f-4b78-8d4e-77c4d104e0bc" + } + }, + "outputs": {}, + "settings": { + "_source": "DSL" + } + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "3108", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:46:19 GMT", + "Expires": "-1", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-3bca104462997fdc66d595ede142191b-496026005debfd81-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "bdee3579-17cf-4692-b91f-dda50ca57a0f", + "x-ms-ratelimit-remaining-subscription-writes": "1134", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034619Z:bdee3579-17cf-4692-b91f-dda50ca57a0f", + "x-request-time": "2.563" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000", + "name": "000000000000000000000", + "type": "Microsoft.MachineLearningServices/workspaces/jobs", + "properties": { + "description": null, + "tags": {}, + "properties": { + "azureml.DevPlatv2": "true", + "azureml.runsource": "azureml.PipelineRun", + "runSource": "MFE", + "runType": "HTTP", + "azureml.parameters": "{}", + "azureml.continue_on_step_failure": "False", + "azureml.continue_on_failed_optional_input": "True", + "azureml.defaultDataStoreName": "workspaceblobstore", + "azureml.pipelineComponent": "pipelinerun" + }, + "displayName": "pipeline_func", + "status": "Preparing", + "experimentName": "azure-ai-ml", + "services": { + "Tracking": { + "jobServiceType": "Tracking", + "port": null, + "endpoint": "azureml://master.api.azureml-test.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", + "status": null, + "errorMessage": null, + "properties": null, + "nodes": null + }, + "Studio": { + "jobServiceType": "Studio", + "port": null, + "endpoint": "https://ml.azure.com/runs/000000000000000000000?wsid=/subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000", + "status": null, + "errorMessage": null, + "properties": null, + "nodes": null + } + }, + "computeId": null, + "isArchived": false, + "identity": null, + "componentId": null, + "jobType": "Pipeline", + "settings": { + "_source": "DSL" + }, + "jobs": { + "node": { + "environment": null, + "limits": { + "job_limits_type": "Command" + }, + "resources": { + "properties": {} + }, + "distribution": { + "distribution_type": "Mpi" + }, + "type": "DistributedComponent", + "computeId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", + "inputs": { + "input_path": { + "uri": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_imdb_reviews_train/versions/2", + "job_input_type": "mltable" + } + }, + "outputs": {}, + "properties": {}, + "_source": "YAML.COMPONENT", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/069bbbc7-917f-4b78-8d4e-77c4d104e0bc" + } + }, + "inputs": {}, + "outputs": {}, + "sourceJobId": null + }, + "systemData": { + "createdAt": "2022-10-10T03:46:19.1761246\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000/cancel?api-version=2022-10-01-preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 202, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "4", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:46:22 GMT", + "Expires": "-1", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-async-operation-timeout": "PT1H", + "x-ms-correlation-request-id": "7c926678-ba62-462f-a2f4-c625343acfd5", + "x-ms-ratelimit-remaining-subscription-writes": "1162", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034623Z:7c926678-ba62-462f-a2f4-c625343acfd5", + "x-request-time": "0.780" + }, + "ResponseBody": "null" + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "*/*", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 202, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "2", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:46:23 GMT", + "Expires": "-1", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "9feb71cb-1fc8-47c4-9633-151ad1a4e4f3", + "x-ms-ratelimit-remaining-subscription-reads": "11908", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034624Z:9feb71cb-1fc8-47c4-9633-151ad1a4e4f3", + "x-request-time": "0.035" + }, + "ResponseBody": {} + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "*/*", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Mon, 10 Oct 2022 03:46:53 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-363015465be934142341be9952a03e56-fbec2ba03e9ac375-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "453a280c-87e5-4870-a964-9263523e2ba7", + "x-ms-ratelimit-remaining-subscription-reads": "11907", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034654Z:453a280c-87e5-4870-a964-9263523e2ba7", + "x-request-time": "0.069" + }, + "ResponseBody": null + } + ], + "Variables": {} +} diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_pipeline_job.pyTestPipelineJobtest_data_as_pipeline_inputs.json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_pipeline_job.pyTestPipelineJobtest_data_as_pipeline_inputs.json new file mode 100644 index 000000000000..69dc943c16be --- /dev/null +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_pipeline_job.pyTestPipelineJobtest_data_as_pipeline_inputs.json @@ -0,0 +1,784 @@ +{ + "Entries": [ + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_imdb_reviews_train/versions?api-version=2022-05-01\u0026$orderBy=createdtime%20desc\u0026$top=1", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:46:57 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-c4387b5ac4f9924523cd10301f682c54-8a4103f00c0478bf-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "cec8c67f-e0d7-41e4-877d-100872edc8b0", + "x-ms-ratelimit-remaining-subscription-reads": "11906", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034658Z:cec8c67f-e0d7-41e4-877d-100872edc8b0", + "x-request-time": "0.131" + }, + "ResponseBody": { + "value": [ + { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_imdb_reviews_train/versions/2", + "name": "2", + "type": "Microsoft.MachineLearningServices/workspaces/data/versions", + "properties": { + "description": null, + "tags": {}, + "properties": {}, + "isArchived": false, + "isAnonymous": false, + "dataUri": "azureml://workspaces/e61cd5e2-512f-475e-9842-5e2a973993b8/datastores/workspaceblobstore/paths/LocalUpload/00000000000000000000000000000000/mnist-data/", + "dataType": "mltable", + "referencedUris": [ + "./0.png", + "./1.png", + "./2.png", + "./3.png" + ] + }, + "systemData": { + "createdAt": "2022-09-23T10:32:48.3746339\u002B00:00", + "createdBy": "Zhengfei Wang", + "createdByType": "User", + "lastModifiedAt": "2022-09-23T10:32:48.3904292\u002B00:00" + } + } + ] + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster?api-version=2022-01-01-preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:47:00 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-516204070007313227dbf42f885234bb-1739728b6c61d911-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "caf1530e-dbb0-4923-b9f2-a8f14cf66348", + "x-ms-ratelimit-remaining-subscription-reads": "11905", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034701Z:caf1530e-dbb0-4923-b9f2-a8f14cf66348", + "x-request-time": "0.219" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", + "name": "cpu-cluster", + "type": "Microsoft.MachineLearningServices/workspaces/computes", + "location": "centraluseuap", + "tags": {}, + "properties": { + "createdOn": "2022-09-22T09:02:22.1899959\u002B00:00", + "modifiedOn": "2022-09-23T03:28:18.0066218\u002B00:00", + "disableLocalAuth": false, + "description": null, + "resourceId": null, + "computeType": "AmlCompute", + "computeLocation": "centraluseuap", + "provisioningState": "Succeeded", + "provisioningErrors": null, + "isAttachedCompute": false, + "properties": { + "vmSize": "STANDARD_DS2_V2", + "vmPriority": "Dedicated", + "scaleSettings": { + "maxNodeCount": 4, + "minNodeCount": 1, + "nodeIdleTimeBeforeScaleDown": "PT2M" + }, + "subnet": null, + "currentNodeCount": 1, + "targetNodeCount": 1, + "nodeStateCounts": { + "preparingNodeCount": 0, + "runningNodeCount": 0, + "idleNodeCount": 1, + "unusableNodeCount": 0, + "leavingNodeCount": 0, + "preemptedNodeCount": 0 + }, + "allocationState": "Steady", + "allocationStateTransitionTime": "2022-09-30T08:08:43.647\u002B00:00", + "errors": null, + "remoteLoginPortPublicAccess": "Enabled", + "osType": "Linux", + "virtualMachineImage": null, + "isolatedNetwork": false, + "propertyBag": {} + } + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore?api-version=2022-05-01", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:47:01 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-0069ef22b5f9cca9ed57760305c66b9b-ddae496aaba8e36d-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "ecdf22ef-529f-4602-a8a2-4a4dbaa9ae4e", + "x-ms-ratelimit-remaining-subscription-reads": "11904", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034701Z:ecdf22ef-529f-4602-a8a2-4a4dbaa9ae4e", + "x-request-time": "0.094" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", + "name": "workspaceblobstore", + "type": "Microsoft.MachineLearningServices/workspaces/datastores", + "properties": { + "description": null, + "tags": null, + "properties": null, + "isDefault": true, + "credentials": { + "credentialsType": "AccountKey" + }, + "datastoreType": "AzureBlob", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "endpoint": "core.windows.net", + "protocol": "https", + "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" + }, + "systemData": { + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "createdByType": "Application", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "lastModifiedByType": "Application" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore/listSecrets?api-version=2022-05-01", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:47:01 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-901fa85e92c0f353db6cd6bf25349c9a-549b41eff91c4d5e-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "670f59d7-c600-4773-a479-9769ff7fbe79", + "x-ms-ratelimit-remaining-subscription-writes": "1161", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034702Z:670f59d7-c600-4773-a479-9769ff7fbe79", + "x-request-time": "0.092" + }, + "ResponseBody": { + "secretsType": "AccountKey", + "key": "dGhpcyBpcyBmYWtlIGtleQ==" + } + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/distribution-component/component_spec.yaml", + "RequestMethod": "HEAD", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:47:02 GMT", + "x-ms-version": "2021-08-06" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Accept-Ranges": "bytes", + "Content-Length": "758", + "Content-MD5": "btu6HWM/OieNWo2NW/ZsWA==", + "Content-Type": "application/octet-stream", + "Date": "Mon, 10 Oct 2022 03:47:01 GMT", + "ETag": "\u00220x8DAAA6EED25D44D\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:24:22 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "Vary": "Origin", + "x-ms-access-tier": "Hot", + "x-ms-access-tier-inferred": "true", + "x-ms-blob-type": "BlockBlob", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:24:22 GMT", + "x-ms-lease-state": "available", + "x-ms-lease-status": "unlocked", + "x-ms-meta-name": "d6667388-5223-4184-8359-e2929a825e06", + "x-ms-meta-upload_status": "completed", + "x-ms-meta-version": "1", + "x-ms-server-encrypted": "true", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/distribution-component/component_spec.yaml", + "RequestMethod": "HEAD", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:47:02 GMT", + "x-ms-version": "2021-08-06" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Date": "Mon, 10 Oct 2022 03:47:02 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "Transfer-Encoding": "chunked", + "Vary": "Origin", + "x-ms-error-code": "BlobNotFound", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1?api-version=2022-05-01", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "311", + "Content-Type": "application/json", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": { + "properties": { + "properties": { + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" + }, + "isAnonymous": true, + "isArchived": false, + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/distribution-component" + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:47:03 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-2e6f2bc24e9b0f99ca507fd01e42f49e-64e327f62a6adbcc-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "0ab72bb7-7a64-4e05-a343-ee4d892eb6be", + "x-ms-ratelimit-remaining-subscription-writes": "1133", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034704Z:0ab72bb7-7a64-4e05-a343-ee4d892eb6be", + "x-request-time": "0.356" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1", + "name": "1", + "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", + "properties": { + "description": null, + "tags": {}, + "properties": { + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" + }, + "isArchived": false, + "isAnonymous": false, + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/distribution-component" + }, + "systemData": { + "createdAt": "2022-10-10T03:24:23.5013448\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:47:04.013503\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "1093", + "Content-Type": "application/json", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": { + "properties": { + "properties": {}, + "tags": {}, + "isAnonymous": true, + "isArchived": false, + "componentSpec": { + "name": "azureml_anonymous", + "tags": {}, + "version": "000000000000000000000", + "$schema": "https://componentsdk.azureedge.net/jsonschema/DistributedComponent.json", + "display_name": "MPI Example", + "inputs": { + "input_path": { + "type": "path", + "description": "The directory contains input data." + }, + "string_parameter": { + "type": "String", + "optional": true, + "description": "A parameter accepts a string value." + } + }, + "outputs": { + "output_path": { + "type": "path", + "description": "The directory contains output data." + } + }, + "type": "DistributedComponent", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1", + "environment": { + "os": "Linux", + "name": "AzureML-Minimal" + }, + "launcher": { + "type": "mpi", + "additional_arguments": "python train.py --input-path {inputs.input_path} [--string-parameter {inputs.string_parameter}] --output-path {outputs.output_path}" + } + } + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "2161", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:47:15 GMT", + "Expires": "-1", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-3f9a6ff5af1a3d4e65eeb107b0d4b073-7e52ca767226534c-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "a30c6bc4-f31f-4801-84cd-cc88ea549d67", + "x-ms-ratelimit-remaining-subscription-writes": "1132", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034716Z:a30c6bc4-f31f-4801-84cd-cc88ea549d67", + "x-request-time": "12.232" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/069bbbc7-917f-4b78-8d4e-77c4d104e0bc", + "name": "069bbbc7-917f-4b78-8d4e-77c4d104e0bc", + "type": "Microsoft.MachineLearningServices/workspaces/components/versions", + "properties": { + "description": null, + "tags": {}, + "properties": {}, + "isArchived": false, + "isAnonymous": true, + "componentSpec": { + "$schema": "https://componentsdk.azureedge.net/jsonschema/DistributedComponent.json", + "name": "azureml_anonymous", + "version": "069bbbc7-917f-4b78-8d4e-77c4d104e0bc", + "display_name": "MPI Example", + "is_deterministic": "True", + "type": "DistributedComponent", + "inputs": { + "input_path": { + "type": "path", + "optional": "False", + "description": "The directory contains input data.", + "datastore_mode": "Mount" + }, + "string_parameter": { + "type": "String", + "optional": "True", + "description": "A parameter accepts a string value." + } + }, + "outputs": { + "output_path": { + "type": "path", + "description": "The directory contains output data.", + "datastore_mode": "Upload" + } + }, + "environment": { + "name": "AzureML-Minimal", + "os": "Linux" + }, + "launcher": { + "type": "mpi", + "additional_arguments": "python train.py --input-path {inputs.input_path} [--string-parameter {inputs.string_parameter}] --output-path {outputs.output_path}" + }, + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/d6667388-5223-4184-8359-e2929a825e06/versions/1" + } + }, + "systemData": { + "createdAt": "2022-10-10T03:39:28.5135534\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:39:28.9591694\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "1196", + "Content-Type": "application/json", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": { + "properties": { + "properties": {}, + "tags": {}, + "displayName": "pipeline_func", + "experimentName": "azure-ai-ml", + "isArchived": false, + "jobType": "Pipeline", + "inputs": { + "pipeline_input": { + "uri": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_imdb_reviews_train/versions/2", + "jobInputType": "mltable" + } + }, + "jobs": { + "node": { + "environment": null, + "limits": { + "job_limits_type": "Command" + }, + "resources": { + "properties": {} + }, + "distribution": { + "distribution_type": "Mpi" + }, + "type": "DistributedComponent", + "computeId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", + "inputs": { + "input_path": { + "job_input_type": "literal", + "value": "${{parent.inputs.pipeline_input}}" + } + }, + "outputs": {}, + "properties": {}, + "_source": "YAML.COMPONENT", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/069bbbc7-917f-4b78-8d4e-77c4d104e0bc" + } + }, + "outputs": {}, + "settings": { + "_source": "DSL" + } + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "3297", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:47:23 GMT", + "Expires": "-1", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-9eff7d3ffa5b5c68d9c3c2f7ddb5117c-cf4029ea5816fad5-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "6157a8fb-bbc0-47ee-b3d9-eec7568b0ae6", + "x-ms-ratelimit-remaining-subscription-writes": "1131", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034723Z:6157a8fb-bbc0-47ee-b3d9-eec7568b0ae6", + "x-request-time": "2.768" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000", + "name": "000000000000000000000", + "type": "Microsoft.MachineLearningServices/workspaces/jobs", + "properties": { + "description": null, + "tags": {}, + "properties": { + "azureml.DevPlatv2": "true", + "azureml.runsource": "azureml.PipelineRun", + "runSource": "MFE", + "runType": "HTTP", + "azureml.parameters": "{}", + "azureml.continue_on_step_failure": "False", + "azureml.continue_on_failed_optional_input": "True", + "azureml.defaultDataStoreName": "workspaceblobstore", + "azureml.pipelineComponent": "pipelinerun" + }, + "displayName": "pipeline_func", + "status": "Preparing", + "experimentName": "azure-ai-ml", + "services": { + "Tracking": { + "jobServiceType": "Tracking", + "port": null, + "endpoint": "azureml://master.api.azureml-test.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", + "status": null, + "errorMessage": null, + "properties": null, + "nodes": null + }, + "Studio": { + "jobServiceType": "Studio", + "port": null, + "endpoint": "https://ml.azure.com/runs/000000000000000000000?wsid=/subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000", + "status": null, + "errorMessage": null, + "properties": null, + "nodes": null + } + }, + "computeId": null, + "isArchived": false, + "identity": null, + "componentId": null, + "jobType": "Pipeline", + "settings": { + "_source": "DSL" + }, + "jobs": { + "node": { + "environment": null, + "limits": { + "job_limits_type": "Command" + }, + "resources": { + "properties": {} + }, + "distribution": { + "distribution_type": "Mpi" + }, + "type": "DistributedComponent", + "computeId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", + "inputs": { + "input_path": { + "job_input_type": "literal", + "value": "${{parent.inputs.pipeline_input}}" + } + }, + "outputs": {}, + "properties": {}, + "_source": "YAML.COMPONENT", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/069bbbc7-917f-4b78-8d4e-77c4d104e0bc" + } + }, + "inputs": { + "pipeline_input": { + "description": null, + "uri": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_imdb_reviews_train/versions/2", + "mode": "ReadOnlyMount", + "jobInputType": "mltable" + } + }, + "outputs": {}, + "sourceJobId": null + }, + "systemData": { + "createdAt": "2022-10-10T03:47:23.4037994\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000/cancel?api-version=2022-10-01-preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 202, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "4", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:47:27 GMT", + "Expires": "-1", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-async-operation-timeout": "PT1H", + "x-ms-correlation-request-id": "9aa0b4ba-b433-4cc5-8cb7-030bd10a34fa", + "x-ms-ratelimit-remaining-subscription-writes": "1160", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034727Z:9aa0b4ba-b433-4cc5-8cb7-030bd10a34fa", + "x-request-time": "0.858" + }, + "ResponseBody": "null" + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "*/*", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 202, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "2", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:47:27 GMT", + "Expires": "-1", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "90b06d37-09bc-484c-8968-2c7d200817d7", + "x-ms-ratelimit-remaining-subscription-reads": "11903", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034727Z:90b06d37-09bc-484c-8968-2c7d200817d7", + "x-request-time": "0.028" + }, + "ResponseBody": {} + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "*/*", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Mon, 10 Oct 2022 03:47:58 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-ddc1d4d45205b6ce1d142ff8004cc3e2-cbfc5bc56bbb784a-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "020dbe99-8065-4bd0-a5a3-222e56d640ed", + "x-ms-ratelimit-remaining-subscription-reads": "11902", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034758Z:020dbe99-8065-4bd0-a5a3-222e56d640ed", + "x-request-time": "0.030" + }, + "ResponseBody": null + } + ], + "Variables": {} +} diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_with_setting_node_output.json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_with_setting_node_output.json index 4de4b0fb59b1..1f2dfd23c4d8 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_with_setting_node_output.json +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_with_setting_node_output.json @@ -1,656 +1,5 @@ { "Entries": [ - { - "RequestUri": "https://login.microsoftonline.com/72f988bf-86f1-41af-91ab-2d7cd011db47/v2.0/.well-known/openid-configuration", - "RequestMethod": "GET", - "RequestHeaders": { - "Accept": "*/*", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "User-Agent": "azsdk-python-identity/1.11.0b4 Python/3.8.6 (Windows-10-10.0.22000-SP0)" - }, - "RequestBody": null, - "StatusCode": 200, - "ResponseHeaders": { - "Access-Control-Allow-Methods": "GET, OPTIONS", - "Access-Control-Allow-Origin": "*", - "Cache-Control": "max-age=86400, private", - "Content-Length": "1753", - "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:34 GMT", - "P3P": "CP=\u0022DSP CUR OTPi IND OTRi ONL FIN\u0022", - "Set-Cookie": [ - "fpc=AhwGpJCOzHhIuETiqO8P0ujwQhvHEgAAAM9UrNoOAAAARUxcfQgAAADXVKzaDgAAAA; expires=Sat, 08-Oct-2022 21:27:35 GMT; path=/; secure; HttpOnly; SameSite=None", - "x-ms-gateway-slice=estsfd; path=/; secure; samesite=none; httponly", - "stsservicecookie=estsfd; path=/; secure; samesite=none; httponly" - ], - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "X-Content-Type-Options": "nosniff", - "x-ms-ests-server": "2.1.13622.6 - EUS ProdSlices", - "X-XSS-Protection": "0" - }, - "ResponseBody": { - "token_endpoint": "https://login.microsoftonline.com/72f988bf-86f1-41af-91ab-2d7cd011db47/oauth2/v2.0/token", - "token_endpoint_auth_methods_supported": [ - "client_secret_post", - "private_key_jwt", - "client_secret_basic" - ], - "jwks_uri": "https://login.microsoftonline.com/72f988bf-86f1-41af-91ab-2d7cd011db47/discovery/v2.0/keys", - "response_modes_supported": [ - "query", - "fragment", - "form_post" - ], - "subject_types_supported": [ - "pairwise" - ], - "id_token_signing_alg_values_supported": [ - "RS256" - ], - "response_types_supported": [ - "code", - "id_token", - "code id_token", - "id_token token" - ], - "scopes_supported": [ - "openid", - "profile", - "email", - "offline_access" - ], - "issuer": "https://login.microsoftonline.com/72f988bf-86f1-41af-91ab-2d7cd011db47/v2.0", - "request_uri_parameter_supported": false, - "userinfo_endpoint": "https://graph.microsoft.com/oidc/userinfo", - "authorization_endpoint": "https://login.microsoftonline.com/72f988bf-86f1-41af-91ab-2d7cd011db47/oauth2/v2.0/authorize", - "device_authorization_endpoint": "https://login.microsoftonline.com/72f988bf-86f1-41af-91ab-2d7cd011db47/oauth2/v2.0/devicecode", - "http_logout_supported": true, - "frontchannel_logout_supported": true, - "end_session_endpoint": "https://login.microsoftonline.com/72f988bf-86f1-41af-91ab-2d7cd011db47/oauth2/v2.0/logout", - "claims_supported": [ - "sub", - "iss", - "cloud_instance_name", - "cloud_instance_host_name", - "cloud_graph_host_name", - "msgraph_host", - "aud", - "exp", - "iat", - "auth_time", - "acr", - "nonce", - "preferred_username", - "name", - "tid", - "ver", - "at_hash", - "c_hash", - "email" - ], - "kerberos_endpoint": "https://login.microsoftonline.com/72f988bf-86f1-41af-91ab-2d7cd011db47/kerberos", - "tenant_region_scope": "WW", - "cloud_instance_name": "microsoftonline.com", - "cloud_graph_host_name": "graph.windows.net", - "msgraph_host": "graph.microsoft.com", - "rbac_url": "https://pas.windows.net" - } - }, - { - "RequestUri": "https://login.microsoftonline.com/common/discovery/instance?api-version=1.1\u0026authorization_endpoint=https://login.microsoftonline.com/common/oauth2/authorize", - "RequestMethod": "GET", - "RequestHeaders": { - "Accept": "application/json", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "Cookie": "fpc=AhwGpJCOzHhIuETiqO8P0ujwQhvHEgAAAM9UrNoOAAAARUxcfQgAAADXVKzaDgAAAA; stsservicecookie=estsfd; x-ms-gateway-slice=estsfd", - "User-Agent": "azsdk-python-identity/1.11.0b4 Python/3.8.6 (Windows-10-10.0.22000-SP0)" - }, - "RequestBody": null, - "StatusCode": 200, - "ResponseHeaders": { - "Access-Control-Allow-Methods": "GET, OPTIONS", - "Access-Control-Allow-Origin": "*", - "Cache-Control": "max-age=86400, private", - "Content-Length": "945", - "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:34 GMT", - "P3P": "CP=\u0022DSP CUR OTPi IND OTRi ONL FIN\u0022", - "Set-Cookie": [ - "fpc=AhwGpJCOzHhIuETiqO8P0ujwQhvHEgAAAM9UrNoOAAAARUxcfQgAAADXVKzaDgAAAA; expires=Sat, 08-Oct-2022 21:27:35 GMT; path=/; secure; HttpOnly; SameSite=None", - "x-ms-gateway-slice=estsfd; path=/; secure; samesite=none; httponly", - "stsservicecookie=estsfd; path=/; secure; samesite=none; httponly" - ], - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "X-Content-Type-Options": "nosniff", - "x-ms-ests-server": "2.1.13562.12 - WUS2 ProdSlices", - "X-XSS-Protection": "0" - }, - "ResponseBody": { - "tenant_discovery_endpoint": "https://login.microsoftonline.com/common/.well-known/openid-configuration", - "api-version": "1.1", - "metadata": [ - { - "preferred_network": "login.microsoftonline.com", - "preferred_cache": "login.windows.net", - "aliases": [ - "login.microsoftonline.com", - "login.windows.net", - "login.microsoft.com", - "sts.windows.net" - ] - }, - { - "preferred_network": "login.partner.microsoftonline.cn", - "preferred_cache": "login.partner.microsoftonline.cn", - "aliases": [ - "login.partner.microsoftonline.cn", - "login.chinacloudapi.cn" - ] - }, - { - "preferred_network": "login.microsoftonline.de", - "preferred_cache": "login.microsoftonline.de", - "aliases": [ - "login.microsoftonline.de" - ] - }, - { - "preferred_network": "login.microsoftonline.us", - "preferred_cache": "login.microsoftonline.us", - "aliases": [ - "login.microsoftonline.us", - "login.usgovcloudapi.net" - ] - }, - { - "preferred_network": "login-us.microsoftonline.com", - "preferred_cache": "login-us.microsoftonline.com", - "aliases": [ - "login-us.microsoftonline.com" - ] - } - ] - } - }, - { - "RequestUri": "https://login.microsoftonline.com/72f988bf-86f1-41af-91ab-2d7cd011db47/oauth2/v2.0/token", - "RequestMethod": "POST", - "RequestHeaders": { - "Accept": "application/json", - "Accept-Encoding": "gzip, deflate", - "client-request-id": "38fb4d4d-f91a-4dbb-a4d8-bf28f127ebc2", - "Connection": "keep-alive", - "Content-Length": "292", - "Content-Type": "application/x-www-form-urlencoded", - "Cookie": "fpc=AhwGpJCOzHhIuETiqO8P0ujwQhvHEgAAAM9UrNoOAAAARUxcfQgAAADXVKzaDgAAAA; stsservicecookie=estsfd; x-ms-gateway-slice=estsfd", - "User-Agent": "azsdk-python-identity/1.11.0b4 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-client-cpu": "x64", - "x-client-current-telemetry": "4|730,0|", - "x-client-last-telemetry": "4|0|||", - "x-client-os": "win32", - "x-client-sku": "MSAL.Python", - "x-client-ver": "1.18.0", - "x-ms-lib-capability": "retry-after, h429" - }, - "RequestBody": "client_id=5019366a-3f7a-4d18-adae-d2483c23e1ee\u0026grant_type=client_credentials\u0026client_info=1\u0026client_secret=5FL8Q~~BBdJpY_y.KpA94zzLZv2Czg.uYQAmfaMZ\u0026claims=%7B%22access_token%22%3A\u002B%7B%22xms_cc%22%3A\u002B%7B%22values%22%3A\u002B%5B%22CP1%22%5D%7D%7D%7D\u0026scope=https%3A%2F%2Fmanagement.azure.com%2F.default", - "StatusCode": 200, - "ResponseHeaders": { - "Cache-Control": "no-store, no-cache", - "client-request-id": "38fb4d4d-f91a-4dbb-a4d8-bf28f127ebc2", - "Content-Length": "111", - "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:34 GMT", - "Expires": "-1", - "P3P": "CP=\u0022DSP CUR OTPi IND OTRi ONL FIN\u0022", - "Pragma": "no-cache", - "Set-Cookie": [ - "fpc=AhwGpJCOzHhIuETiqO8P0ujwQhvHEwAAAM9UrNoOAAAARUxcfQgAAADXVKzaDgAAAA; expires=Sat, 08-Oct-2022 21:27:35 GMT; path=/; secure; HttpOnly; SameSite=None", - "x-ms-gateway-slice=estsfd; path=/; secure; samesite=none; httponly", - "stsservicecookie=estsfd; path=/; secure; samesite=none; httponly" - ], - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "X-Content-Type-Options": "nosniff", - "x-ms-clitelem": "1,0,0,,", - "x-ms-ests-server": "2.1.13622.6 - NCUS ProdSlices", - "X-XSS-Protection": "0" - }, - "ResponseBody": { - "token_type": "Bearer", - "expires_in": 86399, - "ext_expires_in": 86399, - "refresh_in": 43199, - "access_token": "Sanitized" - } - }, - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_mnist_model/versions/2?api-version=2022-05-01", - "RequestMethod": "GET", - "RequestHeaders": { - "Accept": "application/json", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" - }, - "RequestBody": null, - "StatusCode": 200, - "ResponseHeaders": { - "Cache-Control": "no-cache", - "Content-Encoding": "gzip", - "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:35 GMT", - "Expires": "-1", - "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-68d24359dff4aa3199506eef65f0033e-5fb20a4beb0de6f6-01\u0022", - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Transfer-Encoding": "chunked", - "Vary": [ - "Accept-Encoding", - "Accept-Encoding" - ], - "x-aml-cluster": "vienna-eastus2euap-01", - "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "608db370-d35a-4242-a1e2-80633941fbdd", - "x-ms-ratelimit-remaining-subscription-reads": "11884", - "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212735Z:608db370-d35a-4242-a1e2-80633941fbdd", - "x-request-time": "0.030" - }, - "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_mnist_model/versions/2", - "name": "2", - "type": "Microsoft.MachineLearningServices/workspaces/data/versions", - "properties": { - "description": null, - "tags": {}, - "properties": {}, - "isArchived": false, - "isAnonymous": false, - "dataUri": "azureml://subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000/datastores/workspaceblobstore/paths/LocalUpload/d2673b2a-f262-4b87-bdb2-8c348d334441/mnist-data/", - "dataType": "mltable", - "referencedUris": [ - "./0.png", - "./1.png", - "./2.png", - "./3.png" - ] - }, - "systemData": { - "createdAt": "2022-09-08T20:02:49.440887\u002B00:00", - "createdBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "createdByType": "Application", - "lastModifiedAt": "2022-09-08T20:02:49.4513036\u002B00:00" - } - } - }, - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_mnist/versions/2?api-version=2022-05-01", - "RequestMethod": "GET", - "RequestHeaders": { - "Accept": "application/json", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" - }, - "RequestBody": null, - "StatusCode": 200, - "ResponseHeaders": { - "Cache-Control": "no-cache", - "Content-Encoding": "gzip", - "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:35 GMT", - "Expires": "-1", - "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-0575e058f3b215de4f031aaa59edb3a3-f35265c0ad71a81e-01\u0022", - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Transfer-Encoding": "chunked", - "Vary": [ - "Accept-Encoding", - "Accept-Encoding" - ], - "x-aml-cluster": "vienna-eastus2euap-01", - "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "364880fc-5933-4a41-9b2d-05fd31810b55", - "x-ms-ratelimit-remaining-subscription-reads": "11883", - "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212735Z:364880fc-5933-4a41-9b2d-05fd31810b55", - "x-request-time": "0.028" - }, - "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_mnist/versions/2", - "name": "2", - "type": "Microsoft.MachineLearningServices/workspaces/data/versions", - "properties": { - "description": null, - "tags": {}, - "properties": {}, - "isArchived": false, - "isAnonymous": false, - "dataUri": "azureml://subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000/datastores/workspaceblobstore/paths/LocalUpload/330173dc-0f3d-4fa9-b3b7-28c5401f8329/mnist-data/", - "dataType": "mltable", - "referencedUris": [ - "./0.png", - "./1.png", - "./2.png", - "./3.png" - ] - }, - "systemData": { - "createdAt": "2022-09-08T20:02:51.401406\u002B00:00", - "createdBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "createdByType": "Application", - "lastModifiedAt": "2022-09-08T20:02:51.4110475\u002B00:00" - } - } - }, - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_imdb_reviews_train/versions/2?api-version=2022-05-01", - "RequestMethod": "GET", - "RequestHeaders": { - "Accept": "application/json", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" - }, - "RequestBody": null, - "StatusCode": 200, - "ResponseHeaders": { - "Cache-Control": "no-cache", - "Content-Encoding": "gzip", - "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:35 GMT", - "Expires": "-1", - "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-ef599d7356bafd49665b563ca2bccfbd-940a0721ceea65f1-01\u0022", - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Transfer-Encoding": "chunked", - "Vary": [ - "Accept-Encoding", - "Accept-Encoding" - ], - "x-aml-cluster": "vienna-eastus2euap-01", - "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "e390a2ad-9851-4448-9717-0dc45cfa12b6", - "x-ms-ratelimit-remaining-subscription-reads": "11882", - "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212735Z:e390a2ad-9851-4448-9717-0dc45cfa12b6", - "x-request-time": "0.030" - }, - "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_imdb_reviews_train/versions/2", - "name": "2", - "type": "Microsoft.MachineLearningServices/workspaces/data/versions", - "properties": { - "description": null, - "tags": {}, - "properties": {}, - "isArchived": false, - "isAnonymous": false, - "dataUri": "azureml://subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000/datastores/workspaceblobstore/paths/LocalUpload/3f7d49da-8a23-45f9-a14c-405260c6f2e5/mnist-data/", - "dataType": "mltable", - "referencedUris": [ - "./0.png", - "./1.png", - "./2.png", - "./3.png" - ] - }, - "systemData": { - "createdAt": "2022-09-08T20:02:54.4826975\u002B00:00", - "createdBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "createdByType": "Application", - "lastModifiedAt": "2022-09-08T20:02:54.491246\u002B00:00" - } - } - }, - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_Adls_Tsv/versions/2?api-version=2022-05-01", - "RequestMethod": "GET", - "RequestHeaders": { - "Accept": "application/json", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" - }, - "RequestBody": null, - "StatusCode": 200, - "ResponseHeaders": { - "Cache-Control": "no-cache", - "Content-Encoding": "gzip", - "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:35 GMT", - "Expires": "-1", - "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-1547e9149b43ffa878caa9d377063d15-79952bc70acd20c1-01\u0022", - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Transfer-Encoding": "chunked", - "Vary": [ - "Accept-Encoding", - "Accept-Encoding" - ], - "x-aml-cluster": "vienna-eastus2euap-01", - "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "23e7c5c2-e4ad-4b80-a209-55dbf70b7aac", - "x-ms-ratelimit-remaining-subscription-reads": "11881", - "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212736Z:23e7c5c2-e4ad-4b80-a209-55dbf70b7aac", - "x-request-time": "0.033" - }, - "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_Adls_Tsv/versions/2", - "name": "2", - "type": "Microsoft.MachineLearningServices/workspaces/data/versions", - "properties": { - "description": null, - "tags": {}, - "properties": {}, - "isArchived": false, - "isAnonymous": false, - "dataUri": "azureml://subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000/datastores/workspaceblobstore/paths/LocalUpload/24ff1473-8a80-437c-8062-6c6316b991b2/mnist-data/", - "dataType": "mltable", - "referencedUris": [ - "./0.png", - "./1.png", - "./2.png", - "./3.png" - ] - }, - "systemData": { - "createdAt": "2022-09-08T20:02:55.6662389\u002B00:00", - "createdBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "createdByType": "Application", - "lastModifiedAt": "2022-09-08T20:02:55.6749224\u002B00:00" - } - } - }, - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_aml_component_datatransfer_folder/versions/2?api-version=2022-05-01", - "RequestMethod": "GET", - "RequestHeaders": { - "Accept": "application/json", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" - }, - "RequestBody": null, - "StatusCode": 200, - "ResponseHeaders": { - "Cache-Control": "no-cache", - "Content-Encoding": "gzip", - "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:35 GMT", - "Expires": "-1", - "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-573349a368ccdf948b50068274813227-5d4dc1851c14a80d-01\u0022", - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Transfer-Encoding": "chunked", - "Vary": [ - "Accept-Encoding", - "Accept-Encoding" - ], - "x-aml-cluster": "vienna-eastus2euap-01", - "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "a7a86288-979b-4a68-90ce-dbc7607c4f13", - "x-ms-ratelimit-remaining-subscription-reads": "11880", - "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212736Z:a7a86288-979b-4a68-90ce-dbc7607c4f13", - "x-request-time": "0.028" - }, - "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_aml_component_datatransfer_folder/versions/2", - "name": "2", - "type": "Microsoft.MachineLearningServices/workspaces/data/versions", - "properties": { - "description": null, - "tags": {}, - "properties": {}, - "isArchived": false, - "isAnonymous": false, - "dataUri": "azureml://subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000/datastores/workspaceblobstore/paths/LocalUpload/69a18913-f8a0-4c46-8567-7c34ad162063/mnist-data/", - "dataType": "mltable", - "referencedUris": [ - "./0.png", - "./1.png", - "./2.png", - "./3.png" - ] - }, - "systemData": { - "createdAt": "2022-09-08T20:02:57.6322769\u002B00:00", - "createdBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "createdByType": "Application", - "lastModifiedAt": "2022-09-08T20:02:57.6395468\u002B00:00" - } - } - }, - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_reghits/versions/2?api-version=2022-05-01", - "RequestMethod": "GET", - "RequestHeaders": { - "Accept": "application/json", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" - }, - "RequestBody": null, - "StatusCode": 200, - "ResponseHeaders": { - "Cache-Control": "no-cache", - "Content-Encoding": "gzip", - "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:36 GMT", - "Expires": "-1", - "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-e2ce024b36139c97ad1ac6305c9a49bf-4b8b907bf4ff3416-01\u0022", - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Transfer-Encoding": "chunked", - "Vary": [ - "Accept-Encoding", - "Accept-Encoding" - ], - "x-aml-cluster": "vienna-eastus2euap-01", - "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "49ee7531-1d1b-4047-9664-02f5ba45eced", - "x-ms-ratelimit-remaining-subscription-reads": "11879", - "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212736Z:49ee7531-1d1b-4047-9664-02f5ba45eced", - "x-request-time": "0.033" - }, - "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_reghits/versions/2", - "name": "2", - "type": "Microsoft.MachineLearningServices/workspaces/data/versions", - "properties": { - "description": null, - "tags": {}, - "properties": {}, - "isArchived": false, - "isAnonymous": false, - "dataUri": "azureml://subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000/datastores/workspaceblobstore/paths/LocalUpload/bb274d89-8597-4878-90ea-4a141e1dced7/mnist-data/", - "dataType": "mltable", - "referencedUris": [ - "./0.png", - "./1.png", - "./2.png", - "./3.png" - ] - }, - "systemData": { - "createdAt": "2022-09-08T20:02:58.8078917\u002B00:00", - "createdBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "createdByType": "Application", - "lastModifiedAt": "2022-09-08T20:02:58.8181607\u002B00:00" - } - } - }, - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_starlite_sample_output/versions/2?api-version=2022-05-01", - "RequestMethod": "GET", - "RequestHeaders": { - "Accept": "application/json", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" - }, - "RequestBody": null, - "StatusCode": 200, - "ResponseHeaders": { - "Cache-Control": "no-cache", - "Content-Encoding": "gzip", - "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:36 GMT", - "Expires": "-1", - "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-2701cab795e533db592c0a049fb9094d-def59ee52444829b-01\u0022", - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Transfer-Encoding": "chunked", - "Vary": [ - "Accept-Encoding", - "Accept-Encoding" - ], - "x-aml-cluster": "vienna-eastus2euap-01", - "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "0bc97109-dad4-4acb-8606-b94e7fa10f4a", - "x-ms-ratelimit-remaining-subscription-reads": "11878", - "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212736Z:0bc97109-dad4-4acb-8606-b94e7fa10f4a", - "x-request-time": "0.029" - }, - "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/data/mltable_starlite_sample_output/versions/2", - "name": "2", - "type": "Microsoft.MachineLearningServices/workspaces/data/versions", - "properties": { - "description": null, - "tags": {}, - "properties": {}, - "isArchived": false, - "isAnonymous": false, - "dataUri": "azureml://subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000/datastores/workspaceblobstore/paths/LocalUpload/f4391760-0c4f-466c-b00a-853ba02b2852/mnist-data/", - "dataType": "mltable", - "referencedUris": [ - "./0.png", - "./1.png", - "./2.png", - "./3.png" - ] - }, - "systemData": { - "createdAt": "2022-09-08T20:02:59.9344465\u002B00:00", - "createdBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "createdByType": "Application", - "lastModifiedAt": "2022-09-08T20:02:59.9423742\u002B00:00" - } - } - }, { "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster?api-version=2022-01-01-preview", "RequestMethod": "GET", @@ -658,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -666,39 +15,39 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:36 GMT", + "Date": "Mon, 10 Oct 2022 03:48:01 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-a3bf77822298baba14160a1040dbafae-b0c6cddb4e3c4e7c-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-ca3a0dc977e48b3b7867cb9bd1b6a994-e2f7bd86ace70c6f-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "43e33c16-d4e9-4b9a-a9aa-e4a7961adab1", - "x-ms-ratelimit-remaining-subscription-reads": "11877", + "x-ms-correlation-request-id": "6c0fd18e-6153-459f-9108-f5657877bc1c", + "x-ms-ratelimit-remaining-subscription-reads": "11901", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212737Z:43e33c16-d4e9-4b9a-a9aa-e4a7961adab1", - "x-request-time": "0.051" + "x-ms-routing-request-id": "JAPANEAST:20221010T034801Z:6c0fd18e-6153-459f-9108-f5657877bc1c", + "x-request-time": "0.232" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", "name": "cpu-cluster", "type": "Microsoft.MachineLearningServices/workspaces/computes", - "location": "eastus2euap", + "location": "centraluseuap", "tags": {}, "properties": { - "createdOn": "2022-09-08T18:55:38.9086761\u002B00:00", - "modifiedOn": "2022-09-08T18:55:42.5777351\u002B00:00", + "createdOn": "2022-09-22T09:02:22.1899959\u002B00:00", + "modifiedOn": "2022-09-23T03:28:18.0066218\u002B00:00", "disableLocalAuth": false, "description": null, "resourceId": null, "computeType": "AmlCompute", - "computeLocation": "eastus2euap", + "computeLocation": "centraluseuap", "provisioningState": "Succeeded", "provisioningErrors": null, "isAttachedCompute": false, @@ -707,36 +56,23 @@ "vmPriority": "Dedicated", "scaleSettings": { "maxNodeCount": 4, - "minNodeCount": 0, + "minNodeCount": 1, "nodeIdleTimeBeforeScaleDown": "PT2M" }, "subnet": null, - "currentNodeCount": 3, - "targetNodeCount": 4, + "currentNodeCount": 1, + "targetNodeCount": 1, "nodeStateCounts": { "preparingNodeCount": 0, - "runningNodeCount": 2, + "runningNodeCount": 0, "idleNodeCount": 1, "unusableNodeCount": 0, "leavingNodeCount": 0, "preemptedNodeCount": 0 }, - "allocationState": "Resizing", - "allocationStateTransitionTime": "2022-09-08T21:25:00.046\u002B00:00", - "errors": [ - { - "error": { - "code": "DiskFull", - "message": "ComputeNode.Id=tvmps_d0800b4ef6ac4b49c7ad689296d28abfb0a8cea48569b43b9ea8eba2bdfddcd7_d: There is not enough disk space on the node", - "details": [ - { - "code": "Message", - "message": "The VM disk is full. Delete jobs, tasks, or files on the node to free up space and then reboot the node." - } - ] - } - } - ], + "allocationState": "Steady", + "allocationStateTransitionTime": "2022-09-30T08:08:43.647\u002B00:00", + "errors": null, "remoteLoginPortPublicAccess": "Enabled", "osType": "Linux", "virtualMachineImage": null, @@ -753,7 +89,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -761,39 +97,39 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:37 GMT", + "Date": "Mon, 10 Oct 2022 03:48:02 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-ee0bf358bd5f42da617f327e8e2ee083-c36c150014ae1d2a-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-f837b810124c78743eb4b0d34ed6e8d2-56a8adea8cffd56c-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "dc2dd6d6-d40c-4fcc-ab2c-de5dbb0b8926", - "x-ms-ratelimit-remaining-subscription-reads": "11876", + "x-ms-correlation-request-id": "18251651-5218-4813-84cb-d540ef640f95", + "x-ms-ratelimit-remaining-subscription-reads": "11900", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212737Z:dc2dd6d6-d40c-4fcc-ab2c-de5dbb0b8926", - "x-request-time": "0.122" + "x-ms-routing-request-id": "JAPANEAST:20221010T034802Z:18251651-5218-4813-84cb-d540ef640f95", + "x-request-time": "0.245" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", "name": "cpu-cluster", "type": "Microsoft.MachineLearningServices/workspaces/computes", - "location": "eastus2euap", + "location": "centraluseuap", "tags": {}, "properties": { - "createdOn": "2022-09-08T18:55:38.9086761\u002B00:00", - "modifiedOn": "2022-09-08T18:55:42.5777351\u002B00:00", + "createdOn": "2022-09-22T09:02:22.1899959\u002B00:00", + "modifiedOn": "2022-09-23T03:28:18.0066218\u002B00:00", "disableLocalAuth": false, "description": null, "resourceId": null, "computeType": "AmlCompute", - "computeLocation": "eastus2euap", + "computeLocation": "centraluseuap", "provisioningState": "Succeeded", "provisioningErrors": null, "isAttachedCompute": false, @@ -802,36 +138,23 @@ "vmPriority": "Dedicated", "scaleSettings": { "maxNodeCount": 4, - "minNodeCount": 0, + "minNodeCount": 1, "nodeIdleTimeBeforeScaleDown": "PT2M" }, "subnet": null, - "currentNodeCount": 3, - "targetNodeCount": 4, + "currentNodeCount": 1, + "targetNodeCount": 1, "nodeStateCounts": { "preparingNodeCount": 0, - "runningNodeCount": 2, + "runningNodeCount": 0, "idleNodeCount": 1, "unusableNodeCount": 0, "leavingNodeCount": 0, "preemptedNodeCount": 0 }, - "allocationState": "Resizing", - "allocationStateTransitionTime": "2022-09-08T21:25:00.046\u002B00:00", - "errors": [ - { - "error": { - "code": "DiskFull", - "message": "ComputeNode.Id=tvmps_d0800b4ef6ac4b49c7ad689296d28abfb0a8cea48569b43b9ea8eba2bdfddcd7_d: There is not enough disk space on the node", - "details": [ - { - "code": "Message", - "message": "The VM disk is full. Delete jobs, tasks, or files on the node to free up space and then reboot the node." - } - ] - } - } - ], + "allocationState": "Steady", + "allocationStateTransitionTime": "2022-09-30T08:08:43.647\u002B00:00", + "errors": null, "remoteLoginPortPublicAccess": "Enabled", "osType": "Linux", "virtualMachineImage": null, @@ -848,7 +171,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -856,39 +179,39 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:37 GMT", + "Date": "Mon, 10 Oct 2022 03:48:03 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-2aa3b9cf6ac446000027256bdabc5931-e358858a5399a9f9-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-0a07dfd419d5ac45d0d1bf34aa88066b-741b57d2c8dc4eb2-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "264d4511-c33b-4dae-9ace-67bde8190715", - "x-ms-ratelimit-remaining-subscription-reads": "11875", + "x-ms-correlation-request-id": "999b6eb9-848c-4212-952c-7df8035d5868", + "x-ms-ratelimit-remaining-subscription-reads": "11899", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212737Z:264d4511-c33b-4dae-9ace-67bde8190715", - "x-request-time": "0.045" + "x-ms-routing-request-id": "JAPANEAST:20221010T034803Z:999b6eb9-848c-4212-952c-7df8035d5868", + "x-request-time": "0.216" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", "name": "cpu-cluster", "type": "Microsoft.MachineLearningServices/workspaces/computes", - "location": "eastus2euap", + "location": "centraluseuap", "tags": {}, "properties": { - "createdOn": "2022-09-08T18:55:38.9086761\u002B00:00", - "modifiedOn": "2022-09-08T18:55:42.5777351\u002B00:00", + "createdOn": "2022-09-22T09:02:22.1899959\u002B00:00", + "modifiedOn": "2022-09-23T03:28:18.0066218\u002B00:00", "disableLocalAuth": false, "description": null, "resourceId": null, "computeType": "AmlCompute", - "computeLocation": "eastus2euap", + "computeLocation": "centraluseuap", "provisioningState": "Succeeded", "provisioningErrors": null, "isAttachedCompute": false, @@ -897,36 +220,23 @@ "vmPriority": "Dedicated", "scaleSettings": { "maxNodeCount": 4, - "minNodeCount": 0, + "minNodeCount": 1, "nodeIdleTimeBeforeScaleDown": "PT2M" }, "subnet": null, - "currentNodeCount": 3, - "targetNodeCount": 4, + "currentNodeCount": 1, + "targetNodeCount": 1, "nodeStateCounts": { "preparingNodeCount": 0, - "runningNodeCount": 2, + "runningNodeCount": 0, "idleNodeCount": 1, "unusableNodeCount": 0, "leavingNodeCount": 0, "preemptedNodeCount": 0 }, - "allocationState": "Resizing", - "allocationStateTransitionTime": "2022-09-08T21:25:00.046\u002B00:00", - "errors": [ - { - "error": { - "code": "DiskFull", - "message": "ComputeNode.Id=tvmps_d0800b4ef6ac4b49c7ad689296d28abfb0a8cea48569b43b9ea8eba2bdfddcd7_d: There is not enough disk space on the node", - "details": [ - { - "code": "Message", - "message": "The VM disk is full. Delete jobs, tasks, or files on the node to free up space and then reboot the node." - } - ] - } - } - ], + "allocationState": "Steady", + "allocationStateTransitionTime": "2022-09-30T08:08:43.647\u002B00:00", + "errors": null, "remoteLoginPortPublicAccess": "Enabled", "osType": "Linux", "virtualMachineImage": null, @@ -943,7 +253,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -951,24 +261,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:37 GMT", + "Date": "Mon, 10 Oct 2022 03:48:05 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-dfe53fcc048c5f0e11fb5d93173a48cd-d2aa7544b6f3ea3d-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-3a86069066c9889802e60d544fb711f7-71c8dd13c092243c-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "3ecbdb64-5a79-4fe8-a976-5a1fa2a67020", - "x-ms-ratelimit-remaining-subscription-reads": "11874", + "x-ms-correlation-request-id": "3a8a3454-5c8e-4747-9311-2546be1da932", + "x-ms-ratelimit-remaining-subscription-reads": "11898", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212737Z:3ecbdb64-5a79-4fe8-a976-5a1fa2a67020", - "x-request-time": "0.072" + "x-ms-routing-request-id": "JAPANEAST:20221010T034806Z:3a8a3454-5c8e-4747-9311-2546be1da932", + "x-request-time": "0.084" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -983,15 +293,19 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sab4vfkrtgocvgg", - "containerName": "azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-08T18:55:30.287909\u002B00:00", - "lastModifiedAt": "2022-09-08T18:55:31.6200147\u002B00:00" + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "createdByType": "Application", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "lastModifiedByType": "Application" } } }, @@ -1003,7 +317,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -1011,21 +325,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:38 GMT", + "Date": "Mon, 10 Oct 2022 03:48:06 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-07d94410b734d57eac98e8c3893d8b27-9b054c4c449633d9-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-94cf52c4e19397c5ef0ec0ceed7cad5b-6b1232f9b0e1a40d-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "2ed36e79-1e9d-4569-891b-0955d5a5839e", - "x-ms-ratelimit-remaining-subscription-writes": "1181", + "x-ms-correlation-request-id": "86732bbd-3824-4cf3-b810-05c6b56a5b49", + "x-ms-ratelimit-remaining-subscription-writes": "1159", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212738Z:2ed36e79-1e9d-4569-891b-0955d5a5839e", - "x-request-time": "0.090" + "x-ms-routing-request-id": "JAPANEAST:20221010T034806Z:86732bbd-3824-4cf3-b810-05c6b56a5b49", + "x-request-time": "0.097" }, "ResponseBody": { "secretsType": "AccountKey", @@ -1033,20 +347,20 @@ } }, { - "RequestUri": "https://sab4vfkrtgocvgg.blob.core.windows.net/azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8/LocalUpload/000000000000000000000/one-line-tsv/component.yaml", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/one-line-tsv/component.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Thu, 08 Sep 2022 21:27:37 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:48:06 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Thu, 08 Sep 2022 21:27:37 GMT", + "Date": "Mon, 10 Oct 2022 03:48:06 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -1054,12 +368,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sab4vfkrtgocvgg.blob.core.windows.net/azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8/LocalUpload/000000000000000000000/one-line-tsv/component.yaml", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/one-line-tsv/component.yaml", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/xml", @@ -1069,57 +383,57 @@ "Content-MD5": "I/mAXjP62f\u002B\u002BfKCunnI4hw==", "Content-Type": "application/octet-stream", "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Thu, 08 Sep 2022 21:27:37 GMT", - "x-ms-version": "2021-06-08" + "x-ms-date": "Mon, 10 Oct 2022 03:48:07 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbg0KbmFtZTogb25lX2xpbmVfdHN2DQpkaXNwbGF5X25hbWU6IEdlbmVyYXRlIE9uZSBMaW5lIFRzdg0KdmVyc2lvbjogMC4wLjENCnR5cGU6IENvbW1hbmRDb21wb25lbnQNCmlzX2RldGVybWluaXN0aWM6IHRydWUNCnRhZ3M6IHt9DQppbnB1dHM6DQogIGNvbnRlbnQ6DQogICAgdHlwZTogc3RyaW5nDQogICAgb3B0aW9uYWw6IGZhbHNlDQogIHRzdl9maWxlOg0KICAgIHR5cGU6IHN0cmluZw0KICAgIG9wdGlvbmFsOiBmYWxzZQ0KICAgIGRlZmF1bHQ6IG91dHB1dC50c3YNCm91dHB1dHM6DQogIG91dHB1dF9kaXI6DQogICAgdHlwZTogcGF0aA0KY29tbWFuZDogPi0NCiAgZWNobyB7aW5wdXRzLmNvbnRlbnR9ID4ge291dHB1dHMub3V0cHV0X2Rpcn0ve2lucHV0cy50c3ZfZmlsZX0NCmVudmlyb25tZW50Og0KICBuYW1lOiBBenVyZU1MLURlc2lnbmVyDQo=", "StatusCode": 201, "ResponseHeaders": { "Content-Length": "0", "Content-MD5": "I/mAXjP62f\u002B\u002BfKCunnI4hw==", - "Date": "Thu, 08 Sep 2022 21:27:37 GMT", - "ETag": "\u00220x8DA91E0F47B2B77\u0022", - "Last-Modified": "Thu, 08 Sep 2022 21:27:38 GMT", + "Date": "Mon, 10 Oct 2022 03:48:07 GMT", + "ETag": "\u00220x8DAAA723E25AF53\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:48:07 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" ], "x-ms-content-crc64": "r8/6saZu0JE=", "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sab4vfkrtgocvgg.blob.core.windows.net/azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8/LocalUpload/000000000000000000000/one-line-tsv/component.yaml?comp=metadata", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/one-line-tsv/component.yaml?comp=metadata", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Thu, 08 Sep 2022 21:27:37 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:48:07 GMT", "x-ms-meta-name": "000000000000000000000", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Content-Length": "0", - "Date": "Thu, 08 Sep 2022 21:27:37 GMT", - "ETag": "\u00220x8DA91E0F482F2FF\u0022", - "Last-Modified": "Thu, 08 Sep 2022 21:27:38 GMT", + "Date": "Mon, 10 Oct 2022 03:48:07 GMT", + "ETag": "\u00220x8DAAA723E447D70\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:48:07 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" ], "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, @@ -1130,40 +444,40 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "345", + "Content-Length": "301", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { "properties": { - "hash_sha256": "7c636703711f19586ee7ec944199883629e0fd4971a7fcc8a249dbea2317147b", - "hash_version": "202208" + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sab4vfkrtgocvgg.blob.core.windows.net/azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8/LocalUpload/000000000000000000000/one-line-tsv" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/one-line-tsv" } }, "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1029", + "Content-Length": "816", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:40 GMT", + "Date": "Mon, 10 Oct 2022 03:48:08 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-892c8bd8e067ab9c78fe1a8edd8ffd4d-f684904f0398fe85-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-13cc316b028ef00e4c91be1ce183ce69-04574b64921a5363-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "0782a99c-d976-4e7f-9c08-a52365d831e6", - "x-ms-ratelimit-remaining-subscription-writes": "1172", + "x-ms-correlation-request-id": "9e63018d-4e01-4d0e-bc83-83ff15a42eb1", + "x-ms-ratelimit-remaining-subscription-writes": "1130", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212740Z:0782a99c-d976-4e7f-9c08-a52365d831e6", - "x-request-time": "0.126" + "x-ms-routing-request-id": "JAPANEAST:20221010T034808Z:9e63018d-4e01-4d0e-bc83-83ff15a42eb1", + "x-request-time": "0.511" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1", @@ -1173,20 +487,20 @@ "description": null, "tags": {}, "properties": { - "hash_sha256": "7c636703711f19586ee7ec944199883629e0fd4971a7fcc8a249dbea2317147b", - "hash_version": "202208" + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sab4vfkrtgocvgg.blob.core.windows.net/azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8/LocalUpload/000000000000000000000/one-line-tsv" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/one-line-tsv" }, "systemData": { - "createdAt": "2022-09-08T21:27:40.5701979\u002B00:00", - "createdBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "createdByType": "Application", - "lastModifiedAt": "2022-09-08T21:27:40.5701979\u002B00:00", - "lastModifiedBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "lastModifiedByType": "Application" + "createdAt": "2022-10-10T03:48:08.3317693\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:48:08.3317693\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" } } }, @@ -1197,9 +511,9 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "829", + "Content-Length": "832", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -1216,12 +530,10 @@ "is_deterministic": true, "inputs": { "content": { - "type": "string", - "optional": false + "type": "string" }, "tsv_file": { "type": "string", - "optional": false, "default": "output.tsv" } }, @@ -1232,7 +544,10 @@ }, "type": "CommandComponent", "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1", - "environment": {}, + "environment": { + "os": "Linux", + "name": "AzureML-Designer" + }, "command": "echo {inputs.content} \u003E {outputs.output_dir}/{inputs.tsv_file}" } } @@ -1240,26 +555,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1979", + "Content-Length": "1852", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:40 GMT", + "Date": "Mon, 10 Oct 2022 03:48:10 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-d22993b75f7b115b3e76aed7627f53af-91879d7613a3ff1b-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-cb41f4391529a28b81b8b1a9ed3c9133-4bd4a7f4f28f747b-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "9845ff83-7f52-4356-9701-c817fb860bac", - "x-ms-ratelimit-remaining-subscription-writes": "1171", + "x-ms-correlation-request-id": "2e51b4f8-4833-49c2-b7f0-48840c4f5a72", + "x-ms-ratelimit-remaining-subscription-writes": "1129", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212741Z:9845ff83-7f52-4356-9701-c817fb860bac", - "x-request-time": "0.505" + "x-ms-routing-request-id": "JAPANEAST:20221010T034811Z:2e51b4f8-4833-49c2-b7f0-48840c4f5a72", + "x-request-time": "1.897" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0f70e41a-46c6-47e0-b737-42f3afd8bc9d", - "name": "0f70e41a-46c6-47e0-b737-42f3afd8bc9d", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/98f24375-15da-4ba9-83c4-65d2d044081e", + "name": "98f24375-15da-4ba9-83c4-65d2d044081e", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -1270,7 +585,7 @@ "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", "name": "azureml_anonymous", - "version": "0f70e41a-46c6-47e0-b737-42f3afd8bc9d", + "version": "98f24375-15da-4ba9-83c4-65d2d044081e", "display_name": "Generate One Line Tsv", "is_deterministic": "True", "type": "CommandComponent", @@ -1292,9 +607,7 @@ } }, "environment": { - "docker": { - "image": "mcr.microsoft.com/azureml/openmpi3.1.2-ubuntu18.04" - }, + "name": "AzureML-Designer", "os": "Linux" }, "successful_return_code": "Zero", @@ -1303,12 +616,12 @@ } }, "systemData": { - "createdAt": "2022-09-08T21:27:41.0613027\u002B00:00", - "createdBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "createdByType": "Application", - "lastModifiedAt": "2022-09-08T21:27:41.0613027\u002B00:00", - "lastModifiedBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "lastModifiedByType": "Application" + "createdAt": "2022-10-10T03:48:10.4696324\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:48:10.4696324\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" } } }, @@ -1319,7 +632,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -1327,24 +640,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:41 GMT", + "Date": "Mon, 10 Oct 2022 03:48:11 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-7066695c14f925c75fe06d885e56f023-a06b648c70e8fdfa-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-cd366c22d7fd15f6da969437b0af7483-e9c501e970d8857d-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "77418d58-5cfd-461c-9657-413fbcab277c", - "x-ms-ratelimit-remaining-subscription-reads": "11873", + "x-ms-correlation-request-id": "c0987000-4cb9-4320-835f-120ffa881233", + "x-ms-ratelimit-remaining-subscription-reads": "11897", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212741Z:77418d58-5cfd-461c-9657-413fbcab277c", - "x-request-time": "0.080" + "x-ms-routing-request-id": "JAPANEAST:20221010T034811Z:c0987000-4cb9-4320-835f-120ffa881233", + "x-request-time": "0.091" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -1359,48 +672,22 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sab4vfkrtgocvgg", - "containerName": "azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-08T18:55:30.287909\u002B00:00", - "lastModifiedAt": "2022-09-08T18:55:31.6200147\u002B00:00" + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "createdByType": "Application", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "lastModifiedByType": "Application" } } }, - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/eastus2euap/mfeOperationResults/jc:cd46beb1-8b9b-4bdc-974f-092de17efdd8:000000000000000000000?api-version=2022-06-01-preview", - "RequestMethod": "GET", - "RequestHeaders": { - "Accept": "*/*", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" - }, - "RequestBody": null, - "StatusCode": 200, - "ResponseHeaders": { - "Cache-Control": "no-cache", - "Content-Length": "0", - "Date": "Thu, 08 Sep 2022 21:27:41 GMT", - "Expires": "-1", - "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-2bf77400e937677199737cbed9522f0e-ac1f14b1b89f0e32-01\u0022", - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-01", - "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "2517023f-18ef-467d-af64-40439e59ea28", - "x-ms-ratelimit-remaining-subscription-reads": "11947", - "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212742Z:2517023f-18ef-467d-af64-40439e59ea28", - "x-request-time": "0.029" - }, - "ResponseBody": null - }, { "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore/listSecrets?api-version=2022-05-01", "RequestMethod": "POST", @@ -1409,7 +696,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -1417,21 +704,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:41 GMT", + "Date": "Mon, 10 Oct 2022 03:48:12 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-1b25851ac14beeb85a51bbc7760fdf1a-f45812cf09090e28-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-4506a86c53b0005a8053aafc36c8638f-29012a9b627f42b5-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "ec852552-803b-4ec8-ae32-ed9866cae7d4", - "x-ms-ratelimit-remaining-subscription-writes": "1180", + "x-ms-correlation-request-id": "a74213d1-e3a9-4b79-917a-01081b90901f", + "x-ms-ratelimit-remaining-subscription-writes": "1158", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212742Z:ec852552-803b-4ec8-ae32-ed9866cae7d4", - "x-request-time": "0.094" + "x-ms-routing-request-id": "JAPANEAST:20221010T034812Z:a74213d1-e3a9-4b79-917a-01081b90901f", + "x-request-time": "0.091" }, "ResponseBody": { "secretsType": "AccountKey", @@ -1439,20 +726,20 @@ } }, { - "RequestUri": "https://sab4vfkrtgocvgg.blob.core.windows.net/azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8/LocalUpload/000000000000000000000/copy/component.yaml", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/copy/component.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Thu, 08 Sep 2022 21:27:41 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:48:12 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Thu, 08 Sep 2022 21:27:41 GMT", + "Date": "Mon, 10 Oct 2022 03:48:12 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -1460,12 +747,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sab4vfkrtgocvgg.blob.core.windows.net/azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8/LocalUpload/000000000000000000000/copy/component.yaml", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/copy/component.yaml", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/xml", @@ -1475,57 +762,57 @@ "Content-MD5": "ISeDnoo/Cj2rw6jTAllU1A==", "Content-Type": "application/octet-stream", "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Thu, 08 Sep 2022 21:27:41 GMT", - "x-ms-version": "2021-06-08" + "x-ms-date": "Mon, 10 Oct 2022 03:48:12 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbg0KbmFtZTogY29weV9jb21tYW5kDQpkaXNwbGF5X25hbWU6IENvcHkgQ29tbWFuZA0KdmVyc2lvbjogMC4wLjENCnR5cGU6IENvbW1hbmRDb21wb25lbnQNCmlzX2RldGVybWluaXN0aWM6IHRydWUNCnRhZ3M6IHt9DQppbnB1dHM6DQogIGlucHV0X2RpcjoNCiAgICB0eXBlOiBwYXRoDQogICAgb3B0aW9uYWw6IGZhbHNlDQogIGZpbGVfbmFtZXM6DQogICAgdHlwZTogc3RyaW5nDQogICAgb3B0aW9uYWw6IGZhbHNlDQpvdXRwdXRzOg0KICBvdXRwdXRfZGlyOg0KICAgIHR5cGU6IHBhdGgNCmNvbW1hbmQ6ID4tDQogIGNwIHtpbnB1dHMuaW5wdXRfZGlyfS97aW5wdXRzLmZpbGVfbmFtZXN9IHtvdXRwdXRzLm91dHB1dF9kaXJ9DQplbnZpcm9ubWVudDoNCiAgbmFtZTogQXp1cmVNTC1EZXNpZ25lcg0K", "StatusCode": 201, "ResponseHeaders": { "Content-Length": "0", "Content-MD5": "ISeDnoo/Cj2rw6jTAllU1A==", - "Date": "Thu, 08 Sep 2022 21:27:41 GMT", - "ETag": "\u00220x8DA91E0F6C86C52\u0022", - "Last-Modified": "Thu, 08 Sep 2022 21:27:42 GMT", + "Date": "Mon, 10 Oct 2022 03:48:12 GMT", + "ETag": "\u00220x8DAAA72417E47F6\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:48:12 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" ], "x-ms-content-crc64": "AgKDLddIyB8=", "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sab4vfkrtgocvgg.blob.core.windows.net/azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8/LocalUpload/000000000000000000000/copy/component.yaml?comp=metadata", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/copy/component.yaml?comp=metadata", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Thu, 08 Sep 2022 21:27:41 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:48:12 GMT", "x-ms-meta-name": "000000000000000000000", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Content-Length": "0", - "Date": "Thu, 08 Sep 2022 21:27:41 GMT", - "ETag": "\u00220x8DA91E0F6D0D009\u0022", - "Last-Modified": "Thu, 08 Sep 2022 21:27:42 GMT", + "Date": "Mon, 10 Oct 2022 03:48:12 GMT", + "ETag": "\u00220x8DAAA72419B68A3\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:48:13 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" ], "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, @@ -1536,40 +823,40 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "337", + "Content-Length": "293", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { "properties": { - "hash_sha256": "f2de2331409b8b56b433ca377f00901c623279669abdc59c4e7288b2180df725", - "hash_version": "202208" + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sab4vfkrtgocvgg.blob.core.windows.net/azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8/LocalUpload/000000000000000000000/copy" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/copy" } }, "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1021", + "Content-Length": "808", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:42 GMT", + "Date": "Mon, 10 Oct 2022 03:48:13 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-228d4d2a4195cbd1057695be8938de7d-28bab99ff2a01b53-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-733c6207bc06c3003efb9e08eec4d533-a2a36859659934ff-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "b1695c39-3434-4ce6-a2cf-455159b07ae8", - "x-ms-ratelimit-remaining-subscription-writes": "1170", + "x-ms-correlation-request-id": "30b55e71-9e30-4592-92ca-feff1ff9f0d5", + "x-ms-ratelimit-remaining-subscription-writes": "1128", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212742Z:b1695c39-3434-4ce6-a2cf-455159b07ae8", - "x-request-time": "0.114" + "x-ms-routing-request-id": "JAPANEAST:20221010T034813Z:30b55e71-9e30-4592-92ca-feff1ff9f0d5", + "x-request-time": "0.469" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1", @@ -1579,20 +866,20 @@ "description": null, "tags": {}, "properties": { - "hash_sha256": "f2de2331409b8b56b433ca377f00901c623279669abdc59c4e7288b2180df725", - "hash_version": "202208" + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sab4vfkrtgocvgg.blob.core.windows.net/azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8/LocalUpload/000000000000000000000/copy" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/copy" }, "systemData": { - "createdAt": "2022-09-08T21:27:42.7798705\u002B00:00", - "createdBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "createdByType": "Application", - "lastModifiedAt": "2022-09-08T21:27:42.7798705\u002B00:00", - "lastModifiedBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "lastModifiedByType": "Application" + "createdAt": "2022-10-10T03:48:13.5777125\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:48:13.5777125\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" } } }, @@ -1603,9 +890,9 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "797", + "Content-Length": "800", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -1622,12 +909,10 @@ "is_deterministic": true, "inputs": { "input_dir": { - "type": "path", - "optional": false + "type": "path" }, "file_names": { - "type": "string", - "optional": false + "type": "string" } }, "outputs": { @@ -1637,7 +922,10 @@ }, "type": "CommandComponent", "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1", - "environment": {}, + "environment": { + "os": "Linux", + "name": "AzureML-Designer" + }, "command": "cp {inputs.input_dir}/{inputs.file_names} {outputs.output_dir}" } } @@ -1645,26 +933,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1974", + "Content-Length": "1847", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:44 GMT", + "Date": "Mon, 10 Oct 2022 03:48:15 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-cf71ac21d773260579dc45c70363d016-3c84617ca8f4468c-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-63680f43d63a952f1eda8cf367e79d79-712aa2c841dc6c99-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "7b6396ae-6e64-4aaa-8464-94ab726e6d14", - "x-ms-ratelimit-remaining-subscription-writes": "1169", + "x-ms-correlation-request-id": "20c19426-9359-42d3-aecf-419a2aff64f6", + "x-ms-ratelimit-remaining-subscription-writes": "1127", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212744Z:7b6396ae-6e64-4aaa-8464-94ab726e6d14", - "x-request-time": "0.495" + "x-ms-routing-request-id": "JAPANEAST:20221010T034816Z:20c19426-9359-42d3-aecf-419a2aff64f6", + "x-request-time": "1.879" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/9a9de9ec-0083-4031-ae54-5364f2c6f70a", - "name": "9a9de9ec-0083-4031-ae54-5364f2c6f70a", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/f9282ef9-604e-4109-8ea6-e565cc20d711", + "name": "f9282ef9-604e-4109-8ea6-e565cc20d711", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -1675,7 +963,7 @@ "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", "name": "azureml_anonymous", - "version": "9a9de9ec-0083-4031-ae54-5364f2c6f70a", + "version": "f9282ef9-604e-4109-8ea6-e565cc20d711", "display_name": "Copy Command", "is_deterministic": "True", "type": "CommandComponent", @@ -1697,9 +985,7 @@ } }, "environment": { - "docker": { - "image": "mcr.microsoft.com/azureml/openmpi3.1.2-ubuntu18.04" - }, + "name": "AzureML-Designer", "os": "Linux" }, "successful_return_code": "Zero", @@ -1708,12 +994,12 @@ } }, "systemData": { - "createdAt": "2022-09-08T21:27:44.5657525\u002B00:00", - "createdBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "createdByType": "Application", - "lastModifiedAt": "2022-09-08T21:27:44.5657525\u002B00:00", - "lastModifiedBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "lastModifiedByType": "Application" + "createdAt": "2022-10-10T03:48:15.7092374\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:48:15.7092374\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" } } }, @@ -1724,7 +1010,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -1732,24 +1018,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:44 GMT", + "Date": "Mon, 10 Oct 2022 03:48:16 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-7a7133992541447c3d1085e4d800ee54-fa08d944e6cc6c2c-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-4af5b54e99d77f0a76dcd311f0470a2e-d944080bd5c2ebaf-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "eb35831c-379d-4219-996e-faa2b6628792", - "x-ms-ratelimit-remaining-subscription-reads": "11872", + "x-ms-correlation-request-id": "8c5ace35-f7cf-4bb4-bb4f-3e1eefbd9e24", + "x-ms-ratelimit-remaining-subscription-reads": "11896", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212745Z:eb35831c-379d-4219-996e-faa2b6628792", - "x-request-time": "0.093" + "x-ms-routing-request-id": "JAPANEAST:20221010T034816Z:8c5ace35-f7cf-4bb4-bb4f-3e1eefbd9e24", + "x-request-time": "0.109" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -1764,15 +1050,19 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sab4vfkrtgocvgg", - "containerName": "azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-08T18:55:30.287909\u002B00:00", - "lastModifiedAt": "2022-09-08T18:55:31.6200147\u002B00:00" + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "createdByType": "Application", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "lastModifiedByType": "Application" } } }, @@ -1784,7 +1074,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -1792,21 +1082,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:45 GMT", + "Date": "Mon, 10 Oct 2022 03:48:16 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-99f9b50e986bf85c0487dda441f90174-76fe37db99c1ca76-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-29b51c2f2adcbb0c557b33a7e3ec5eaa-8e803b3112696f4d-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "7abd4d35-944a-4c95-ba76-270165ad45ba", - "x-ms-ratelimit-remaining-subscription-writes": "1179", + "x-ms-correlation-request-id": "71f55c97-e482-4d3a-a596-1103d4ed9312", + "x-ms-ratelimit-remaining-subscription-writes": "1157", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212745Z:7abd4d35-944a-4c95-ba76-270165ad45ba", - "x-request-time": "0.081" + "x-ms-routing-request-id": "JAPANEAST:20221010T034817Z:71f55c97-e482-4d3a-a596-1103d4ed9312", + "x-request-time": "0.099" }, "ResponseBody": { "secretsType": "AccountKey", @@ -1814,20 +1104,20 @@ } }, { - "RequestUri": "https://sab4vfkrtgocvgg.blob.core.windows.net/azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8/LocalUpload/000000000000000000000/ls/ls.yaml", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/ls/ls.yaml", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Thu, 08 Sep 2022 21:27:44 GMT", - "x-ms-version": "2021-06-08" + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:48:17 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Thu, 08 Sep 2022 21:27:45 GMT", + "Date": "Mon, 10 Oct 2022 03:48:17 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -1835,12 +1125,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sab4vfkrtgocvgg.blob.core.windows.net/azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8/LocalUpload/000000000000000000000/ls/ls.yaml", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/ls/ls.yaml", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/xml", @@ -1850,57 +1140,57 @@ "Content-MD5": "4FDxsPtcQKSnynuNx488iw==", "Content-Type": "application/octet-stream", "If-None-Match": "*", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", "x-ms-blob-type": "BlockBlob", - "x-ms-date": "Thu, 08 Sep 2022 21:27:44 GMT", - "x-ms-version": "2021-06-08" + "x-ms-date": "Mon, 10 Oct 2022 03:48:17 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": "JHNjaGVtYTogaHR0cHM6Ly9jb21wb25lbnRzZGsuYXp1cmVlZGdlLm5ldC9qc29uc2NoZW1hL0NvbW1hbmRDb21wb25lbnQuanNvbg0KbmFtZTogbHNfY29tbWFuZA0KZGlzcGxheV9uYW1lOiBMcyBDb21tYW5kDQp2ZXJzaW9uOiAwLjAuMQ0KdHlwZTogQ29tbWFuZENvbXBvbmVudA0KaXNfZGV0ZXJtaW5pc3RpYzogdHJ1ZQ0KdGFnczoge30NCmlucHV0czoNCiAgaW5wdXRfZGlyOg0KICAgIHR5cGU6IHBhdGgNCiAgICBvcHRpb25hbDogZmFsc2UNCm91dHB1dHM6IHt9DQpjb21tYW5kOiA\u002BLQ0KICBscyB7aW5wdXRzLmlucHV0X2Rpcn0NCmVudmlyb25tZW50Og0KICBuYW1lOiBBenVyZU1MLURlc2lnbmVyDQo=", "StatusCode": 201, "ResponseHeaders": { "Content-Length": "0", "Content-MD5": "4FDxsPtcQKSnynuNx488iw==", - "Date": "Thu, 08 Sep 2022 21:27:45 GMT", - "ETag": "\u00220x8DA91E0F8DCA09C\u0022", - "Last-Modified": "Thu, 08 Sep 2022 21:27:46 GMT", + "Date": "Mon, 10 Oct 2022 03:48:17 GMT", + "ETag": "\u00220x8DAAA72447483AD\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:48:17 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" ], "x-ms-content-crc64": "RhOdAIh1YAA=", "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sab4vfkrtgocvgg.blob.core.windows.net/azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8/LocalUpload/000000000000000000000/ls/ls.yaml?comp=metadata", + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/ls/ls.yaml?comp=metadata", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azsdk-python-storage-blob/12.12.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-ms-date": "Thu, 08 Sep 2022 21:27:45 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:48:17 GMT", "x-ms-meta-name": "000000000000000000000", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Content-Length": "0", - "Date": "Thu, 08 Sep 2022 21:27:45 GMT", - "ETag": "\u00220x8DA91E0F8E3A4E2\u0022", - "Last-Modified": "Thu, 08 Sep 2022 21:27:46 GMT", + "Date": "Mon, 10 Oct 2022 03:48:17 GMT", + "ETag": "\u00220x8DAAA724492DCAF\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:48:17 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" ], "x-ms-request-server-encrypted": "true", - "x-ms-version": "2021-06-08" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, @@ -1911,40 +1201,40 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "335", + "Content-Length": "291", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { "properties": { - "hash_sha256": "ff68e097bba530d7bce7a047abb7a81b0e509542f4f24f741a647c4f7bf3ea3a", - "hash_version": "202208" + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sab4vfkrtgocvgg.blob.core.windows.net/azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8/LocalUpload/000000000000000000000/ls" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/ls" } }, "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1017", + "Content-Length": "806", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:45 GMT", + "Date": "Mon, 10 Oct 2022 03:48:18 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-6ac91b8353c9911fabbe9c7c8f83656b-633c97678c1afc9c-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-1bfba295c26efb0eb7d2136ee0266888-1086026a2a51b00b-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "fb605f8e-c8a7-4e2e-a5e1-e0a04e145189", - "x-ms-ratelimit-remaining-subscription-writes": "1168", + "x-ms-correlation-request-id": "05f5deb5-4083-4877-a589-b1e4adf1319c", + "x-ms-ratelimit-remaining-subscription-writes": "1126", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212746Z:fb605f8e-c8a7-4e2e-a5e1-e0a04e145189", - "x-request-time": "0.150" + "x-ms-routing-request-id": "JAPANEAST:20221010T034819Z:05f5deb5-4083-4877-a589-b1e4adf1319c", + "x-request-time": "0.373" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1", @@ -1954,20 +1244,20 @@ "description": null, "tags": {}, "properties": { - "hash_sha256": "ff68e097bba530d7bce7a047abb7a81b0e509542f4f24f741a647c4f7bf3ea3a", - "hash_version": "202208" + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sab4vfkrtgocvgg.blob.core.windows.net/azureml-blobstore-cd46beb1-8b9b-4bdc-974f-092de17efdd8/LocalUpload/000000000000000000000/ls" + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/ls" }, "systemData": { - "createdAt": "2022-09-08T21:27:46.340477\u002B00:00", - "createdBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "createdByType": "Application", - "lastModifiedAt": "2022-09-08T21:27:46.340477\u002B00:00", - "lastModifiedBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "lastModifiedByType": "Application" + "createdAt": "2022-10-10T03:48:18.7141211\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:48:18.7141211\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" } } }, @@ -1978,9 +1268,9 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "671", + "Content-Length": "693", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -1997,14 +1287,16 @@ "is_deterministic": true, "inputs": { "input_dir": { - "type": "path", - "optional": false + "type": "path" } }, "outputs": {}, "type": "CommandComponent", "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1", - "environment": {}, + "environment": { + "os": "Linux", + "name": "AzureML-Designer" + }, "command": "ls {inputs.input_dir}" } } @@ -2012,26 +1304,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1713", + "Content-Length": "1586", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:47 GMT", + "Date": "Mon, 10 Oct 2022 03:48:20 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-4d9a0e7731137206ca43d6e8f4dfaf19-26f4f604b3662d73-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-8e6835d98c9a6da04f40b45276946e7d-99f0a384192d1591-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "13ba63ca-4aeb-44b7-bb6b-9306d4066fb4", - "x-ms-ratelimit-remaining-subscription-writes": "1167", + "x-ms-correlation-request-id": "3b1e69e0-874c-45b0-9c18-3acf134df531", + "x-ms-ratelimit-remaining-subscription-writes": "1125", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212747Z:13ba63ca-4aeb-44b7-bb6b-9306d4066fb4", - "x-request-time": "0.514" + "x-ms-routing-request-id": "JAPANEAST:20221010T034821Z:3b1e69e0-874c-45b0-9c18-3acf134df531", + "x-request-time": "1.910" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/6e612aea-d513-45b8-bbd6-282848123ea6", - "name": "6e612aea-d513-45b8-bbd6-282848123ea6", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/31415cc3-81dd-4085-8824-13f76ee1cbbb", + "name": "31415cc3-81dd-4085-8824-13f76ee1cbbb", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -2042,7 +1334,7 @@ "componentSpec": { "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", "name": "azureml_anonymous", - "version": "6e612aea-d513-45b8-bbd6-282848123ea6", + "version": "31415cc3-81dd-4085-8824-13f76ee1cbbb", "display_name": "Ls Command", "is_deterministic": "True", "type": "CommandComponent", @@ -2054,9 +1346,7 @@ } }, "environment": { - "docker": { - "image": "mcr.microsoft.com/azureml/openmpi3.1.2-ubuntu18.04" - }, + "name": "AzureML-Designer", "os": "Linux" }, "successful_return_code": "Zero", @@ -2065,85 +1355,30 @@ } }, "systemData": { - "createdAt": "2022-09-08T21:27:47.2159072\u002B00:00", - "createdBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "createdByType": "Application", - "lastModifiedAt": "2022-09-08T21:27:47.2159072\u002B00:00", - "lastModifiedBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "lastModifiedByType": "Application" + "createdAt": "2022-10-10T03:48:20.7205182\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:48:20.7205182\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" } } }, { - "RequestUri": "https://login.microsoftonline.com/72f988bf-86f1-41af-91ab-2d7cd011db47/oauth2/v2.0/token", - "RequestMethod": "POST", - "RequestHeaders": { - "Accept": "application/json", - "Accept-Encoding": "gzip, deflate", - "client-request-id": "0de69eae-e31f-4a65-a79e-ca2885945879", - "Connection": "keep-alive", - "Content-Length": "284", - "Content-Type": "application/x-www-form-urlencoded", - "Cookie": "fpc=AhwGpJCOzHhIuETiqO8P0ujwQhvHEwAAAM9UrNoOAAAARUxcfQgAAADXVKzaDgAAAA; stsservicecookie=estsfd; x-ms-gateway-slice=estsfd", - "User-Agent": "azsdk-python-identity/1.11.0b4 Python/3.8.6 (Windows-10-10.0.22000-SP0)", - "x-client-cpu": "x64", - "x-client-current-telemetry": "4|730,0|", - "x-client-last-telemetry": "4|1|||", - "x-client-os": "win32", - "x-client-sku": "MSAL.Python", - "x-client-ver": "1.18.0", - "x-ms-lib-capability": "retry-after, h429" - }, - "RequestBody": "client_id=5019366a-3f7a-4d18-adae-d2483c23e1ee\u0026grant_type=client_credentials\u0026client_info=1\u0026client_secret=5FL8Q~~BBdJpY_y.KpA94zzLZv2Czg.uYQAmfaMZ\u0026claims=%7B%22access_token%22%3A\u002B%7B%22xms_cc%22%3A\u002B%7B%22values%22%3A\u002B%5B%22CP1%22%5D%7D%7D%7D\u0026scope=https%3A%2F%2Fml.azure.com%2F.default", - "StatusCode": 200, - "ResponseHeaders": { - "Cache-Control": "no-store, no-cache", - "client-request-id": "0de69eae-e31f-4a65-a79e-ca2885945879", - "Content-Length": "111", - "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:47 GMT", - "Expires": "-1", - "P3P": "CP=\u0022DSP CUR OTPi IND OTRi ONL FIN\u0022", - "Pragma": "no-cache", - "Set-Cookie": [ - "fpc=AhwGpJCOzHhIuETiqO8P0ujwQhvHEwAAAM9UrNoOAAAARUxcfQkAAADXVKzaDgAAAA; expires=Sat, 08-Oct-2022 21:27:47 GMT; path=/; secure; HttpOnly; SameSite=None", - "x-ms-gateway-slice=estsfd; path=/; secure; samesite=none; httponly", - "stsservicecookie=estsfd; path=/; secure; samesite=none; httponly" - ], - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "X-Content-Type-Options": "nosniff", - "x-ms-clitelem": "1,0,0,,", - "x-ms-ests-server": "2.1.13622.6 - EUS ProdSlices", - "X-XSS-Protection": "0" - }, - "ResponseBody": { - "token_type": "Bearer", - "expires_in": 86399, - "ext_expires_in": 86399, - "refresh_in": 43199, - "access_token": "Sanitized" - } - }, - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-06-01-preview", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "3106", + "Content-Length": "2874", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { "description": "Pipeline with command components", - "properties": { - "mlflow.source.git.repoURL": "https://github.com/needuv/azure-sdk-for-python.git", - "mlflow.source.git.branch": "needuv/add-live-tests", - "mlflow.source.git.commit": "1ddf1b357d82451d88b2d1af6b94eae789b30d6e", - "azureml.git.dirty": "True" - }, + "properties": {}, "tags": {}, "displayName": "pipeline_with_command_components", "experimentName": "v15_v2_interop", @@ -2163,8 +1398,7 @@ "write_tsv": { "environment": null, "limits": { - "job_limits_type": "Command", - "timeout": null + "job_limits_type": "Command" }, "resources": { "properties": {} @@ -2182,14 +1416,14 @@ } }, "outputs": {}, + "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0f70e41a-46c6-47e0-b737-42f3afd8bc9d" + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/98f24375-15da-4ba9-83c4-65d2d044081e" }, "copy_file": { "environment": null, "limits": { - "job_limits_type": "Command", - "timeout": null + "job_limits_type": "Command" }, "resources": { "properties": {} @@ -2212,14 +1446,14 @@ "job_output_type": "uri_folder" } }, + "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/9a9de9ec-0083-4031-ae54-5364f2c6f70a" + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/f9282ef9-604e-4109-8ea6-e565cc20d711" }, "ls_file": { "environment": null, "limits": { - "job_limits_type": "Command", - "timeout": null + "job_limits_type": "Command" }, "resources": { "properties": {} @@ -2233,11 +1467,12 @@ } }, "outputs": {}, + "properties": {}, "_source": "YAML.COMPONENT", "environment_variables": { "verbose": "DEBUG" }, - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/6e612aea-d513-45b8-bbd6-282848123ea6" + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/31415cc3-81dd-4085-8824-13f76ee1cbbb" } }, "outputs": {}, @@ -2249,22 +1484,22 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "5810", + "Content-Length": "5561", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:50 GMT", + "Date": "Mon, 10 Oct 2022 03:48:34 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-06-01-preview", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-c3f96010f1600a663c16dd77e401c8b2-363fd95d4a9790e3-01\u0022", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-2bf87c46c0e4f2497ef5229123f387b9-71013bda337512e1-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "6a46d604-27a1-4241-8f7f-5e0a753f7f3a", - "x-ms-ratelimit-remaining-subscription-writes": "1166", + "x-ms-correlation-request-id": "42e791c8-1f8d-4f46-91f1-c429b4a39068", + "x-ms-ratelimit-remaining-subscription-writes": "1124", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212750Z:6a46d604-27a1-4241-8f7f-5e0a753f7f3a", - "x-request-time": "2.499" + "x-ms-routing-request-id": "JAPANEAST:20221010T034834Z:42e791c8-1f8d-4f46-91f1-c429b4a39068", + "x-request-time": "9.505" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000", @@ -2274,10 +1509,6 @@ "description": "Pipeline with command components", "tags": {}, "properties": { - "mlflow.source.git.repoURL": "https://github.com/needuv/azure-sdk-for-python.git", - "mlflow.source.git.branch": "needuv/add-live-tests", - "mlflow.source.git.commit": "1ddf1b357d82451d88b2d1af6b94eae789b30d6e", - "azureml.git.dirty": "True", "azureml.DevPlatv2": "true", "azureml.runsource": "azureml.PipelineRun", "runSource": "MFE", @@ -2295,10 +1526,11 @@ "Tracking": { "jobServiceType": "Tracking", "port": null, - "endpoint": "azureml://eastus2euap.api.azureml.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", + "endpoint": "azureml://master.api.azureml-test.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", "status": null, "errorMessage": null, - "properties": null + "properties": null, + "nodes": null }, "Studio": { "jobServiceType": "Studio", @@ -2306,7 +1538,8 @@ "endpoint": "https://ml.azure.com/runs/000000000000000000000?wsid=/subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000", "status": null, "errorMessage": null, - "properties": null + "properties": null, + "nodes": null } }, "computeId": null, @@ -2321,8 +1554,7 @@ "write_tsv": { "environment": null, "limits": { - "job_limits_type": "Command", - "timeout": null + "job_limits_type": "Command" }, "resources": { "properties": {} @@ -2340,14 +1572,14 @@ } }, "outputs": {}, + "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0f70e41a-46c6-47e0-b737-42f3afd8bc9d" + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/98f24375-15da-4ba9-83c4-65d2d044081e" }, "copy_file": { "environment": null, "limits": { - "job_limits_type": "Command", - "timeout": null + "job_limits_type": "Command" }, "resources": { "properties": {} @@ -2370,14 +1602,14 @@ "job_output_type": "uri_folder" } }, + "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/9a9de9ec-0083-4031-ae54-5364f2c6f70a" + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/f9282ef9-604e-4109-8ea6-e565cc20d711" }, "ls_file": { "environment": null, "limits": { - "job_limits_type": "Command", - "timeout": null + "job_limits_type": "Command" }, "resources": { "properties": {} @@ -2391,11 +1623,12 @@ } }, "outputs": {}, + "properties": {}, "_source": "YAML.COMPONENT", "environment_variables": { "verbose": "DEBUG" }, - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/6e612aea-d513-45b8-bbd6-282848123ea6" + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/31415cc3-81dd-4085-8824-13f76ee1cbbb" } }, "inputs": { @@ -2414,21 +1647,21 @@ "sourceJobId": null }, "systemData": { - "createdAt": "2022-09-08T21:27:50.1988744\u002B00:00", - "createdBy": "5019366a-3f7a-4d18-adae-d2483c23e1ee", - "createdByType": "Application" + "createdAt": "2022-10-10T03:48:34.293254\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000/cancel?api-version=2022-06-01-preview", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000/cancel?api-version=2022-10-01-preview", "RequestMethod": "POST", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.0.139 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.6 (Windows-10-10.0.22000-SP0)" + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 202, @@ -2436,22 +1669,83 @@ "Cache-Control": "no-cache", "Content-Length": "4", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 08 Sep 2022 21:27:50 GMT", + "Date": "Mon, 10 Oct 2022 03:48:37 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/eastus2euap/mfeOperationResults/jc:cd46beb1-8b9b-4bdc-974f-092de17efdd8:000000000000000000000?api-version=2022-06-01-preview", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-test-westus2-01", "X-Content-Type-Options": "nosniff", "x-ms-async-operation-timeout": "PT1H", - "x-ms-correlation-request-id": "b560d3d8-90a6-4a2b-91d9-f359368d7171", - "x-ms-ratelimit-remaining-subscription-writes": "1178", + "x-ms-correlation-request-id": "a3983223-1423-4975-b9bf-178c55364425", + "x-ms-ratelimit-remaining-subscription-writes": "1156", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "CANADACENTRAL:20220908T212751Z:b560d3d8-90a6-4a2b-91d9-f359368d7171", - "x-request-time": "0.501" + "x-ms-routing-request-id": "JAPANEAST:20221010T034837Z:a3983223-1423-4975-b9bf-178c55364425", + "x-request-time": "0.678" }, "ResponseBody": "null" + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "*/*", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 202, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "2", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:48:37 GMT", + "Expires": "-1", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "28eeb183-c617-4c3f-9e85-905659cc170e", + "x-ms-ratelimit-remaining-subscription-reads": "11895", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034838Z:28eeb183-c617-4c3f-9e85-905659cc170e", + "x-request-time": "0.032" + }, + "ResponseBody": {} + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "*/*", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Mon, 10 Oct 2022 03:49:08 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-5f20e6a0af4ae78b9f67be4630bf6e91-4fe487ae18ba49d0-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "ffca7c8f-83f1-4e35-838f-1838ce9355d5", + "x-ms-ratelimit-remaining-subscription-reads": "11894", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034909Z:ffca7c8f-83f1-4e35-838f-1838ce9355d5", + "x-request-time": "0.054" + }, + "ResponseBody": null } ], "Variables": {} diff --git a/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_with_setting_node_output_mode.json b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_with_setting_node_output_mode.json new file mode 100644 index 000000000000..7e7e7673ae63 --- /dev/null +++ b/sdk/ml/azure-ai-ml/tests/recordings/internal/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_with_setting_node_output_mode.json @@ -0,0 +1,1860 @@ +{ + "Entries": [ + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore?api-version=2022-05-01", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:49:12 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-0ef112f2444c0559acc42f4822d6482d-ad0addf31e39e0a2-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "86fe7c72-3e92-4e9f-a29d-85983b776d22", + "x-ms-ratelimit-remaining-subscription-reads": "11893", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034913Z:86fe7c72-3e92-4e9f-a29d-85983b776d22", + "x-request-time": "0.099" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", + "name": "workspaceblobstore", + "type": "Microsoft.MachineLearningServices/workspaces/datastores", + "properties": { + "description": null, + "tags": null, + "properties": null, + "isDefault": true, + "credentials": { + "credentialsType": "AccountKey" + }, + "datastoreType": "AzureBlob", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "endpoint": "core.windows.net", + "protocol": "https", + "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" + }, + "systemData": { + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "createdByType": "Application", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "lastModifiedByType": "Application" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore/listSecrets?api-version=2022-05-01", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:49:12 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-02204212953834ff7299573a8185bd98-c6282397dba7fa60-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "596b1d3e-637f-4c7b-9dfc-9b84800cab3b", + "x-ms-ratelimit-remaining-subscription-writes": "1155", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034913Z:596b1d3e-637f-4c7b-9dfc-9b84800cab3b", + "x-request-time": "0.131" + }, + "ResponseBody": { + "secretsType": "AccountKey", + "key": "dGhpcyBpcyBmYWtlIGtleQ==" + } + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/get_started_train_score_eval/eval.py", + "RequestMethod": "HEAD", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:49:13 GMT", + "x-ms-version": "2021-08-06" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Date": "Mon, 10 Oct 2022 03:49:13 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "Transfer-Encoding": "chunked", + "Vary": "Origin", + "x-ms-error-code": "BlobNotFound", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/get_started_train_score_eval/score.py", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "874", + "Content-MD5": "uYOtVexN2Vq8JencBZ8KgA==", + "Content-Type": "application/octet-stream", + "If-None-Match": "*", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-blob-type": "BlockBlob", + "x-ms-date": "Mon, 10 Oct 2022 03:49:14 GMT", + "x-ms-version": "2021-08-06" + }, + "RequestBody": "aW1wb3J0IGFyZ3BhcnNlDQpmcm9tIHBhdGhsaWIgaW1wb3J0IFBhdGgNCg0KcGFyc2VyID0gYXJncGFyc2UuQXJndW1lbnRQYXJzZXIoInNjb3JlIikNCnBhcnNlci5hZGRfYXJndW1lbnQoIi0tbW9kZWxfaW5wdXQiLCB0eXBlPXN0ciwgaGVscD0iUGF0aCBvZiBpbnB1dCBtb2RlbCIpDQpwYXJzZXIuYWRkX2FyZ3VtZW50KCItLXRlc3RfZGF0YSIsIHR5cGU9c3RyLCBoZWxwPSJQYXRoIHRvIHRlc3QgZGF0YSIpDQpwYXJzZXIuYWRkX2FyZ3VtZW50KCItLXNjb3JlX291dHB1dCIsIHR5cGU9c3RyLCBoZWxwPSJQYXRoIG9mIHNjb3Jpbmcgb3V0cHV0IikNCg0KYXJncyA9IHBhcnNlci5wYXJzZV9hcmdzKCkNCg0KbGluZXMgPSBbDQogICAgZiJNb2RlbCBwYXRoOiB7YXJncy5tb2RlbF9pbnB1dH0iLA0KICAgIGYiVGVzdCBkYXRhIHBhdGg6IHthcmdzLnRlc3RfZGF0YX0iLA0KICAgIGYiU2NvcmluZyBvdXRwdXQgcGF0aDoge2FyZ3Muc2NvcmVfb3V0cHV0fSIsDQpdDQoNCmZvciBsaW5lIGluIGxpbmVzOg0KICAgIHByaW50KGxpbmUpDQoNCiMgTG9hZCB0aGUgbW9kZWwgZnJvbSBpbnB1dCBwb3J0DQojIEhlcmUgb25seSBwcmludCB0aGUgbW9kZWwgYXMgdGV4dCBzaW5jZSBpdCBpcyBhIGR1bW15IG9uZQ0KbW9kZWwgPSAoUGF0aChhcmdzLm1vZGVsX2lucHV0KSAvICJtb2RlbCIpLnJlYWRfdGV4dCgpDQpwcmludCgiTW9kZWw6IiwgbW9kZWwpDQoNCiMgRG8gc2NvcmluZyB3aXRoIHRoZSBpbnB1dCBtb2RlbA0KIyBIZXJlIG9ubHkgcHJpbnQgdGV4dCB0byBvdXRwdXQgZmlsZSBhcyBkZW1vDQooUGF0aChhcmdzLnNjb3JlX291dHB1dCkgLyAic2NvcmUiKS53cml0ZV90ZXh0KCJzY29yZWQgd2l0aCB7fSIuZm9ybWF0KG1vZGVsKSkNCg==", + "StatusCode": 201, + "ResponseHeaders": { + "Content-Length": "0", + "Content-MD5": "uYOtVexN2Vq8JencBZ8KgA==", + "Date": "Mon, 10 Oct 2022 03:49:14 GMT", + "ETag": "\u00220x8DAAA72660F13AB\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:49:14 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "x-ms-content-crc64": "m7be2v/6TI4=", + "x-ms-request-server-encrypted": "true", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/get_started_train_score_eval/eval.yaml", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "1162", + "Content-MD5": "F57tUBtQHTUSM\u002B1jl5uDkA==", + "Content-Type": "application/octet-stream", + "If-None-Match": "*", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-blob-type": "BlockBlob", + "x-ms-date": "Mon, 10 Oct 2022 03:49:14 GMT", + "x-ms-version": "2021-08-06" + }, + "RequestBody": "IyBDb3B5cmlnaHQgKGMpIE1pY3Jvc29mdCBDb3Jwb3JhdGlvbi4NCiMgTGljZW5zZWQgdW5kZXIgdGhlIE1JVCBMaWNlbnNlLg0KDQokc2NoZW1hOiBodHRwczovL2NvbXBvbmVudHNkay5henVyZWVkZ2UubmV0L2pzb25zY2hlbWEvQ29tbWFuZENvbXBvbmVudC5qc29uDQpuYW1lOiBzYW1wbGVzX2V2YWx1YXRlDQp2ZXJzaW9uOiAwLjAuNQ0KZGlzcGxheV9uYW1lOiBFdmFsdWF0ZQ0KdHlwZTogQ29tbWFuZENvbXBvbmVudA0KZGVzY3JpcHRpb246IEEgZHVtbXkgZXZhbHVhdGUgbW9kdWxlDQp0YWdzOiB7fQ0KaW5wdXRzOg0KICBzY29yaW5nX3Jlc3VsdDoNCiAgICB0eXBlOiBwYXRoDQogICAgZGVzY3JpcHRpb246IFNjb3JpbmcgcmVzdWx0IGZpbGUgaW4gVFNWIGZvcm1hdA0KICAgIG9wdGlvbmFsOiBmYWxzZQ0Kb3V0cHV0czoNCiAgZXZhbF9vdXRwdXQ6DQogICAgdHlwZTogcGF0aA0KICAgIGRlc2NyaXB0aW9uOiBFdmFsdWF0aW9uIHJlc3VsdA0KY29tbWFuZDogPi0NCiAgcHl0aG9uIGV2YWwucHkgLS1zY29yaW5nX3Jlc3VsdCB7aW5wdXRzLnNjb3JpbmdfcmVzdWx0fSAtLWV2YWxfb3V0cHV0IHtvdXRwdXRzLmV2YWxfb3V0cHV0fQ0KZW52aXJvbm1lbnQ6DQogIGRvY2tlcjoNCiAgICBpbWFnZTogbWNyLm1pY3Jvc29mdC5jb20vYXp1cmVtbC9vcGVubXBpMy4xLjItdWJ1bnR1MTguMDQ6MjAyMjA3MTQudjENCiAgY29uZGE6DQogICAgY29uZGFfZGVwZW5kZW5jaWVzOg0KICAgICAgbmFtZTogcHJvamVjdF9lbnZpcm9ubWVudA0KICAgICAgY2hhbm5lbHM6DQogICAgICAtIGNvbmRhLWZvcmdlDQogICAgICBkZXBlbmRlbmNpZXM6DQogICAgICAtIHBpcD0yMC4yDQogICAgICAtIHB5dGhvbj0zLjcuOQ0KICAgICAgLSBzY2lraXQtc3VycHJpc2U9MS4wLjYNCiAgICAgIC0gcGlwOg0KICAgICAgICAtIHdhaXRyZXNzPT0yLjAuMA0KICAgICAgICAtIGF6dXJlbWwtZGVzaWduZXItY2xhc3NpYy1tb2R1bGVzPT0wLjAuMTYxDQogICAgICAgIC0gaHR0cHM6Ly9naXRodWIuY29tL2V4cGxvc2lvbi9zcGFjeS1tb2RlbHMvcmVsZWFzZXMvZG93bmxvYWQvZW5fY29yZV93ZWJfc20tMi4xLjAvZW5fY29yZV93ZWJfc20tMi4xLjAudGFyLmd6I2VnZz1lbl9jb3JlX3dlYl9zbQ0KICAgICAgICAtIHNwYWN5PT0yLjEuNw0KICBvczogTGludXgNCg==", + "StatusCode": 201, + "ResponseHeaders": { + "Content-Length": "0", + "Content-MD5": "F57tUBtQHTUSM\u002B1jl5uDkA==", + "Date": "Mon, 10 Oct 2022 03:49:14 GMT", + "ETag": "\u00220x8DAAA72662BBF35\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:49:14 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "x-ms-content-crc64": "w/rVLLusT7o=", + "x-ms-request-server-encrypted": "true", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/get_started_train_score_eval/train.py", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "898", + "Content-MD5": "4m2M6BmO0mIIYqX9qFFt5Q==", + "Content-Type": "application/octet-stream", + "If-None-Match": "*", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-blob-type": "BlockBlob", + "x-ms-date": "Mon, 10 Oct 2022 03:49:14 GMT", + "x-ms-version": "2021-08-06" + }, + "RequestBody": "aW1wb3J0IGFyZ3BhcnNlDQpmcm9tIHBhdGhsaWIgaW1wb3J0IFBhdGgNCmZyb20gdXVpZCBpbXBvcnQgdXVpZDQNCg0KcGFyc2VyID0gYXJncGFyc2UuQXJndW1lbnRQYXJzZXIoInRyYWluIikNCnBhcnNlci5hZGRfYXJndW1lbnQoIi0tdHJhaW5pbmdfZGF0YSIsIHR5cGU9c3RyLCBoZWxwPSJQYXRoIHRvIHRyYWluaW5nIGRhdGEiKQ0KcGFyc2VyLmFkZF9hcmd1bWVudCgiLS1tYXhfZXBvY2hzIiwgdHlwZT1pbnQsIGhlbHA9Ik1heCAjIG9mIGVwb2NocyBmb3IgdGhlIHRyYWluaW5nIikNCnBhcnNlci5hZGRfYXJndW1lbnQoIi0tbGVhcm5pbmdfcmF0ZSIsIHR5cGU9ZmxvYXQsIGhlbHA9IkxlYXJuaW5nIHJhdGUiKQ0KcGFyc2VyLmFkZF9hcmd1bWVudCgiLS1tb2RlbF9vdXRwdXQiLCB0eXBlPXN0ciwgaGVscD0iUGF0aCBvZiBvdXRwdXQgbW9kZWwiKQ0KDQphcmdzID0gcGFyc2VyLnBhcnNlX2FyZ3MoKQ0KDQpsaW5lcyA9IFsNCiAgICBmIlRyYWluaW5nIGRhdGEgcGF0aDoge2FyZ3MudHJhaW5pbmdfZGF0YX0iLA0KICAgIGYiTWF4IGVwb2Noczoge2FyZ3MubWF4X2Vwb2Noc30iLA0KICAgIGYiTGVhcm5pbmcgcmF0ZToge2FyZ3MubGVhcm5pbmdfcmF0ZX0iLA0KICAgIGYiTW9kZWwgb3V0cHV0IHBhdGg6IHthcmdzLm1vZGVsX291dHB1dH0iLA0KXQ0KDQpmb3IgbGluZSBpbiBsaW5lczoNCiAgICBwcmludChsaW5lKQ0KDQojIERvIHRoZSB0cmFpbiBhbmQgc2F2ZSB0aGUgdHJhaW5lZCBtb2RlbCBhcyBhIGZpbGUgaW50byB0aGUgb3V0cHV0IGZvbGRlci4NCiMgSGVyZSBvbmx5IG91dHB1dCBhIGR1bW15IGRhdGEgZm9yIGRlbW8uDQptb2RlbCA9IHN0cih1dWlkNCgpKQ0KKFBhdGgoYXJncy5tb2RlbF9vdXRwdXQpIC8gIm1vZGVsIikud3JpdGVfdGV4dChtb2RlbCkNCg==", + "StatusCode": 201, + "ResponseHeaders": { + "Content-Length": "0", + "Content-MD5": "4m2M6BmO0mIIYqX9qFFt5Q==", + "Date": "Mon, 10 Oct 2022 03:49:14 GMT", + "ETag": "\u00220x8DAAA72664843B8\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:49:14 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "x-ms-content-crc64": "/j4FUT1m/2o=", + "x-ms-request-server-encrypted": "true", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/get_started_train_score_eval/score.yaml", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "1368", + "Content-MD5": "yGCzdeY/livCd15Izk36Yw==", + "Content-Type": "application/octet-stream", + "If-None-Match": "*", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-blob-type": "BlockBlob", + "x-ms-date": "Mon, 10 Oct 2022 03:49:14 GMT", + "x-ms-version": "2021-08-06" + }, + "RequestBody": "IyBDb3B5cmlnaHQgKGMpIE1pY3Jvc29mdCBDb3Jwb3JhdGlvbi4NCiMgTGljZW5zZWQgdW5kZXIgdGhlIE1JVCBMaWNlbnNlLg0KDQokc2NoZW1hOiBodHRwczovL2NvbXBvbmVudHNkay5henVyZWVkZ2UubmV0L2pzb25zY2hlbWEvQ29tbWFuZENvbXBvbmVudC5qc29uDQpuYW1lOiBzYW1wbGVzX3Njb3JlDQp2ZXJzaW9uOiAwLjAuNA0KZGlzcGxheV9uYW1lOiBTY29yZQ0KdHlwZTogQ29tbWFuZENvbXBvbmVudA0KZGVzY3JpcHRpb246IEEgZHVtbXkgc2NvcmluZyBtb2R1bGUNCnRhZ3M6DQogIGNhdGVnb3J5OiBDb21wb25lbnQgVHV0b3JpYWwNCiAgY29udGFjdDogYW1sZGVzaWduZXJAbWljcm9zb2Z0LmNvbQ0KaW5wdXRzOg0KICBtb2RlbF9pbnB1dDoNCiAgICB0eXBlOiBwYXRoDQogICAgZGVzY3JpcHRpb246IFppcHBlZCBtb2RlbCBmaWxlDQogICAgb3B0aW9uYWw6IGZhbHNlDQogIHRlc3RfZGF0YToNCiAgICB0eXBlOiBwYXRoDQogICAgZGVzY3JpcHRpb246IFRlc3QgZGF0YSBvcmdhbml6ZWQgaW4gdGhlIHRvcmNodmlzaW9uIGZvcm1hdC9zdHJ1Y3R1cmUNCiAgICBvcHRpb25hbDogZmFsc2UNCm91dHB1dHM6DQogIHNjb3JlX291dHB1dDoNCiAgICB0eXBlOiBwYXRoDQogICAgZGVzY3JpcHRpb246IFRoZSBzY29yaW5nIHJlc3VsdCBpbiBUU1YNCmNvbW1hbmQ6ID4tDQogIHB5dGhvbiBzY29yZS5weSAtLW1vZGVsX2lucHV0IHtpbnB1dHMubW9kZWxfaW5wdXR9IC0tdGVzdF9kYXRhIHtpbnB1dHMudGVzdF9kYXRhfQ0KICAtLXNjb3JlX291dHB1dCB7b3V0cHV0cy5zY29yZV9vdXRwdXR9DQplbnZpcm9ubWVudDoNCiAgZG9ja2VyOg0KICAgIGltYWdlOiBtY3IubWljcm9zb2Z0LmNvbS9henVyZW1sL29wZW5tcGkzLjEuMi11YnVudHUxOC4wNDoyMDIyMDcxNC52MQ0KICBjb25kYToNCiAgICBjb25kYV9kZXBlbmRlbmNpZXM6DQogICAgICBuYW1lOiBwcm9qZWN0X2Vudmlyb25tZW50DQogICAgICBjaGFubmVsczoNCiAgICAgIC0gY29uZGEtZm9yZ2UNCiAgICAgIGRlcGVuZGVuY2llczoNCiAgICAgIC0gcGlwPTIwLjINCiAgICAgIC0gcHl0aG9uPTMuNy45DQogICAgICAtIHNjaWtpdC1zdXJwcmlzZT0xLjAuNg0KICAgICAgLSBwaXA6DQogICAgICAgIC0gd2FpdHJlc3M9PTIuMC4wDQogICAgICAgIC0gYXp1cmVtbC1kZXNpZ25lci1jbGFzc2ljLW1vZHVsZXM9PTAuMC4xNjENCiAgICAgICAgLSBodHRwczovL2dpdGh1Yi5jb20vZXhwbG9zaW9uL3NwYWN5LW1vZGVscy9yZWxlYXNlcy9kb3dubG9hZC9lbl9jb3JlX3dlYl9zbS0yLjEuMC9lbl9jb3JlX3dlYl9zbS0yLjEuMC50YXIuZ3ojZWdnPWVuX2NvcmVfd2ViX3NtDQogICAgICAgIC0gc3BhY3k9PTIuMS43DQogIG9zOiBMaW51eA0K", + "StatusCode": 201, + "ResponseHeaders": { + "Content-Length": "0", + "Content-MD5": "yGCzdeY/livCd15Izk36Yw==", + "Date": "Mon, 10 Oct 2022 03:49:14 GMT", + "ETag": "\u00220x8DAAA7266656465\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:49:14 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "x-ms-content-crc64": "Rv5fFG6v3ww=", + "x-ms-request-server-encrypted": "true", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/get_started_train_score_eval/train.yaml", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "1560", + "Content-MD5": "Z2w3miW4esPqTv8xbxjPJg==", + "Content-Type": "application/octet-stream", + "If-None-Match": "*", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-blob-type": "BlockBlob", + "x-ms-date": "Mon, 10 Oct 2022 03:49:14 GMT", + "x-ms-version": "2021-08-06" + }, + "RequestBody": "IyBDb3B5cmlnaHQgKGMpIE1pY3Jvc29mdCBDb3Jwb3JhdGlvbi4NCiMgTGljZW5zZWQgdW5kZXIgdGhlIE1JVCBMaWNlbnNlLg0KDQokc2NoZW1hOiBodHRwczovL2NvbXBvbmVudHNkay5henVyZWVkZ2UubmV0L2pzb25zY2hlbWEvQ29tbWFuZENvbXBvbmVudC5qc29uDQpuYW1lOiBzYW1wbGVzX3RyYWluDQp2ZXJzaW9uOiAwLjAuNQ0KZGlzcGxheV9uYW1lOiBUcmFpbg0KdHlwZTogQ29tbWFuZENvbXBvbmVudA0KZGVzY3JpcHRpb246IEEgZHVtbXkgdHJhaW5pbmcgbW9kdWxlDQp0YWdzOiB7Y2F0ZWdvcnk6IENvbXBvbmVudCBUdXRvcmlhbCwgY29udGFjdDogYW1sZGVzaWduZXJAbWljcm9zb2Z0LmNvbX0NCmlucHV0czoNCiAgdHJhaW5pbmdfZGF0YToNCiAgICB0eXBlOiBwYXRoDQogICAgZGVzY3JpcHRpb246IFRyYWluaW5nIGRhdGEgb3JnYW5pemVkIGluIHRoZSB0b3JjaHZpc2lvbiBmb3JtYXQvc3RydWN0dXJlDQogICAgb3B0aW9uYWw6IGZhbHNlDQogIG1heF9lcG9jaHM6DQogICAgdHlwZTogaW50ZWdlcg0KICAgIGRlc2NyaXB0aW9uOiBNYXhpbXVtIG51bWJlciBvZiBlcG9jaHMgZm9yIHRoZSB0cmFpbmluZw0KICAgIG9wdGlvbmFsOiBmYWxzZQ0KICBsZWFybmluZ19yYXRlOg0KICAgIHR5cGU6IGZsb2F0DQogICAgZGVzY3JpcHRpb246IExlYXJuaW5nIHJhdGUsIGRlZmF1bHQgaXMgMC4wMQ0KICAgIGRlZmF1bHQ6IDAuMDENCiAgICBvcHRpb25hbDogZmFsc2UNCm91dHB1dHM6DQogIG1vZGVsX291dHB1dDoNCiAgICB0eXBlOiBwYXRoDQogICAgZGVzY3JpcHRpb246IFRoZSBvdXRwdXQgbW9kZWwNCmNvbW1hbmQ6ID4tDQogIHB5dGhvbiB0cmFpbi5weSAtLXRyYWluaW5nX2RhdGEge2lucHV0cy50cmFpbmluZ19kYXRhfSAtLW1heF9lcG9jaHMge2lucHV0cy5tYXhfZXBvY2hzfQ0KICAtLWxlYXJuaW5nX3JhdGUge2lucHV0cy5sZWFybmluZ19yYXRlfSAtLW1vZGVsX291dHB1dCB7b3V0cHV0cy5tb2RlbF9vdXRwdXR9DQplbnZpcm9ubWVudDoNCiAgZG9ja2VyOg0KICAgIGltYWdlOiBtY3IubWljcm9zb2Z0LmNvbS9henVyZW1sL29wZW5tcGkzLjEuMi11YnVudHUxOC4wNDoyMDIyMDcxNC52MQ0KICBjb25kYToNCiAgICBjb25kYV9kZXBlbmRlbmNpZXM6DQogICAgICBuYW1lOiBwcm9qZWN0X2Vudmlyb25tZW50DQogICAgICBjaGFubmVsczoNCiAgICAgIC0gY29uZGEtZm9yZ2UNCiAgICAgIGRlcGVuZGVuY2llczoNCiAgICAgIC0gcGlwPTIwLjINCiAgICAgIC0gcHl0aG9uPTMuNy45DQogICAgICAtIHNjaWtpdC1zdXJwcmlzZT0xLjAuNg0KICAgICAgLSBwaXA6DQogICAgICAgIC0gd2FpdHJlc3M9PTIuMC4wDQogICAgICAgIC0gYXp1cmVtbC1kZXNpZ25lci1jbGFzc2ljLW1vZHVsZXM9PTAuMC4xNjENCiAgICAgICAgLSBodHRwczovL2dpdGh1Yi5jb20vZXhwbG9zaW9uL3NwYWN5LW1vZGVscy9yZWxlYXNlcy9kb3dubG9hZC9lbl9jb3JlX3dlYl9zbS0yLjEuMC9lbl9jb3JlX3dlYl9zbS0yLjEuMC50YXIuZ3ojZWdnPWVuX2NvcmVfd2ViX3NtDQogICAgICAgIC0gc3BhY3k9PTIuMS43DQogIG9zOiBMaW51eA0K", + "StatusCode": 201, + "ResponseHeaders": { + "Content-Length": "0", + "Content-MD5": "Z2w3miW4esPqTv8xbxjPJg==", + "Date": "Mon, 10 Oct 2022 03:49:14 GMT", + "ETag": "\u00220x8DAAA726681C1E4\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:49:14 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "x-ms-content-crc64": "WjhTc3b6zkY=", + "x-ms-request-server-encrypted": "true", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/get_started_train_score_eval/eval.py", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "631", + "Content-MD5": "/02Z/06rW8eIP\u002BVAq4ZOig==", + "Content-Type": "application/octet-stream", + "If-None-Match": "*", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-blob-type": "BlockBlob", + "x-ms-date": "Mon, 10 Oct 2022 03:49:14 GMT", + "x-ms-version": "2021-08-06" + }, + "RequestBody": "aW1wb3J0IGFyZ3BhcnNlDQpmcm9tIHBhdGhsaWIgaW1wb3J0IFBhdGgNCg0KcGFyc2VyID0gYXJncGFyc2UuQXJndW1lbnRQYXJzZXIoInNjb3JlIikNCnBhcnNlci5hZGRfYXJndW1lbnQoIi0tc2NvcmluZ19yZXN1bHQiLCB0eXBlPXN0ciwgaGVscD0iUGF0aCBvZiBzY29yaW5nIHJlc3VsdCIpDQpwYXJzZXIuYWRkX2FyZ3VtZW50KCItLWV2YWxfb3V0cHV0IiwgdHlwZT1zdHIsIGhlbHA9IlBhdGggb2Ygb3V0cHV0IGV2YWx1YXRpb24gcmVzdWx0IikNCg0KYXJncyA9IHBhcnNlci5wYXJzZV9hcmdzKCkNCg0KbGluZXMgPSBbDQogICAgZiJTY29yaW5nIHJlc3VsdCBwYXRoOiB7YXJncy5zY29yaW5nX3Jlc3VsdH0iLA0KICAgIGYiRXZhbHVhdGlvbiBvdXRwdXQgcGF0aDoge2FyZ3MuZXZhbF9vdXRwdXR9IiwNCl0NCg0KZm9yIGxpbmUgaW4gbGluZXM6DQogICAgcHJpbnQobGluZSkNCg0KIyBFdmFsdWF0ZSB0aGUgaW5jb21pbmcgc2NvcmluZyByZXN1bHQgYW5kIG91dHB1dCBldmFsdWF0aW9uIHJlc3VsdC4NCiMgSGVyZSBvbmx5IG91dHB1dCBhIGR1bW15IGZpbGUgZm9yIGRlbW8uDQooUGF0aChhcmdzLmV2YWxfb3V0cHV0KSAvICJldmFsX3Jlc3VsdCIpLndyaXRlX3RleHQoImV2YWxfcmVzdWx0IikNCg==", + "StatusCode": 201, + "ResponseHeaders": { + "Content-Length": "0", + "Content-MD5": "/02Z/06rW8eIP\u002BVAq4ZOig==", + "Date": "Mon, 10 Oct 2022 03:49:14 GMT", + "ETag": "\u00220x8DAAA72669065BC\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:49:15 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "x-ms-content-crc64": "fg2Vbcn6t2o=", + "x-ms-request-server-encrypted": "true", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/get_started_train_score_eval/eval.py?comp=metadata", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:49:15 GMT", + "x-ms-meta-name": "000000000000000000000", + "x-ms-meta-upload_status": "completed", + "x-ms-meta-version": "1", + "x-ms-version": "2021-08-06" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Content-Length": "0", + "Date": "Mon, 10 Oct 2022 03:49:14 GMT", + "ETag": "\u00220x8DAAA7266AE4999\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:49:15 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "x-ms-request-server-encrypted": "true", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1?api-version=2022-05-01", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "317", + "Content-Type": "application/json", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": { + "properties": { + "properties": { + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" + }, + "isAnonymous": true, + "isArchived": false, + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/get_started_train_score_eval" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "832", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:49:15 GMT", + "Expires": "-1", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1?api-version=2022-05-01", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-64963a7b21caeacf8d43e7f977caa7e2-17dd68dabe7a3489-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "fe81ff76-2fe5-4cc2-9345-97e6eba32ae8", + "x-ms-ratelimit-remaining-subscription-writes": "1123", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034916Z:fe81ff76-2fe5-4cc2-9345-97e6eba32ae8", + "x-request-time": "0.651" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1", + "name": "1", + "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", + "properties": { + "description": null, + "tags": {}, + "properties": { + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" + }, + "isArchived": false, + "isAnonymous": false, + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/get_started_train_score_eval" + }, + "systemData": { + "createdAt": "2022-10-10T03:49:16.1243019\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:49:16.1243019\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "1826", + "Content-Type": "application/json", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": { + "properties": { + "description": "A dummy training module", + "properties": {}, + "tags": { + "category": "Component Tutorial", + "contact": "amldesigner@microsoft.com" + }, + "isAnonymous": true, + "isArchived": false, + "componentSpec": { + "name": "azureml_anonymous", + "description": "A dummy training module", + "tags": { + "category": "Component Tutorial", + "contact": "amldesigner@microsoft.com" + }, + "version": "000000000000000000000", + "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", + "display_name": "Train", + "inputs": { + "training_data": { + "type": "path", + "description": "Training data organized in the torchvision format/structure" + }, + "max_epochs": { + "type": "integer", + "description": "Maximum number of epochs for the training" + }, + "learning_rate": { + "type": "float", + "default": 0.01, + "description": "Learning rate, default is 0.01" + } + }, + "outputs": { + "model_output": { + "type": "path", + "description": "The output model" + } + }, + "type": "CommandComponent", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1", + "environment": { + "docker": { + "image": "mcr.microsoft.com/azureml/openmpi3.1.2-ubuntu18.04:20220714.v1" + }, + "conda": { + "conda_dependencies": { + "name": "project_environment", + "channels": [ + "conda-forge" + ], + "dependencies": [ + "pip=20.2", + "python=3.7.9", + "scikit-surprise=1.0.6", + { + "pip": [ + "waitress==2.0.0", + "azureml-designer-classic-modules==0.0.161", + "https://github.com/explosion/spacy-models/releases/download/en_core_web_sm-2.1.0/en_core_web_sm-2.1.0.tar.gz#egg=en_core_web_sm", + "spacy==2.1.7" + ] + } + ] + } + }, + "os": "Linux" + }, + "command": "python train.py --training_data {inputs.training_data} --max_epochs {inputs.max_epochs} --learning_rate {inputs.learning_rate} --model_output {outputs.model_output}" + } + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "3348", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:49:17 GMT", + "Expires": "-1", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-12e1437f99d698e0cd6e51588db33c45-e659be6df2e92b0f-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "1cb5d1e9-c274-418f-9f92-9f8fcd32fee8", + "x-ms-ratelimit-remaining-subscription-writes": "1122", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034918Z:1cb5d1e9-c274-418f-9f92-9f8fcd32fee8", + "x-request-time": "1.221" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/ddbb8e79-6e6e-4b82-9bb0-7b784431f766", + "name": "ddbb8e79-6e6e-4b82-9bb0-7b784431f766", + "type": "Microsoft.MachineLearningServices/workspaces/components/versions", + "properties": { + "description": null, + "tags": { + "category": "Component Tutorial", + "contact": "amldesigner@microsoft.com" + }, + "properties": {}, + "isArchived": false, + "isAnonymous": true, + "componentSpec": { + "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", + "name": "azureml_anonymous", + "version": "ddbb8e79-6e6e-4b82-9bb0-7b784431f766", + "display_name": "Train", + "is_deterministic": "True", + "type": "CommandComponent", + "description": "A dummy training module", + "tags": { + "category": "Component Tutorial", + "contact": "amldesigner@microsoft.com" + }, + "inputs": { + "training_data": { + "type": "path", + "optional": "False", + "description": "Training data organized in the torchvision format/structure", + "datastore_mode": "Mount" + }, + "max_epochs": { + "type": "Integer", + "optional": "False", + "description": "Maximum number of epochs for the training" + }, + "learning_rate": { + "type": "Float", + "optional": "False", + "default": "0.01", + "description": "Learning rate, default is 0.01" + } + }, + "outputs": { + "model_output": { + "type": "path", + "description": "The output model", + "datastore_mode": "Upload" + } + }, + "environment": { + "conda": { + "conda_dependencies": { + "name": "project_environment", + "channels": [ + "conda-forge" + ], + "dependencies": [ + "pip=20.2", + "python=3.7.9", + "scikit-surprise=1.0.6", + { + "pip": [ + "waitress==2.0.0", + "azureml-designer-classic-modules==0.0.161", + "https://github.com/explosion/spacy-models/releases/download/en_core_web_sm-2.1.0/en_core_web_sm-2.1.0.tar.gz#egg=en_core_web_sm", + "spacy==2.1.7" + ] + } + ] + } + }, + "docker": { + "image": "mcr.microsoft.com/azureml/openmpi3.1.2-ubuntu18.04:20220714.v1" + }, + "os": "Linux" + }, + "successful_return_code": "Zero", + "command": "python train.py --training_data {inputs.training_data} --max_epochs {inputs.max_epochs} --learning_rate {inputs.learning_rate} --model_output {outputs.model_output}", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1" + } + }, + "systemData": { + "createdAt": "2022-10-10T03:49:17.453798\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:49:17.453798\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore?api-version=2022-05-01", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:49:17 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-eaa768d57c202cc7a116583ff5657bdf-6c19286c06f0282f-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "3738b160-1b40-4ecb-bed2-33103468d151", + "x-ms-ratelimit-remaining-subscription-reads": "11892", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034918Z:3738b160-1b40-4ecb-bed2-33103468d151", + "x-request-time": "0.098" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", + "name": "workspaceblobstore", + "type": "Microsoft.MachineLearningServices/workspaces/datastores", + "properties": { + "description": null, + "tags": null, + "properties": null, + "isDefault": true, + "credentials": { + "credentialsType": "AccountKey" + }, + "datastoreType": "AzureBlob", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "endpoint": "core.windows.net", + "protocol": "https", + "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" + }, + "systemData": { + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "createdByType": "Application", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "lastModifiedByType": "Application" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore/listSecrets?api-version=2022-05-01", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:49:18 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-c591f41dfbcc778ede847b2295d42f54-94b2794bcbf37672-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "e23ce6db-b3db-4348-994a-7eead0a770ca", + "x-ms-ratelimit-remaining-subscription-writes": "1154", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034919Z:e23ce6db-b3db-4348-994a-7eead0a770ca", + "x-request-time": "0.111" + }, + "ResponseBody": { + "secretsType": "AccountKey", + "key": "dGhpcyBpcyBmYWtlIGtleQ==" + } + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/get_started_train_score_eval/eval.py", + "RequestMethod": "HEAD", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:49:19 GMT", + "x-ms-version": "2021-08-06" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Accept-Ranges": "bytes", + "Content-Length": "631", + "Content-MD5": "/02Z/06rW8eIP\u002BVAq4ZOig==", + "Content-Type": "application/octet-stream", + "Date": "Mon, 10 Oct 2022 03:49:18 GMT", + "ETag": "\u00220x8DAAA7266AE4999\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:49:15 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "Vary": "Origin", + "x-ms-access-tier": "Hot", + "x-ms-access-tier-inferred": "true", + "x-ms-blob-type": "BlockBlob", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:49:15 GMT", + "x-ms-lease-state": "available", + "x-ms-lease-status": "unlocked", + "x-ms-meta-name": "000000000000000000000", + "x-ms-meta-upload_status": "completed", + "x-ms-meta-version": "1", + "x-ms-server-encrypted": "true", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/get_started_train_score_eval/eval.py", + "RequestMethod": "HEAD", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:49:19 GMT", + "x-ms-version": "2021-08-06" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Date": "Mon, 10 Oct 2022 03:49:19 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "Transfer-Encoding": "chunked", + "Vary": "Origin", + "x-ms-error-code": "BlobNotFound", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1?api-version=2022-05-01", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "317", + "Content-Type": "application/json", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": { + "properties": { + "properties": { + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" + }, + "isAnonymous": true, + "isArchived": false, + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/get_started_train_score_eval" + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:49:19 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-1cbc8fb828d863c1ec6c3e1685d057bf-ede4b4a71ddacfff-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "cf29f8a6-de40-4a14-8d4b-c2ea4573ee68", + "x-ms-ratelimit-remaining-subscription-writes": "1121", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034920Z:cf29f8a6-de40-4a14-8d4b-c2ea4573ee68", + "x-request-time": "0.234" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1", + "name": "1", + "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", + "properties": { + "description": null, + "tags": {}, + "properties": { + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" + }, + "isArchived": false, + "isAnonymous": false, + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/get_started_train_score_eval" + }, + "systemData": { + "createdAt": "2022-10-10T03:49:16.1243019\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:49:20.3001015\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "1652", + "Content-Type": "application/json", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": { + "properties": { + "description": "A dummy scoring module", + "properties": {}, + "tags": { + "category": "Component Tutorial", + "contact": "amldesigner@microsoft.com" + }, + "isAnonymous": true, + "isArchived": false, + "componentSpec": { + "name": "azureml_anonymous", + "description": "A dummy scoring module", + "tags": { + "category": "Component Tutorial", + "contact": "amldesigner@microsoft.com" + }, + "version": "000000000000000000000", + "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", + "display_name": "Score", + "inputs": { + "model_input": { + "type": "path", + "description": "Zipped model file" + }, + "test_data": { + "type": "path", + "description": "Test data organized in the torchvision format/structure" + } + }, + "outputs": { + "score_output": { + "type": "path", + "description": "The scoring result in TSV" + } + }, + "type": "CommandComponent", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1", + "environment": { + "docker": { + "image": "mcr.microsoft.com/azureml/openmpi3.1.2-ubuntu18.04:20220714.v1" + }, + "conda": { + "conda_dependencies": { + "name": "project_environment", + "channels": [ + "conda-forge" + ], + "dependencies": [ + "pip=20.2", + "python=3.7.9", + "scikit-surprise=1.0.6", + { + "pip": [ + "waitress==2.0.0", + "azureml-designer-classic-modules==0.0.161", + "https://github.com/explosion/spacy-models/releases/download/en_core_web_sm-2.1.0/en_core_web_sm-2.1.0.tar.gz#egg=en_core_web_sm", + "spacy==2.1.7" + ] + } + ] + } + }, + "os": "Linux" + }, + "command": "python score.py --model_input {inputs.model_input} --test_data {inputs.test_data} --score_output {outputs.score_output}" + } + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "3133", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:49:21 GMT", + "Expires": "-1", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-daedcbcc1a93ca6f849c4c6a40152fc0-01955ccfee86e27e-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "616bc8c1-4191-402f-a779-316377019648", + "x-ms-ratelimit-remaining-subscription-writes": "1120", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034922Z:616bc8c1-4191-402f-a779-316377019648", + "x-request-time": "1.192" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/6f291e6e-393d-4a46-9f45-916fac695e0d", + "name": "6f291e6e-393d-4a46-9f45-916fac695e0d", + "type": "Microsoft.MachineLearningServices/workspaces/components/versions", + "properties": { + "description": null, + "tags": { + "category": "Component Tutorial", + "contact": "amldesigner@microsoft.com" + }, + "properties": {}, + "isArchived": false, + "isAnonymous": true, + "componentSpec": { + "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", + "name": "azureml_anonymous", + "version": "6f291e6e-393d-4a46-9f45-916fac695e0d", + "display_name": "Score", + "is_deterministic": "True", + "type": "CommandComponent", + "description": "A dummy scoring module", + "tags": { + "category": "Component Tutorial", + "contact": "amldesigner@microsoft.com" + }, + "inputs": { + "model_input": { + "type": "path", + "optional": "False", + "description": "Zipped model file", + "datastore_mode": "Mount" + }, + "test_data": { + "type": "path", + "optional": "False", + "description": "Test data organized in the torchvision format/structure", + "datastore_mode": "Mount" + } + }, + "outputs": { + "score_output": { + "type": "path", + "description": "The scoring result in TSV", + "datastore_mode": "Upload" + } + }, + "environment": { + "conda": { + "conda_dependencies": { + "name": "project_environment", + "channels": [ + "conda-forge" + ], + "dependencies": [ + "pip=20.2", + "python=3.7.9", + "scikit-surprise=1.0.6", + { + "pip": [ + "waitress==2.0.0", + "azureml-designer-classic-modules==0.0.161", + "https://github.com/explosion/spacy-models/releases/download/en_core_web_sm-2.1.0/en_core_web_sm-2.1.0.tar.gz#egg=en_core_web_sm", + "spacy==2.1.7" + ] + } + ] + } + }, + "docker": { + "image": "mcr.microsoft.com/azureml/openmpi3.1.2-ubuntu18.04:20220714.v1" + }, + "os": "Linux" + }, + "successful_return_code": "Zero", + "command": "python score.py --model_input {inputs.model_input} --test_data {inputs.test_data} --score_output {outputs.score_output}", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1" + } + }, + "systemData": { + "createdAt": "2022-10-10T03:49:21.4128497\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:49:21.4128497\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore?api-version=2022-05-01", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:49:22 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-ac55ddfa47d70879a03d53abd5688d6e-d8f8f2454a445243-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "e361a370-b337-4a11-8c02-5920d692fe4f", + "x-ms-ratelimit-remaining-subscription-reads": "11891", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034922Z:e361a370-b337-4a11-8c02-5920d692fe4f", + "x-request-time": "0.082" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", + "name": "workspaceblobstore", + "type": "Microsoft.MachineLearningServices/workspaces/datastores", + "properties": { + "description": null, + "tags": null, + "properties": null, + "isDefault": true, + "credentials": { + "credentialsType": "AccountKey" + }, + "datastoreType": "AzureBlob", + "accountName": "sagvgsoim6nmhbq", + "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "endpoint": "core.windows.net", + "protocol": "https", + "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" + }, + "systemData": { + "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "createdByType": "Application", + "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", + "lastModifiedByType": "Application" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore/listSecrets?api-version=2022-05-01", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:49:23 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-a70cbfee874756d9d05e1ef58a070adc-58fbb77e6ee4383c-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "27fb5b55-bc2d-4a2a-89f8-201d5591bc1d", + "x-ms-ratelimit-remaining-subscription-writes": "1153", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034923Z:27fb5b55-bc2d-4a2a-89f8-201d5591bc1d", + "x-request-time": "0.513" + }, + "ResponseBody": { + "secretsType": "AccountKey", + "key": "dGhpcyBpcyBmYWtlIGtleQ==" + } + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/get_started_train_score_eval/eval.py", + "RequestMethod": "HEAD", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:49:23 GMT", + "x-ms-version": "2021-08-06" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Accept-Ranges": "bytes", + "Content-Length": "631", + "Content-MD5": "/02Z/06rW8eIP\u002BVAq4ZOig==", + "Content-Type": "application/octet-stream", + "Date": "Mon, 10 Oct 2022 03:49:23 GMT", + "ETag": "\u00220x8DAAA7266AE4999\u0022", + "Last-Modified": "Mon, 10 Oct 2022 03:49:15 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "Vary": "Origin", + "x-ms-access-tier": "Hot", + "x-ms-access-tier-inferred": "true", + "x-ms-blob-type": "BlockBlob", + "x-ms-creation-time": "Mon, 10 Oct 2022 03:49:15 GMT", + "x-ms-lease-state": "available", + "x-ms-lease-status": "unlocked", + "x-ms-meta-name": "000000000000000000000", + "x-ms-meta-upload_status": "completed", + "x-ms-meta-version": "1", + "x-ms-server-encrypted": "true", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/get_started_train_score_eval/eval.py", + "RequestMethod": "HEAD", + "RequestHeaders": { + "Accept": "application/xml", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Mon, 10 Oct 2022 03:49:24 GMT", + "x-ms-version": "2021-08-06" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Date": "Mon, 10 Oct 2022 03:49:23 GMT", + "Server": [ + "Windows-Azure-Blob/1.0", + "Microsoft-HTTPAPI/2.0" + ], + "Transfer-Encoding": "chunked", + "Vary": "Origin", + "x-ms-error-code": "BlobNotFound", + "x-ms-version": "2021-08-06" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1?api-version=2022-05-01", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "317", + "Content-Type": "application/json", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": { + "properties": { + "properties": { + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" + }, + "isAnonymous": true, + "isArchived": false, + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/get_started_train_score_eval" + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:49:24 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-06c9013427e73b38bffc1aeee50e1d34-571baafb2fd8be08-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "9c5fd88e-d062-44c9-9bd6-b8b66c04fb0f", + "x-ms-ratelimit-remaining-subscription-writes": "1119", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034924Z:9c5fd88e-d062-44c9-9bd6-b8b66c04fb0f", + "x-request-time": "0.202" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1", + "name": "1", + "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", + "properties": { + "description": null, + "tags": {}, + "properties": { + "hash_sha256": "0000000000000", + "hash_version": "0000000000000" + }, + "isArchived": false, + "isAnonymous": false, + "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/get_started_train_score_eval" + }, + "systemData": { + "createdAt": "2022-10-10T03:49:16.1243019\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:49:24.7967171\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "1390", + "Content-Type": "application/json", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": { + "properties": { + "description": "A dummy evaluate module", + "properties": {}, + "tags": {}, + "isAnonymous": true, + "isArchived": false, + "componentSpec": { + "name": "azureml_anonymous", + "description": "A dummy evaluate module", + "tags": {}, + "version": "000000000000000000000", + "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", + "display_name": "Evaluate", + "inputs": { + "scoring_result": { + "type": "path", + "description": "Scoring result file in TSV format" + } + }, + "outputs": { + "eval_output": { + "type": "path", + "description": "Evaluation result" + } + }, + "type": "CommandComponent", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1", + "environment": { + "docker": { + "image": "mcr.microsoft.com/azureml/openmpi3.1.2-ubuntu18.04:20220714.v1" + }, + "conda": { + "conda_dependencies": { + "name": "project_environment", + "channels": [ + "conda-forge" + ], + "dependencies": [ + "pip=20.2", + "python=3.7.9", + "scikit-surprise=1.0.6", + { + "pip": [ + "waitress==2.0.0", + "azureml-designer-classic-modules==0.0.161", + "https://github.com/explosion/spacy-models/releases/download/en_core_web_sm-2.1.0/en_core_web_sm-2.1.0.tar.gz#egg=en_core_web_sm", + "spacy==2.1.7" + ] + } + ] + } + }, + "os": "Linux" + }, + "command": "python eval.py --scoring_result {inputs.scoring_result} --eval_output {outputs.eval_output}" + } + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "2704", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:49:25 GMT", + "Expires": "-1", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-fdccd1028a2b81d67bd492d690968cbd-7932e3419d2acccc-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "93ddf6f9-0dbb-4365-8a3d-6af6273c8fc6", + "x-ms-ratelimit-remaining-subscription-writes": "1118", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034926Z:93ddf6f9-0dbb-4365-8a3d-6af6273c8fc6", + "x-request-time": "1.194" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/77eb52ac-6693-4df4-8c98-a417048f48c0", + "name": "77eb52ac-6693-4df4-8c98-a417048f48c0", + "type": "Microsoft.MachineLearningServices/workspaces/components/versions", + "properties": { + "description": null, + "tags": {}, + "properties": {}, + "isArchived": false, + "isAnonymous": true, + "componentSpec": { + "$schema": "https://componentsdk.azureedge.net/jsonschema/CommandComponent.json", + "name": "azureml_anonymous", + "version": "77eb52ac-6693-4df4-8c98-a417048f48c0", + "display_name": "Evaluate", + "is_deterministic": "True", + "type": "CommandComponent", + "description": "A dummy evaluate module", + "inputs": { + "scoring_result": { + "type": "path", + "optional": "False", + "description": "Scoring result file in TSV format", + "datastore_mode": "Mount" + } + }, + "outputs": { + "eval_output": { + "type": "path", + "description": "Evaluation result", + "datastore_mode": "Upload" + } + }, + "environment": { + "conda": { + "conda_dependencies": { + "name": "project_environment", + "channels": [ + "conda-forge" + ], + "dependencies": [ + "pip=20.2", + "python=3.7.9", + "scikit-surprise=1.0.6", + { + "pip": [ + "waitress==2.0.0", + "azureml-designer-classic-modules==0.0.161", + "https://github.com/explosion/spacy-models/releases/download/en_core_web_sm-2.1.0/en_core_web_sm-2.1.0.tar.gz#egg=en_core_web_sm", + "spacy==2.1.7" + ] + } + ] + } + }, + "docker": { + "image": "mcr.microsoft.com/azureml/openmpi3.1.2-ubuntu18.04:20220714.v1" + }, + "os": "Linux" + }, + "successful_return_code": "Zero", + "command": "python eval.py --scoring_result {inputs.scoring_result} --eval_output {outputs.eval_output}", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/000000000000000000000/versions/1" + } + }, + "systemData": { + "createdAt": "2022-10-10T03:49:26.0736187\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User", + "lastModifiedAt": "2022-10-10T03:49:26.0736187\u002B00:00", + "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedByType": "User" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "2681", + "Content-Type": "application/json", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": { + "properties": { + "properties": {}, + "tags": {}, + "displayName": "training_pipeline_with_components_in_registry", + "experimentName": "v15_v2_interop", + "isArchived": false, + "jobType": "Pipeline", + "inputs": { + "input_data": { + "uri": "https://dprepdata.blob.core.windows.net/demo/Titanic.csv", + "jobInputType": "uri_file" + }, + "test_data": { + "uri": "https://dprepdata.blob.core.windows.net/demo/Titanic.csv", + "jobInputType": "uri_file" + }, + "learning_rate": { + "jobInputType": "literal", + "value": "0.1" + } + }, + "jobs": { + "train": { + "environment": null, + "limits": { + "job_limits_type": "Command" + }, + "resources": { + "properties": {} + }, + "type": "CommandComponent", + "inputs": { + "training_data": { + "job_input_type": "literal", + "value": "${{parent.inputs.input_data}}" + }, + "learning_rate": { + "job_input_type": "literal", + "value": "${{parent.inputs.learning_rate}}" + }, + "max_epochs": { + "job_input_type": "literal", + "value": "5" + } + }, + "outputs": { + "model_output": { + "mode": "Upload", + "job_output_type": "uri_folder" + } + }, + "properties": {}, + "_source": "YAML.COMPONENT", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/ddbb8e79-6e6e-4b82-9bb0-7b784431f766" + }, + "score": { + "environment": null, + "limits": { + "job_limits_type": "Command" + }, + "resources": { + "properties": {} + }, + "type": "CommandComponent", + "inputs": { + "model_input": { + "job_input_type": "literal", + "value": "${{parent.jobs.train.outputs.model_output}}" + }, + "test_data": { + "job_input_type": "literal", + "value": "${{parent.inputs.test_data}}" + } + }, + "outputs": {}, + "properties": {}, + "_source": "YAML.COMPONENT", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/6f291e6e-393d-4a46-9f45-916fac695e0d" + }, + "eval": { + "environment": null, + "limits": { + "job_limits_type": "Command" + }, + "resources": { + "properties": {} + }, + "type": "CommandComponent", + "inputs": { + "scoring_result": { + "job_input_type": "literal", + "value": "${{parent.jobs.score.outputs.score_output}}" + } + }, + "outputs": { + "eval_output": { + "mode": "Upload", + "job_output_type": "uri_folder" + } + }, + "properties": {}, + "_source": "YAML.COMPONENT", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/77eb52ac-6693-4df4-8c98-a417048f48c0" + } + }, + "outputs": {}, + "settings": { + "default_compute": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", + "_source": "DSL" + } + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "5593", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:49:33 GMT", + "Expires": "-1", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-c962baba492fb99acbfce13cf59f14b3-522b10ef365f66d5-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "7f91f204-e8d7-488e-8626-1dec012235bb", + "x-ms-ratelimit-remaining-subscription-writes": "1117", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034934Z:7f91f204-e8d7-488e-8626-1dec012235bb", + "x-request-time": "4.011" + }, + "ResponseBody": { + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000", + "name": "000000000000000000000", + "type": "Microsoft.MachineLearningServices/workspaces/jobs", + "properties": { + "description": null, + "tags": {}, + "properties": { + "azureml.DevPlatv2": "true", + "azureml.runsource": "azureml.PipelineRun", + "runSource": "MFE", + "runType": "HTTP", + "azureml.parameters": "{\u0022learning_rate\u0022:\u00220.1\u0022}", + "azureml.continue_on_step_failure": "False", + "azureml.continue_on_failed_optional_input": "True", + "azureml.defaultComputeName": "cpu-cluster", + "azureml.defaultDataStoreName": "workspaceblobstore", + "azureml.pipelineComponent": "pipelinerun" + }, + "displayName": "training_pipeline_with_components_in_registry", + "status": "Preparing", + "experimentName": "v15_v2_interop", + "services": { + "Tracking": { + "jobServiceType": "Tracking", + "port": null, + "endpoint": "azureml://master.api.azureml-test.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", + "status": null, + "errorMessage": null, + "properties": null, + "nodes": null + }, + "Studio": { + "jobServiceType": "Studio", + "port": null, + "endpoint": "https://ml.azure.com/runs/000000000000000000000?wsid=/subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000", + "status": null, + "errorMessage": null, + "properties": null, + "nodes": null + } + }, + "computeId": null, + "isArchived": false, + "identity": null, + "componentId": null, + "jobType": "Pipeline", + "settings": { + "default_compute": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", + "_source": "DSL" + }, + "jobs": { + "train": { + "environment": null, + "limits": { + "job_limits_type": "Command" + }, + "resources": { + "properties": {} + }, + "type": "CommandComponent", + "inputs": { + "training_data": { + "job_input_type": "literal", + "value": "${{parent.inputs.input_data}}" + }, + "learning_rate": { + "job_input_type": "literal", + "value": "${{parent.inputs.learning_rate}}" + }, + "max_epochs": { + "job_input_type": "literal", + "value": "5" + } + }, + "outputs": { + "model_output": { + "mode": "Upload", + "job_output_type": "uri_folder" + } + }, + "properties": {}, + "_source": "YAML.COMPONENT", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/ddbb8e79-6e6e-4b82-9bb0-7b784431f766" + }, + "score": { + "environment": null, + "limits": { + "job_limits_type": "Command" + }, + "resources": { + "properties": {} + }, + "type": "CommandComponent", + "inputs": { + "model_input": { + "job_input_type": "literal", + "value": "${{parent.jobs.train.outputs.model_output}}" + }, + "test_data": { + "job_input_type": "literal", + "value": "${{parent.inputs.test_data}}" + } + }, + "outputs": {}, + "properties": {}, + "_source": "YAML.COMPONENT", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/6f291e6e-393d-4a46-9f45-916fac695e0d" + }, + "eval": { + "environment": null, + "limits": { + "job_limits_type": "Command" + }, + "resources": { + "properties": {} + }, + "type": "CommandComponent", + "inputs": { + "scoring_result": { + "job_input_type": "literal", + "value": "${{parent.jobs.score.outputs.score_output}}" + } + }, + "outputs": { + "eval_output": { + "mode": "Upload", + "job_output_type": "uri_folder" + } + }, + "properties": {}, + "_source": "YAML.COMPONENT", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/77eb52ac-6693-4df4-8c98-a417048f48c0" + } + }, + "inputs": { + "input_data": { + "description": null, + "uri": "https://dprepdata.blob.core.windows.net/demo/Titanic.csv", + "mode": "ReadOnlyMount", + "jobInputType": "uri_file" + }, + "test_data": { + "description": null, + "uri": "https://dprepdata.blob.core.windows.net/demo/Titanic.csv", + "mode": "ReadOnlyMount", + "jobInputType": "uri_file" + }, + "learning_rate": { + "description": null, + "jobInputType": "literal", + "value": "0.1" + } + }, + "outputs": {}, + "sourceJobId": null + }, + "systemData": { + "createdAt": "2022-10-10T03:49:33.9610347\u002B00:00", + "createdBy": "Xingzhi Zhang", + "createdByType": "User" + } + } + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000/cancel?api-version=2022-10-01-preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 202, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "4", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:49:36 GMT", + "Expires": "-1", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-async-operation-timeout": "PT1H", + "x-ms-correlation-request-id": "e35bbf2d-af22-4190-80de-12d47e33a12d", + "x-ms-ratelimit-remaining-subscription-writes": "1152", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034937Z:e35bbf2d-af22-4190-80de-12d47e33a12d", + "x-request-time": "0.735" + }, + "ResponseBody": "null" + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "*/*", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 202, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "2", + "Content-Type": "application/json; charset=utf-8", + "Date": "Mon, 10 Oct 2022 03:49:38 GMT", + "Expires": "-1", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "1f7c1d37-ee5a-47d8-a445-bc57431be7f9", + "x-ms-ratelimit-remaining-subscription-reads": "11890", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T034938Z:1f7c1d37-ee5a-47d8-a445-bc57431be7f9", + "x-request-time": "0.029" + }, + "ResponseBody": {} + }, + { + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "*/*", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azure-ai-ml/0.2.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Mon, 10 Oct 2022 03:50:08 GMT", + "Expires": "-1", + "Pragma": "no-cache", + "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Server-Timing": "traceparent;desc=\u002200-7f9a434df0d4d8ecfa07651bb8e15af3-8a968896e4a66865-01\u0022", + "Strict-Transport-Security": "max-age=31536000; includeSubDomains", + "x-aml-cluster": "vienna-test-westus2-01", + "X-Content-Type-Options": "nosniff", + "x-ms-correlation-request-id": "94662413-82a8-4637-9c1f-12e314c43838", + "x-ms-ratelimit-remaining-subscription-reads": "11891", + "x-ms-response-type": "standard", + "x-ms-routing-request-id": "JAPANEAST:20221010T035008Z:94662413-82a8-4637-9c1f-12e314c43838", + "x-request-time": "0.033" + }, + "ResponseBody": null + } + ], + "Variables": {} +} diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/additional_includes/docker/DockerFile b/sdk/ml/azure-ai-ml/tests/test_configs/internal/additional_includes/docker/DockerFile new file mode 100644 index 000000000000..99beedbb337d --- /dev/null +++ b/sdk/ml/azure-ai-ml/tests/test_configs/internal/additional_includes/docker/DockerFile @@ -0,0 +1,32 @@ +FROM ubuntu:16.04 + +ARG CONDA_VERSION=4.7.12 +ARG PYTHON_VERSION=3.7 +ARG AZUREML_SDK_VERSION=1.33.0 +ARG INFERENCE_SCHEMA_VERSION=1.3.0 + +ENV LANG=C.UTF-8 LC_ALL=C.UTF-8 +ENV PATH /opt/miniconda/bin:$PATH +ENV DEBIAN_FRONTEND=noninteractive + +RUN apt-get update --fix-missing && \ + apt-get install -y wget bzip2 && \ + apt-get install -y fuse && \ + apt-get clean -y && \ + rm -rf /var/lib/apt/lists/* + +RUN useradd --create-home dockeruser +WORKDIR /home/dockeruser +USER dockeruser + +RUN wget --quiet https://repo.anaconda.com/miniconda/Miniconda3-${CONDA_VERSION}-Linux-x86_64.sh -O ~/miniconda.sh && \ + /bin/bash ~/miniconda.sh -b -p ~/miniconda && \ + rm ~/miniconda.sh && \ + ~/miniconda/bin/conda clean -tipsy +ENV PATH="/home/dockeruser/miniconda/bin/:${PATH}" + +RUN conda install -y conda=${CONDA_VERSION} python=${PYTHON_VERSION} && \ + pip install azureml-defaults==${AZUREML_SDK_VERSION} inference-schema==${INFERENCE_SCHEMA_VERSION} &&\ + conda clean -aqy && \ + rm -rf ~/miniconda/pkgs && \ + find ~/miniconda/ -type d -name __pycache__ -prune -exec rm -rf {} \; diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/ls_command_component.yaml b/sdk/ml/azure-ai-ml/tests/test_configs/internal/command-component-ls/ls_command_component.yaml similarity index 100% rename from sdk/ml/azure-ai-ml/tests/test_configs/internal/ls_command_component.yaml rename to sdk/ml/azure-ai-ml/tests/test_configs/internal/command-component-ls/ls_command_component.yaml diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/component_with_docker_file_in_additional_includes/helloworld_additional_includes.additional_includes b/sdk/ml/azure-ai-ml/tests/test_configs/internal/component_with_docker_file_in_additional_includes/helloworld_additional_includes.additional_includes new file mode 100644 index 000000000000..94254172716d --- /dev/null +++ b/sdk/ml/azure-ai-ml/tests/test_configs/internal/component_with_docker_file_in_additional_includes/helloworld_additional_includes.additional_includes @@ -0,0 +1 @@ +../additional_includes/docker/DockerFile diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/component_with_docker_file_in_additional_includes/helloworld_additional_includes.yml b/sdk/ml/azure-ai-ml/tests/test_configs/internal/component_with_docker_file_in_additional_includes/helloworld_additional_includes.yml new file mode 100644 index 000000000000..70bf26b460f2 --- /dev/null +++ b/sdk/ml/azure-ai-ml/tests/test_configs/internal/component_with_docker_file_in_additional_includes/helloworld_additional_includes.yml @@ -0,0 +1,33 @@ +$schema: https://componentsdk.azureedge.net/jsonschema/CommandComponent.json +name: microsoft.com.azureml.samples.train +version: 0.0.4 +display_name: Train +type: CommandComponent +description: A dummy training module +tags: {category: Component Tutorial, contact: amldesigner@microsoft.com} +inputs: + training_data: + type: path + description: Training data organized in the torchvision format/structure + optional: false + max_epochs: + type: integer + description: Maximum number of epochs for the training + optional: false + learning_rate: + type: float + description: Learning rate, default is 0.01 + default: 0.01 + optional: false +outputs: + model_output: + type: path + description: The output model +command: >- + python train.py --training_data {inputs.training_data} --max_epochs {inputs.max_epochs} + --learning_rate {inputs.learning_rate} --model_output {outputs.model_output} +environment: + docker: + build: + dockerfile: file:DockerFile + os: Linux diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/component_with_input_types/component_spec.yaml b/sdk/ml/azure-ai-ml/tests/test_configs/internal/component_with_input_outputs/component_spec.yaml similarity index 100% rename from sdk/ml/azure-ai-ml/tests/test_configs/internal/component_with_input_types/component_spec.yaml rename to sdk/ml/azure-ai-ml/tests/test_configs/internal/component_with_input_outputs/component_spec.yaml diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/component_with_input_types/component_spec_with_attrs.yaml b/sdk/ml/azure-ai-ml/tests/test_configs/internal/component_with_input_outputs/component_spec_with_attrs.yaml similarity index 100% rename from sdk/ml/azure-ai-ml/tests/test_configs/internal/component_with_input_types/component_spec_with_attrs.yaml rename to sdk/ml/azure-ai-ml/tests/test_configs/internal/component_with_input_outputs/component_spec_with_attrs.yaml diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/component_with_input_outputs/component_spec_with_outputs.yaml b/sdk/ml/azure-ai-ml/tests/test_configs/internal/component_with_input_outputs/component_spec_with_outputs.yaml new file mode 100644 index 000000000000..de28450e68a6 --- /dev/null +++ b/sdk/ml/azure-ai-ml/tests/test_configs/internal/component_with_input_outputs/component_spec_with_outputs.yaml @@ -0,0 +1,25 @@ +$schema: https://componentsdk.azureedge.net/jsonschema/CommandComponent.json +name: convert_file_to_boolean +version: 0.0.1 +display_name: Convert File to Boolean +type: CommandComponent +description: Convert input file to boolean type output. +tags: + codegenBy: dsl.component +inputs: + input: + optional: false + type: + - AnyFile + - AnyDirectory +outputs: + primitive_is_control: + is_control: true + type: boolean + path_with_optional: + optional: false + type: AnyDirectory +command: python -m azure.ml.component.dsl.executor --file run.py --name convert_file_to_boolean + --params --input {inputs.input} --output {outputs.path_with_optional} +environment: + name: AzureML-Component diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/hdi-component/iris.csv b/sdk/ml/azure-ai-ml/tests/test_configs/internal/hdi-component/iris.csv deleted file mode 100644 index a3490e0e07dc..000000000000 --- a/sdk/ml/azure-ai-ml/tests/test_configs/internal/hdi-component/iris.csv +++ /dev/null @@ -1,150 +0,0 @@ -5.1,3.5,1.4,0.2,Iris-setosa -4.9,3.0,1.4,0.2,Iris-setosa -4.7,3.2,1.3,0.2,Iris-setosa -4.6,3.1,1.5,0.2,Iris-setosa -5.0,3.6,1.4,0.2,Iris-setosa -5.4,3.9,1.7,0.4,Iris-setosa -4.6,3.4,1.4,0.3,Iris-setosa -5.0,3.4,1.5,0.2,Iris-setosa -4.4,2.9,1.4,0.2,Iris-setosa -4.9,3.1,1.5,0.1,Iris-setosa -5.4,3.7,1.5,0.2,Iris-setosa -4.8,3.4,1.6,0.2,Iris-setosa -4.8,3.0,1.4,0.1,Iris-setosa -4.3,3.0,1.1,0.1,Iris-setosa -5.8,4.0,1.2,0.2,Iris-setosa -5.7,4.4,1.5,0.4,Iris-setosa -5.4,3.9,1.3,0.4,Iris-setosa -5.1,3.5,1.4,0.3,Iris-setosa -5.7,3.8,1.7,0.3,Iris-setosa -5.1,3.8,1.5,0.3,Iris-setosa -5.4,3.4,1.7,0.2,Iris-setosa -5.1,3.7,1.5,0.4,Iris-setosa -4.6,3.6,1.0,0.2,Iris-setosa -5.1,3.3,1.7,0.5,Iris-setosa -4.8,3.4,1.9,0.2,Iris-setosa -5.0,3.0,1.6,0.2,Iris-setosa -5.0,3.4,1.6,0.4,Iris-setosa -5.2,3.5,1.5,0.2,Iris-setosa -5.2,3.4,1.4,0.2,Iris-setosa -4.7,3.2,1.6,0.2,Iris-setosa -4.8,3.1,1.6,0.2,Iris-setosa -5.4,3.4,1.5,0.4,Iris-setosa -5.2,4.1,1.5,0.1,Iris-setosa -5.5,4.2,1.4,0.2,Iris-setosa -4.9,3.1,1.5,0.1,Iris-setosa -5.0,3.2,1.2,0.2,Iris-setosa -5.5,3.5,1.3,0.2,Iris-setosa -4.9,3.1,1.5,0.1,Iris-setosa -4.4,3.0,1.3,0.2,Iris-setosa -5.1,3.4,1.5,0.2,Iris-setosa -5.0,3.5,1.3,0.3,Iris-setosa -4.5,2.3,1.3,0.3,Iris-setosa -4.4,3.2,1.3,0.2,Iris-setosa -5.0,3.5,1.6,0.6,Iris-setosa -5.1,3.8,1.9,0.4,Iris-setosa -4.8,3.0,1.4,0.3,Iris-setosa -5.1,3.8,1.6,0.2,Iris-setosa -4.6,3.2,1.4,0.2,Iris-setosa -5.3,3.7,1.5,0.2,Iris-setosa -5.0,3.3,1.4,0.2,Iris-setosa -7.0,3.2,4.7,1.4,Iris-versicolor -6.4,3.2,4.5,1.5,Iris-versicolor -6.9,3.1,4.9,1.5,Iris-versicolor -5.5,2.3,4.0,1.3,Iris-versicolor -6.5,2.8,4.6,1.5,Iris-versicolor -5.7,2.8,4.5,1.3,Iris-versicolor -6.3,3.3,4.7,1.6,Iris-versicolor -4.9,2.4,3.3,1.0,Iris-versicolor -6.6,2.9,4.6,1.3,Iris-versicolor -5.2,2.7,3.9,1.4,Iris-versicolor -5.0,2.0,3.5,1.0,Iris-versicolor -5.9,3.0,4.2,1.5,Iris-versicolor -6.0,2.2,4.0,1.0,Iris-versicolor -6.1,2.9,4.7,1.4,Iris-versicolor -5.6,2.9,3.6,1.3,Iris-versicolor -6.7,3.1,4.4,1.4,Iris-versicolor -5.6,3.0,4.5,1.5,Iris-versicolor -5.8,2.7,4.1,1.0,Iris-versicolor -6.2,2.2,4.5,1.5,Iris-versicolor -5.6,2.5,3.9,1.1,Iris-versicolor -5.9,3.2,4.8,1.8,Iris-versicolor -6.1,2.8,4.0,1.3,Iris-versicolor -6.3,2.5,4.9,1.5,Iris-versicolor -6.1,2.8,4.7,1.2,Iris-versicolor -6.4,2.9,4.3,1.3,Iris-versicolor -6.6,3.0,4.4,1.4,Iris-versicolor -6.8,2.8,4.8,1.4,Iris-versicolor -6.7,3.0,5.0,1.7,Iris-versicolor -6.0,2.9,4.5,1.5,Iris-versicolor -5.7,2.6,3.5,1.0,Iris-versicolor -5.5,2.4,3.8,1.1,Iris-versicolor -5.5,2.4,3.7,1.0,Iris-versicolor -5.8,2.7,3.9,1.2,Iris-versicolor -6.0,2.7,5.1,1.6,Iris-versicolor -5.4,3.0,4.5,1.5,Iris-versicolor -6.0,3.4,4.5,1.6,Iris-versicolor -6.7,3.1,4.7,1.5,Iris-versicolor -6.3,2.3,4.4,1.3,Iris-versicolor -5.6,3.0,4.1,1.3,Iris-versicolor -5.5,2.5,4.0,1.3,Iris-versicolor -5.5,2.6,4.4,1.2,Iris-versicolor -6.1,3.0,4.6,1.4,Iris-versicolor -5.8,2.6,4.0,1.2,Iris-versicolor -5.0,2.3,3.3,1.0,Iris-versicolor -5.6,2.7,4.2,1.3,Iris-versicolor -5.7,3.0,4.2,1.2,Iris-versicolor -5.7,2.9,4.2,1.3,Iris-versicolor -6.2,2.9,4.3,1.3,Iris-versicolor -5.1,2.5,3.0,1.1,Iris-versicolor -5.7,2.8,4.1,1.3,Iris-versicolor -6.3,3.3,6.0,2.5,Iris-virginica -5.8,2.7,5.1,1.9,Iris-virginica -7.1,3.0,5.9,2.1,Iris-virginica -6.3,2.9,5.6,1.8,Iris-virginica -6.5,3.0,5.8,2.2,Iris-virginica -7.6,3.0,6.6,2.1,Iris-virginica -4.9,2.5,4.5,1.7,Iris-virginica -7.3,2.9,6.3,1.8,Iris-virginica -6.7,2.5,5.8,1.8,Iris-virginica -7.2,3.6,6.1,2.5,Iris-virginica -6.5,3.2,5.1,2.0,Iris-virginica -6.4,2.7,5.3,1.9,Iris-virginica -6.8,3.0,5.5,2.1,Iris-virginica -5.7,2.5,5.0,2.0,Iris-virginica -5.8,2.8,5.1,2.4,Iris-virginica -6.4,3.2,5.3,2.3,Iris-virginica -6.5,3.0,5.5,1.8,Iris-virginica -7.7,3.8,6.7,2.2,Iris-virginica -7.7,2.6,6.9,2.3,Iris-virginica -6.0,2.2,5.0,1.5,Iris-virginica -6.9,3.2,5.7,2.3,Iris-virginica -5.6,2.8,4.9,2.0,Iris-virginica -7.7,2.8,6.7,2.0,Iris-virginica -6.3,2.7,4.9,1.8,Iris-virginica -6.7,3.3,5.7,2.1,Iris-virginica -7.2,3.2,6.0,1.8,Iris-virginica -6.2,2.8,4.8,1.8,Iris-virginica -6.1,3.0,4.9,1.8,Iris-virginica -6.4,2.8,5.6,2.1,Iris-virginica -7.2,3.0,5.8,1.6,Iris-virginica -7.4,2.8,6.1,1.9,Iris-virginica -7.9,3.8,6.4,2.0,Iris-virginica -6.4,2.8,5.6,2.2,Iris-virginica -6.3,2.8,5.1,1.5,Iris-virginica -6.1,2.6,5.6,1.4,Iris-virginica -7.7,3.0,6.1,2.3,Iris-virginica -6.3,3.4,5.6,2.4,Iris-virginica -6.4,3.1,5.5,1.8,Iris-virginica -6.0,3.0,4.8,1.8,Iris-virginica -6.9,3.1,5.4,2.1,Iris-virginica -6.7,3.1,5.6,2.4,Iris-virginica -6.9,3.1,5.1,2.3,Iris-virginica -5.8,2.7,5.1,1.9,Iris-virginica -6.8,3.2,5.9,2.3,Iris-virginica -6.7,3.3,5.7,2.5,Iris-virginica -6.7,3.0,5.2,2.3,Iris-virginica -6.3,2.5,5.0,1.9,Iris-virginica -6.5,3.0,5.2,2.0,Iris-virginica -6.2,3.4,5.4,2.3,Iris-virginica -5.9,3.0,5.1,1.8,Iris-virginica diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/helloworld_component_command.yml b/sdk/ml/azure-ai-ml/tests/test_configs/internal/helloworld/helloworld_component_command.yml similarity index 100% rename from sdk/ml/azure-ai-ml/tests/test_configs/internal/helloworld_component_command.yml rename to sdk/ml/azure-ai-ml/tests/test_configs/internal/helloworld/helloworld_component_command.yml diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/helloworld_component_scope.yml b/sdk/ml/azure-ai-ml/tests/test_configs/internal/helloworld/helloworld_component_scope.yml similarity index 98% rename from sdk/ml/azure-ai-ml/tests/test_configs/internal/helloworld_component_scope.yml rename to sdk/ml/azure-ai-ml/tests/test_configs/internal/helloworld/helloworld_component_scope.yml index 6e03b4183fc1..ffac44d0ab7c 100644 --- a/sdk/ml/azure-ai-ml/tests/test_configs/internal/helloworld_component_scope.yml +++ b/sdk/ml/azure-ai-ml/tests/test_configs/internal/helloworld/helloworld_component_scope.yml @@ -28,7 +28,7 @@ outputs: type: path description: output path of ss -code: ./scope +code: ../scope environment: azureml:AzureEnv:1 diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/ae365exepool-component/component_spec.loaded_from_rest.json b/sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/ae365exepool-component/component_spec.json similarity index 100% rename from sdk/ml/azure-ai-ml/tests/test_configs/internal/ae365exepool-component/component_spec.loaded_from_rest.json rename to sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/ae365exepool-component/component_spec.json diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/batch_inference/batch_score.loaded_from_rest.json b/sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/batch_inference/batch_score.json similarity index 100% rename from sdk/ml/azure-ai-ml/tests/test_configs/internal/batch_inference/batch_score.loaded_from_rest.json rename to sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/batch_inference/batch_score.json diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/ls_command_component.loaded_from_rest.json b/sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/command-component-ls/ls_command_component.json similarity index 100% rename from sdk/ml/azure-ai-ml/tests/test_configs/internal/ls_command_component.loaded_from_rest.json rename to sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/command-component-ls/ls_command_component.json diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/data-transfer-component/component_spec.loaded_from_rest.json b/sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/data-transfer-component/component_spec.json similarity index 100% rename from sdk/ml/azure-ai-ml/tests/test_configs/internal/data-transfer-component/component_spec.loaded_from_rest.json rename to sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/data-transfer-component/component_spec.json diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/distribution-component/component_spec.loaded_from_rest.json b/sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/distribution-component/component_spec.json similarity index 100% rename from sdk/ml/azure-ai-ml/tests/test_configs/internal/distribution-component/component_spec.loaded_from_rest.json rename to sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/distribution-component/component_spec.json diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/hdi-component/component_spec.loaded_from_rest.json b/sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/hdi-component/component_spec.json similarity index 100% rename from sdk/ml/azure-ai-ml/tests/test_configs/internal/hdi-component/component_spec.loaded_from_rest.json rename to sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/hdi-component/component_spec.json diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/hemera-component/component.loaded_from_rest.json b/sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/hemera-component/component.json similarity index 100% rename from sdk/ml/azure-ai-ml/tests/test_configs/internal/hemera-component/component.loaded_from_rest.json rename to sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/hemera-component/component.json diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/scope-component/component_spec.loaded_from_rest.json b/sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/scope-component/component_spec.json similarity index 100% rename from sdk/ml/azure-ai-ml/tests/test_configs/internal/scope-component/component_spec.loaded_from_rest.json rename to sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/scope-component/component_spec.json diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/starlite-component/component_spec.loaded_from_rest.json b/sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/starlite-component/component_spec.json similarity index 100% rename from sdk/ml/azure-ai-ml/tests/test_configs/internal/starlite-component/component_spec.loaded_from_rest.json rename to sdk/ml/azure-ai-ml/tests/test_configs/internal/loaded_from_rest/starlite-component/component_spec.json diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/pipeline_jobs/pipeline_job_with_properties.yml b/sdk/ml/azure-ai-ml/tests/test_configs/internal/pipeline_jobs/pipeline_job_with_properties.yml index 6180609f8339..a208c528b32f 100644 --- a/sdk/ml/azure-ai-ml/tests/test_configs/internal/pipeline_jobs/pipeline_job_with_properties.yml +++ b/sdk/ml/azure-ai-ml/tests/test_configs/internal/pipeline_jobs/pipeline_job_with_properties.yml @@ -145,7 +145,7 @@ jobs: # node7: # internal command node with properties as a typical implement of internal base node. # type: CommandComponent # compute: azureml:cpu-cluster -# component: ../internal/helloworld_component_command.yml +# component: ../internal/helloworld/helloworld_component_command.yml # inputs: # training_data: ${{parent.inputs.input_data}} # max_epochs: 10 diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/internal/scope-component/label_data.tsv b/sdk/ml/azure-ai-ml/tests/test_configs/internal/scope-component/label_data.tsv deleted file mode 100644 index 312372eabe50..000000000000 --- a/sdk/ml/azure-ai-ml/tests/test_configs/internal/scope-component/label_data.tsv +++ /dev/null @@ -1,10 +0,0 @@ -a 1 -b 2 -a 3 -d 4 -d 5 -r 6 -r 7 -i 8 -v 9 -c 10 diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/pipeline_jobs/pipeline_job_with_properties.yml b/sdk/ml/azure-ai-ml/tests/test_configs/pipeline_jobs/pipeline_job_with_properties.yml index 6180609f8339..a208c528b32f 100644 --- a/sdk/ml/azure-ai-ml/tests/test_configs/pipeline_jobs/pipeline_job_with_properties.yml +++ b/sdk/ml/azure-ai-ml/tests/test_configs/pipeline_jobs/pipeline_job_with_properties.yml @@ -145,7 +145,7 @@ jobs: # node7: # internal command node with properties as a typical implement of internal base node. # type: CommandComponent # compute: azureml:cpu-cluster -# component: ../internal/helloworld_component_command.yml +# component: ../internal/helloworld/helloworld_component_command.yml # inputs: # training_data: ${{parent.inputs.input_data}} # max_epochs: 10