Skip to main content
Back to top
Ctrl
+
K
Install
User Guide
Reference
Development
Search
Ctrl
+
K
GitHub
PyPI
Choose version
Search
Ctrl
+
K
Install
User Guide
Reference
Development
GitHub
PyPI
Choose version
Section Navigation
hpcflow.sdk.sdk_classes
hpcflow.sdk.sdk_funcs
hpcflow.sdk.get_SDK_logger
hpcflow.sdk.app
hpcflow.sdk.app.get_app_attribute
hpcflow.sdk.app.get_app_module_all
hpcflow.sdk.app.get_app_module_dir
hpcflow.sdk.app.rate_limit_safe_url_to_fs
hpcflow.sdk.app.App
hpcflow.sdk.app.BaseApp
hpcflow.sdk.app.Singleton
hpcflow.sdk.cli
hpcflow.sdk.cli.string_option
hpcflow.sdk.cli.workflow_ref_type_opt
hpcflow.sdk.cli.make_cli
hpcflow.sdk.cli.parse_jobscript_wait_spec
hpcflow.sdk.cli.redirect_std_to_file_click
hpcflow.sdk.cli.ErrorPropagatingClickContext
hpcflow.sdk.cli_common
hpcflow.sdk.cli_common.format_option
hpcflow.sdk.cli_common.path_option
hpcflow.sdk.cli_common.name_option
hpcflow.sdk.cli_common.overwrite_option
hpcflow.sdk.cli_common.store_option
hpcflow.sdk.cli_common.ts_fmt_option
hpcflow.sdk.cli_common.ts_name_fmt_option
hpcflow.sdk.cli_common.variables_option
hpcflow.sdk.cli_common.js_parallelism_option
hpcflow.sdk.cli_common.wait_option
hpcflow.sdk.cli_common.add_to_known_opt
hpcflow.sdk.cli_common.print_idx_opt
hpcflow.sdk.cli_common.tasks_opt
hpcflow.sdk.cli_common.cancel_opt
hpcflow.sdk.cli_common.submit_status_opt
hpcflow.sdk.cli_common.force_arr_opt
hpcflow.sdk.cli_common.make_status_opt
hpcflow.sdk.cli_common.add_sub_opt
hpcflow.sdk.cli_common.zip_path_opt
hpcflow.sdk.cli_common.zip_overwrite_opt
hpcflow.sdk.cli_common.zip_log_opt
hpcflow.sdk.cli_common.zip_include_execute_opt
hpcflow.sdk.cli_common.zip_include_rechunk_backups_opt
hpcflow.sdk.cli_common.unzip_path_opt
hpcflow.sdk.cli_common.unzip_log_opt
hpcflow.sdk.cli_common.rechunk_backup_opt
hpcflow.sdk.cli_common.rechunk_chunk_size_opt
hpcflow.sdk.cli_common.rechunk_status_opt
hpcflow.sdk.cli_common.sub_tasks_callback
hpcflow.sdk.cli_common.BoolOrString
hpcflow.sdk.config
hpcflow.sdk.config.callbacks
hpcflow.sdk.config.callbacks.callback_bool
hpcflow.sdk.config.callbacks.callback_file_paths
hpcflow.sdk.config.callbacks.callback_log_file_path
hpcflow.sdk.config.callbacks.callback_lowercase
hpcflow.sdk.config.callbacks.callback_scheduler_set_up
hpcflow.sdk.config.callbacks.callback_supported_schedulers
hpcflow.sdk.config.callbacks.callback_supported_shells
hpcflow.sdk.config.callbacks.callback_unset_log_console_level
hpcflow.sdk.config.callbacks.callback_unset_log_file_level
hpcflow.sdk.config.callbacks.callback_unset_log_file_path
hpcflow.sdk.config.callbacks.callback_update_log_console_level
hpcflow.sdk.config.callbacks.callback_update_log_file_level
hpcflow.sdk.config.callbacks.callback_update_log_file_path
hpcflow.sdk.config.callbacks.callback_vars
hpcflow.sdk.config.callbacks.check_load_data_files
hpcflow.sdk.config.callbacks.exists_in_schedulers
hpcflow.sdk.config.callbacks.set_callback_file_paths
hpcflow.sdk.config.callbacks.set_scheduler_invocation_match
hpcflow.sdk.config.cli
hpcflow.sdk.config.cli.CLI_exception_wrapper_gen
hpcflow.sdk.config.cli.get_config_CLI
hpcflow.sdk.config.config
hpcflow.sdk.config.config.DEFAULT_CONFIG
hpcflow.sdk.config.config.Config
hpcflow.sdk.config.config.ConfigOptions
hpcflow.sdk.config.config_file
hpcflow.sdk.config.config_file.ConfigFile
hpcflow.sdk.config.errors
hpcflow.sdk.config.errors.ConfigChangeFileUpdateError
hpcflow.sdk.config.errors.ConfigChangeInvalidError
hpcflow.sdk.config.errors.ConfigChangeInvalidJSONError
hpcflow.sdk.config.errors.ConfigChangePopIndexError
hpcflow.sdk.config.errors.ConfigChangeTypeInvalidError
hpcflow.sdk.config.errors.ConfigChangeValidationError
hpcflow.sdk.config.errors.ConfigDefaultValidationError
hpcflow.sdk.config.errors.ConfigError
hpcflow.sdk.config.errors.ConfigFileInvocationIncompatibleError
hpcflow.sdk.config.errors.ConfigFileInvocationUnknownMatchKey
hpcflow.sdk.config.errors.ConfigFileValidationError
hpcflow.sdk.config.errors.ConfigInvocationKeyNotFoundError
hpcflow.sdk.config.errors.ConfigItemAlreadyUnsetError
hpcflow.sdk.config.errors.ConfigItemCallbackError
hpcflow.sdk.config.errors.ConfigNonConfigurableError
hpcflow.sdk.config.errors.ConfigReadOnlyError
hpcflow.sdk.config.errors.ConfigUnknownItemError
hpcflow.sdk.config.errors.ConfigUnknownOverrideError
hpcflow.sdk.config.errors.ConfigValidationError
hpcflow.sdk.config.errors.MissingEnvironmentFileError
hpcflow.sdk.config.errors.MissingTaskSchemaFileError
hpcflow.sdk.config.errors.UnknownMetaTaskConstitutiveSchema
hpcflow.sdk.config.types
hpcflow.sdk.config.types.GetterCallback
hpcflow.sdk.config.types.SetterCallback
hpcflow.sdk.config.types.UnsetterCallback
hpcflow.sdk.config.types.ConfigDict
hpcflow.sdk.config.types.ConfigDescriptor
hpcflow.sdk.config.types.ConfigMetadata
hpcflow.sdk.config.types.DefaultConfiguration
hpcflow.sdk.config.types.InvocationDescriptor
hpcflow.sdk.config.types.SGEParallelEnvsDescriptor
hpcflow.sdk.config.types.SLURMPartitionsDescriptor
hpcflow.sdk.config.types.SchedulerConfigDescriptor
hpcflow.sdk.config.types.ShellConfigDescriptor
hpcflow.sdk.core
hpcflow.sdk.core.ALL_TEMPLATE_FORMATS
hpcflow.sdk.core.ABORT_EXIT_CODE
hpcflow.sdk.core.actions
hpcflow.sdk.core.actions.ACTION_SCOPE_ALLOWED_KWARGS
hpcflow.sdk.core.actions.Action
hpcflow.sdk.core.actions.ActionEnvironment
hpcflow.sdk.core.actions.ActionRule
hpcflow.sdk.core.actions.ActionScope
hpcflow.sdk.core.actions.ElementAction
hpcflow.sdk.core.actions.ElementActionRun
hpcflow.sdk.core.actions.UnsetParamTracker
hpcflow.sdk.core.app_aware
hpcflow.sdk.core.app_aware.AppAware
hpcflow.sdk.core.cache
hpcflow.sdk.core.cache.ObjectCache
hpcflow.sdk.core.command_files
hpcflow.sdk.core.command_files.FileNameExt
hpcflow.sdk.core.command_files.FileNamePart
hpcflow.sdk.core.command_files.FileNameSpec
hpcflow.sdk.core.command_files.FileNameStem
hpcflow.sdk.core.command_files.FileSpec
hpcflow.sdk.core.command_files.InputFile
hpcflow.sdk.core.command_files.InputFileGenerator
hpcflow.sdk.core.command_files.InputFileGeneratorSource
hpcflow.sdk.core.command_files.OutputFileParser
hpcflow.sdk.core.command_files.OutputFileParserSource
hpcflow.sdk.core.commands
hpcflow.sdk.core.commands.Command
hpcflow.sdk.core.element
hpcflow.sdk.core.element.Element
hpcflow.sdk.core.element.ElementFilter
hpcflow.sdk.core.element.ElementGroup
hpcflow.sdk.core.element.ElementInputFiles
hpcflow.sdk.core.element.ElementInputs
hpcflow.sdk.core.element.ElementIteration
hpcflow.sdk.core.element.ElementOutputFiles
hpcflow.sdk.core.element.ElementOutputs
hpcflow.sdk.core.element.ElementParameter
hpcflow.sdk.core.element.ElementRepeats
hpcflow.sdk.core.element.ElementResources
hpcflow.sdk.core.enums
hpcflow.sdk.core.enums.EARStatus
hpcflow.sdk.core.enums.ParallelMode
hpcflow.sdk.core.environment
hpcflow.sdk.core.environment.Environment
hpcflow.sdk.core.environment.Executable
hpcflow.sdk.core.environment.ExecutableInstance
hpcflow.sdk.core.environment.NumCores
hpcflow.sdk.core.errors
hpcflow.sdk.core.errors.ActionEnvironmentMissingNameError
hpcflow.sdk.core.errors.ContainerKeyError
hpcflow.sdk.core.errors.DuplicateExecutableError
hpcflow.sdk.core.errors.EnvironmentPresetUnknownEnvironmentError
hpcflow.sdk.core.errors.EnvironmentSpecValidationError
hpcflow.sdk.core.errors.ExtraInputs
hpcflow.sdk.core.errors.FileSpecValidationError
hpcflow.sdk.core.errors.FromSpecMissingObjectError
hpcflow.sdk.core.errors.InapplicableInputSourceElementIters
hpcflow.sdk.core.errors.IncompatibleParallelModeError
hpcflow.sdk.core.errors.IncompatibleSGEPEError
hpcflow.sdk.core.errors.IncompatibleSLURMArgumentsError
hpcflow.sdk.core.errors.IncompatibleSLURMPartitionError
hpcflow.sdk.core.errors.InputSourceValidationError
hpcflow.sdk.core.errors.InputValueDuplicateSequenceAddress
hpcflow.sdk.core.errors.InvalidIdentifier
hpcflow.sdk.core.errors.InvalidInputSourceTaskReference
hpcflow.sdk.core.errors.JobscriptSubmissionFailure
hpcflow.sdk.core.errors.LoopAlreadyExistsError
hpcflow.sdk.core.errors.LoopTaskSubsetError
hpcflow.sdk.core.errors.MalformedNestingOrderPath
hpcflow.sdk.core.errors.MalformedParameterPathError
hpcflow.sdk.core.errors.MalformedWorkflowError
hpcflow.sdk.core.errors.MayNeedObjectError
hpcflow.sdk.core.errors.MissingActionEnvironment
hpcflow.sdk.core.errors.MissingCompatibleActionEnvironment
hpcflow.sdk.core.errors.MissingElementGroup
hpcflow.sdk.core.errors.MissingEnvironmentError
hpcflow.sdk.core.errors.MissingEnvironmentExecutableError
hpcflow.sdk.core.errors.MissingEnvironmentExecutableInstanceError
hpcflow.sdk.core.errors.MissingInputs
hpcflow.sdk.core.errors.MissingParameterData
hpcflow.sdk.core.errors.MissingStoreEARError
hpcflow.sdk.core.errors.MissingStoreElementError
hpcflow.sdk.core.errors.MissingStoreElementIterationError
hpcflow.sdk.core.errors.MissingStoreTaskError
hpcflow.sdk.core.errors.MissingVariableSubstitutionError
hpcflow.sdk.core.errors.MultipleEnvironmentsError
hpcflow.sdk.core.errors.NoAvailableElementSetsError
hpcflow.sdk.core.errors.NoCLIFormatMethodError
hpcflow.sdk.core.errors.NoCoincidentInputSources
hpcflow.sdk.core.errors.NoCompatibleSGEPEError
hpcflow.sdk.core.errors.NotSubmitMachineError
hpcflow.sdk.core.errors.OutputFileParserNoOutputError
hpcflow.sdk.core.errors.ParameterSpecValidationError
hpcflow.sdk.core.errors.ParametersMetadataReadOnlyError
hpcflow.sdk.core.errors.ResourceValidationError
hpcflow.sdk.core.errors.RunNotAbortableError
hpcflow.sdk.core.errors.SchedulerVersionsFailure
hpcflow.sdk.core.errors.SubmissionEnvironmentError
hpcflow.sdk.core.errors.SubmissionFailure
hpcflow.sdk.core.errors.TaskSchemaMissingParameterError
hpcflow.sdk.core.errors.TaskSchemaSpecValidationError
hpcflow.sdk.core.errors.TaskTemplateInvalidNesting
hpcflow.sdk.core.errors.TaskTemplateMultipleInputValues
hpcflow.sdk.core.errors.TaskTemplateMultipleSchemaObjectives
hpcflow.sdk.core.errors.TaskTemplateUnexpectedInput
hpcflow.sdk.core.errors.TaskTemplateUnexpectedSequenceInput
hpcflow.sdk.core.errors.ToJSONLikeChildReferenceError
hpcflow.sdk.core.errors.UnavailableInputSource
hpcflow.sdk.core.errors.UnknownActionDataKey
hpcflow.sdk.core.errors.UnknownActionDataParameter
hpcflow.sdk.core.errors.UnknownEnvironmentPresetError
hpcflow.sdk.core.errors.UnknownResourceSpecItemError
hpcflow.sdk.core.errors.UnknownSGEPEError
hpcflow.sdk.core.errors.UnknownSLURMPartitionError
hpcflow.sdk.core.errors.UnrequiredInputSources
hpcflow.sdk.core.errors.UnsetParameterDataError
hpcflow.sdk.core.errors.UnsetParameterDataErrorBase
hpcflow.sdk.core.errors.UnsetParameterFractionLimitExceededError
hpcflow.sdk.core.errors.UnsetParameterNumberLimitExceededError
hpcflow.sdk.core.errors.UnsupportedActionDataFormat
hpcflow.sdk.core.errors.UnsupportedOSError
hpcflow.sdk.core.errors.UnsupportedSchedulerError
hpcflow.sdk.core.errors.UnsupportedShellError
hpcflow.sdk.core.errors.ValuesAlreadyPersistentError
hpcflow.sdk.core.errors.WorkflowBatchUpdateFailedError
hpcflow.sdk.core.errors.WorkflowLimitsError
hpcflow.sdk.core.errors.WorkflowNotFoundError
hpcflow.sdk.core.errors.WorkflowParameterMissingError
hpcflow.sdk.core.errors.WorkflowSpecValidationError
hpcflow.sdk.core.errors.WorkflowSubmissionFailure
hpcflow.sdk.core.errors.YAMLError
hpcflow.sdk.core.execute
hpcflow.sdk.core.execute.Executor
hpcflow.sdk.core.json_like
hpcflow.sdk.core.json_like.PRIMITIVES
hpcflow.sdk.core.json_like.to_json_like
hpcflow.sdk.core.json_like.BaseJSONLike
hpcflow.sdk.core.json_like.ChildObjectSpec
hpcflow.sdk.core.json_like.JSONLike
hpcflow.sdk.core.loop
hpcflow.sdk.core.loop.Loop
hpcflow.sdk.core.loop.WorkflowLoop
hpcflow.sdk.core.loop_cache
hpcflow.sdk.core.loop_cache.LoopCache
hpcflow.sdk.core.loop_cache.LoopIndex
hpcflow.sdk.core.object_list
hpcflow.sdk.core.object_list.index
hpcflow.sdk.core.object_list.AppDataList
hpcflow.sdk.core.object_list.CommandFilesList
hpcflow.sdk.core.object_list.DotAccessObjectList
hpcflow.sdk.core.object_list.EnvironmentsList
hpcflow.sdk.core.object_list.ExecutablesList
hpcflow.sdk.core.object_list.GroupList
hpcflow.sdk.core.object_list.ObjectList
hpcflow.sdk.core.object_list.ParametersList
hpcflow.sdk.core.object_list.ResourceList
hpcflow.sdk.core.object_list.TaskList
hpcflow.sdk.core.object_list.TaskSchemasList
hpcflow.sdk.core.object_list.TaskTemplateList
hpcflow.sdk.core.object_list.WorkflowLoopList
hpcflow.sdk.core.object_list.WorkflowTaskList
hpcflow.sdk.core.object_list.DotAccessAttributeError
hpcflow.sdk.core.object_list.ObjectListMultipleMatchError
hpcflow.sdk.core.parameters
hpcflow.sdk.core.parameters.Where
hpcflow.sdk.core.parameters.AbstractInputValue
hpcflow.sdk.core.parameters.BuiltinSchemaParameter
hpcflow.sdk.core.parameters.InputSource
hpcflow.sdk.core.parameters.InputValue
hpcflow.sdk.core.parameters.MultiPathSequence
hpcflow.sdk.core.parameters.NullDefault
hpcflow.sdk.core.parameters.Parameter
hpcflow.sdk.core.parameters.ParameterPath
hpcflow.sdk.core.parameters.ParameterValue
hpcflow.sdk.core.parameters.ResourceSpec
hpcflow.sdk.core.parameters.SchemaInput
hpcflow.sdk.core.parameters.SchemaOutput
hpcflow.sdk.core.parameters.SchemaParameter
hpcflow.sdk.core.parameters.SubParameter
hpcflow.sdk.core.parameters.ValuePerturbation
hpcflow.sdk.core.parameters.ValueSequence
hpcflow.sdk.core.rule
hpcflow.sdk.core.rule.Rule
hpcflow.sdk.core.run_dir_files
hpcflow.sdk.core.run_dir_files.RunDirAppFiles
hpcflow.sdk.core.skip_reason
hpcflow.sdk.core.skip_reason.SkipReason
hpcflow.sdk.core.task
hpcflow.sdk.core.task.TaskTemplate
hpcflow.sdk.core.task.ElementPropagation
hpcflow.sdk.core.task.ElementSet
hpcflow.sdk.core.task.Elements
hpcflow.sdk.core.task.InputStatus
hpcflow.sdk.core.task.MetaTask
hpcflow.sdk.core.task.OutputLabel
hpcflow.sdk.core.task.Parameters
hpcflow.sdk.core.task.Task
hpcflow.sdk.core.task.TaskInputParameters
hpcflow.sdk.core.task.TaskOutputParameters
hpcflow.sdk.core.task.TaskTemplate
hpcflow.sdk.core.task.WorkflowTask
hpcflow.sdk.core.task_schema
hpcflow.sdk.core.task_schema.MetaTaskSchema
hpcflow.sdk.core.task_schema.TaskObjective
hpcflow.sdk.core.task_schema.TaskSchema
hpcflow.sdk.core.test_utils
hpcflow.sdk.core.test_utils.Strs
hpcflow.sdk.core.test_utils.command_line_test
hpcflow.sdk.core.test_utils.make_actions
hpcflow.sdk.core.test_utils.make_parameters
hpcflow.sdk.core.test_utils.make_schemas
hpcflow.sdk.core.test_utils.make_tasks
hpcflow.sdk.core.test_utils.make_test_data_YAML_workflow
hpcflow.sdk.core.test_utils.make_test_data_YAML_workflow_template
hpcflow.sdk.core.test_utils.make_workflow
hpcflow.sdk.core.test_utils.make_workflow_to_run_command
hpcflow.sdk.core.test_utils.P1_parameter_cls
hpcflow.sdk.core.test_utils.P1_sub_parameter_cls
hpcflow.sdk.core.test_utils.P1_sub_parameter_cls_2
hpcflow.sdk.core.types
hpcflow.sdk.core.types.Address
hpcflow.sdk.core.types.Numeric
hpcflow.sdk.core.types.Resources
hpcflow.sdk.core.types.RelevantPath
hpcflow.sdk.core.types.BlockActionKey
hpcflow.sdk.core.types.AbstractFileSystem
hpcflow.sdk.core.types.ActParameterDependence
hpcflow.sdk.core.types.ActionData
hpcflow.sdk.core.types.CreationInfo
hpcflow.sdk.core.types.DependentDescriptor
hpcflow.sdk.core.types.ElementDescriptor
hpcflow.sdk.core.types.IterableParam
hpcflow.sdk.core.types.JobscriptSubmissionFailureArgs
hpcflow.sdk.core.types.LabelInfo
hpcflow.sdk.core.types.LabellingDescriptor
hpcflow.sdk.core.types.MultiplicityDescriptor
hpcflow.sdk.core.types.ParameterDependence
hpcflow.sdk.core.types.ParentPath
hpcflow.sdk.core.types.Pending
hpcflow.sdk.core.types.RelevantData
hpcflow.sdk.core.types.RepeatsDescriptor
hpcflow.sdk.core.types.ResourcePersistingWorkflow
hpcflow.sdk.core.types.ResourceSpecArgs
hpcflow.sdk.core.types.RuleArgs
hpcflow.sdk.core.types.SchemaInputKwargs
hpcflow.sdk.core.types.SiblingPath
hpcflow.sdk.core.types.UpdatePath
hpcflow.sdk.core.types.WorkflowTemplateElementSetData
hpcflow.sdk.core.types.WorkflowTemplateTaskData
hpcflow.sdk.core.utils
hpcflow.sdk.core.utils.bisect_slice
hpcflow.sdk.core.utils.check_valid_py_identifier
hpcflow.sdk.core.utils.current_timestamp
hpcflow.sdk.core.utils.dict_values_process_flat
hpcflow.sdk.core.utils.ensure_in
hpcflow.sdk.core.utils.flatten
hpcflow.sdk.core.utils.get_duplicate_items
hpcflow.sdk.core.utils.get_enum_by_name_or_val
hpcflow.sdk.core.utils.get_file_context
hpcflow.sdk.core.utils.get_in_container
hpcflow.sdk.core.utils.get_item_repeat_index
hpcflow.sdk.core.utils.get_md5_hash
hpcflow.sdk.core.utils.get_nested_indices
hpcflow.sdk.core.utils.get_process_stamp
hpcflow.sdk.core.utils.get_relative_path
hpcflow.sdk.core.utils.get_time_stamp
hpcflow.sdk.core.utils.group_by_dict_key_values
hpcflow.sdk.core.utils.is_fsspec_url
hpcflow.sdk.core.utils.linspace_rect
hpcflow.sdk.core.utils.list_to_dict
hpcflow.sdk.core.utils.make_workflow_id
hpcflow.sdk.core.utils.normalise_timestamp
hpcflow.sdk.core.utils.nth_key
hpcflow.sdk.core.utils.nth_value
hpcflow.sdk.core.utils.open_file
hpcflow.sdk.core.utils.open_text_resource
hpcflow.sdk.core.utils.parse_timestamp
hpcflow.sdk.core.utils.process_string_nodes
hpcflow.sdk.core.utils.read_JSON_file
hpcflow.sdk.core.utils.read_JSON_string
hpcflow.sdk.core.utils.read_YAML_file
hpcflow.sdk.core.utils.read_YAML_str
hpcflow.sdk.core.utils.redirect_std_to_file
hpcflow.sdk.core.utils.remap
hpcflow.sdk.core.utils.remove_ansi_escape_sequences
hpcflow.sdk.core.utils.replace_items
hpcflow.sdk.core.utils.reshape
hpcflow.sdk.core.utils.search_dir_files_by_regex
hpcflow.sdk.core.utils.set_in_container
hpcflow.sdk.core.utils.split_param_label
hpcflow.sdk.core.utils.substitute_string_vars
hpcflow.sdk.core.utils.swap_nested_dict_keys
hpcflow.sdk.core.utils.timedelta_format
hpcflow.sdk.core.utils.timedelta_parse
hpcflow.sdk.core.utils.to_thread
hpcflow.sdk.core.utils.write_JSON_file
hpcflow.sdk.core.utils.write_YAML_file
hpcflow.sdk.core.utils.JSONLikeDirSnapShot
hpcflow.sdk.core.utils.PrettyPrinter
hpcflow.sdk.core.validation
hpcflow.sdk.core.validation.get_schema
hpcflow.sdk.core.validation.Condition
hpcflow.sdk.core.validation.PreparedConditionCallable
hpcflow.sdk.core.validation.Rule
hpcflow.sdk.core.validation.Schema
hpcflow.sdk.core.validation.ValidatedData
hpcflow.sdk.core.workflow
hpcflow.sdk.core.workflow.load_workflow_config
hpcflow.sdk.core.workflow.resolve_fsspec
hpcflow.sdk.core.workflow.Workflow
hpcflow.sdk.core.workflow.WorkflowBlueprint
hpcflow.sdk.core.workflow.WorkflowTemplate
hpcflow.sdk.core.zarr_io
hpcflow.sdk.core.zarr_io.PRIMITIVES
hpcflow.sdk.core.zarr_io.MAX_DEPTH
hpcflow.sdk.core.zarr_io.zarr_decode
hpcflow.sdk.core.zarr_io.zarr_encode
hpcflow.sdk.core.zarr_io.ZarrEncodable
hpcflow.sdk.data
hpcflow.sdk.demo
hpcflow.sdk.demo.cli
hpcflow.sdk.demo.cli.get_demo_software_CLI
hpcflow.sdk.demo.cli.get_demo_workflow_CLI
hpcflow.sdk.helper
hpcflow.sdk.helper.cli
hpcflow.sdk.helper.cli.timeout_option
hpcflow.sdk.helper.cli.timeout_check_interval_option
hpcflow.sdk.helper.cli.watch_interval_option
hpcflow.sdk.helper.cli.get_helper_CLI
hpcflow.sdk.helper.helper
hpcflow.sdk.helper.helper.clear_helper
hpcflow.sdk.helper.helper.get_PID_file_path
hpcflow.sdk.helper.helper.get_helper_PID
hpcflow.sdk.helper.helper.get_helper_log_path
hpcflow.sdk.helper.helper.get_helper_logger
hpcflow.sdk.helper.helper.get_helper_uptime
hpcflow.sdk.helper.helper.get_helper_watch_list
hpcflow.sdk.helper.helper.get_watcher_file_path
hpcflow.sdk.helper.helper.helper_timeout
hpcflow.sdk.helper.helper.kill_proc_tree
hpcflow.sdk.helper.helper.restart_helper
hpcflow.sdk.helper.helper.run_helper
hpcflow.sdk.helper.helper.start_helper
hpcflow.sdk.helper.helper.stop_helper
hpcflow.sdk.helper.watcher
hpcflow.sdk.helper.watcher.MonitorController
hpcflow.sdk.helper.watcher.WorkflowMonitor
hpcflow.sdk.log
hpcflow.sdk.log.AppLog
hpcflow.sdk.log.TimeIt
hpcflow.sdk.persistence
hpcflow.sdk.persistence.store_cls_from_str
hpcflow.sdk.persistence.base
hpcflow.sdk.persistence.base.SerFormT
hpcflow.sdk.persistence.base.ContextT
hpcflow.sdk.persistence.base.update_param_source_dict
hpcflow.sdk.persistence.base.writes_parameter_data
hpcflow.sdk.persistence.base.PersistentStore
hpcflow.sdk.persistence.base.PersistentStoreFeatures
hpcflow.sdk.persistence.base.StoreEAR
hpcflow.sdk.persistence.base.StoreElement
hpcflow.sdk.persistence.base.StoreElementIter
hpcflow.sdk.persistence.base.StoreParameter
hpcflow.sdk.persistence.base.StoreTask
hpcflow.sdk.persistence.defaults
hpcflow.sdk.persistence.defaults.DEFAULT_STORE_FORMAT
hpcflow.sdk.persistence.discovery
hpcflow.sdk.persistence.discovery.ALL_STORE_FORMATS
hpcflow.sdk.persistence.discovery.ALL_CREATE_STORE_FORMATS
hpcflow.sdk.persistence.discovery.store_cls_from_str
hpcflow.sdk.persistence.json
hpcflow.sdk.persistence.json.JSONPersistentStore
hpcflow.sdk.persistence.json.JsonStoreEAR
hpcflow.sdk.persistence.json.JsonStoreElement
hpcflow.sdk.persistence.json.JsonStoreElementIter
hpcflow.sdk.persistence.json.JsonStoreTask
hpcflow.sdk.persistence.pending
hpcflow.sdk.persistence.pending.CommitResourceMap
hpcflow.sdk.persistence.pending.PendingChanges
hpcflow.sdk.persistence.store_resource
hpcflow.sdk.persistence.store_resource.JSONFileStoreResource
hpcflow.sdk.persistence.store_resource.StoreResource
hpcflow.sdk.persistence.store_resource.ZarrAttrsStoreResource
hpcflow.sdk.persistence.types
hpcflow.sdk.persistence.types.AnySTask
hpcflow.sdk.persistence.types.AnySElement
hpcflow.sdk.persistence.types.AnySElementIter
hpcflow.sdk.persistence.types.AnySEAR
hpcflow.sdk.persistence.types.AnySParameter
hpcflow.sdk.persistence.types.ParameterTypes
hpcflow.sdk.persistence.types.ElemMeta
hpcflow.sdk.persistence.types.EncodedStoreParameter
hpcflow.sdk.persistence.types.File
hpcflow.sdk.persistence.types.FileDescriptor
hpcflow.sdk.persistence.types.IterMeta
hpcflow.sdk.persistence.types.LoopDescriptor
hpcflow.sdk.persistence.types.Metadata
hpcflow.sdk.persistence.types.PersistenceCache
hpcflow.sdk.persistence.types.RunMeta
hpcflow.sdk.persistence.types.StoreCreationInfo
hpcflow.sdk.persistence.types.TaskMeta
hpcflow.sdk.persistence.types.TemplateMeta
hpcflow.sdk.persistence.types.TypeLookup
hpcflow.sdk.persistence.types.ZarrAttrsDict
hpcflow.sdk.persistence.utils
hpcflow.sdk.persistence.utils.ask_pw_on_auth_exc
hpcflow.sdk.persistence.utils.infer_store
hpcflow.sdk.persistence.zarr
hpcflow.sdk.persistence.zarr.ListAny
hpcflow.sdk.persistence.zarr.ZarrAttrs
hpcflow.sdk.persistence.zarr.append_items_to_ragged_array
hpcflow.sdk.persistence.zarr.ZarrPersistentStore
hpcflow.sdk.persistence.zarr.ZarrStoreEAR
hpcflow.sdk.persistence.zarr.ZarrStoreElement
hpcflow.sdk.persistence.zarr.ZarrStoreElementIter
hpcflow.sdk.persistence.zarr.ZarrStoreParameter
hpcflow.sdk.persistence.zarr.ZarrStoreTask
hpcflow.sdk.persistence.zarr.ZarrZipPersistentStore
hpcflow.sdk.runtime
hpcflow.sdk.runtime.RunTimeInfo
hpcflow.sdk.submission
hpcflow.sdk.submission.enums
hpcflow.sdk.submission.enums.JobscriptElementState
hpcflow.sdk.submission.enums.SubmissionStatus
hpcflow.sdk.submission.jobscript
hpcflow.sdk.submission.jobscript.generate_EAR_resource_map
hpcflow.sdk.submission.jobscript.group_resource_map_into_jobscripts
hpcflow.sdk.submission.jobscript.is_jobscript_array
hpcflow.sdk.submission.jobscript.merge_jobscripts_across_tasks
hpcflow.sdk.submission.jobscript.resolve_jobscript_blocks
hpcflow.sdk.submission.jobscript.resolve_jobscript_dependencies
hpcflow.sdk.submission.jobscript.Jobscript
hpcflow.sdk.submission.jobscript.JobscriptBlock
hpcflow.sdk.submission.schedulers
hpcflow.sdk.submission.schedulers.JSRefType
hpcflow.sdk.submission.schedulers.QueuedScheduler
hpcflow.sdk.submission.schedulers.Scheduler
hpcflow.sdk.submission.schedulers.direct
hpcflow.sdk.submission.schedulers.direct.DirectPosix
hpcflow.sdk.submission.schedulers.direct.DirectScheduler
hpcflow.sdk.submission.schedulers.direct.DirectWindows
hpcflow.sdk.submission.schedulers.sge
hpcflow.sdk.submission.schedulers.sge.SGEPosix
hpcflow.sdk.submission.schedulers.slurm
hpcflow.sdk.submission.schedulers.slurm.SlurmPosix
hpcflow.sdk.submission.schedulers.utils
hpcflow.sdk.submission.schedulers.utils.run_cmd
hpcflow.sdk.submission.shells
hpcflow.sdk.submission.shells.ALL_SHELLS
hpcflow.sdk.submission.shells.DEFAULT_SHELL_NAMES
hpcflow.sdk.submission.shells.get_shell
hpcflow.sdk.submission.shells.get_supported_shells
hpcflow.sdk.submission.shells.base
hpcflow.sdk.submission.shells.base.Shell
hpcflow.sdk.submission.shells.bash
hpcflow.sdk.submission.shells.bash.Bash
hpcflow.sdk.submission.shells.bash.WSLBash
hpcflow.sdk.submission.shells.os_version
hpcflow.sdk.submission.shells.os_version.get_OS_info
hpcflow.sdk.submission.shells.os_version.get_OS_info_POSIX
hpcflow.sdk.submission.shells.os_version.get_OS_info_windows
hpcflow.sdk.submission.shells.powershell
hpcflow.sdk.submission.shells.powershell.WindowsPowerShell
hpcflow.sdk.submission.submission
hpcflow.sdk.submission.submission.Submission
hpcflow.sdk.submission.types
hpcflow.sdk.submission.types.VersionInfo
hpcflow.sdk.submission.types.JobScriptCreationArguments
hpcflow.sdk.submission.types.JobScriptDescriptor
hpcflow.sdk.submission.types.JobscriptHeaderArgs
hpcflow.sdk.submission.types.ResolvedJobscriptBlockDependencies
hpcflow.sdk.submission.types.SchedulerRef
hpcflow.sdk.submission.types.SubmissionPart
hpcflow.sdk.typing
hpcflow.sdk.typing.PathLike
hpcflow.sdk.typing.BasicTemplateComponents
hpcflow.sdk.typing.DataIndex
hpcflow.sdk.typing.hydrate
hpcflow.sdk.typing.KnownSubmission
hpcflow.sdk.typing.KnownSubmissionItem
hpcflow.sdk.typing.MakeWorkflowCommonArgs
hpcflow.sdk.typing.ParamSource
hpcflow.sdk.typing.TemplateComponents
hpcflow.sdk.demo
hpcflow.sdk.demo
#
Demonstration code.
cli
CLI components for demonstration code.
Edit on GitHub
This Page
Show Source