Les traductions sont fournies par des outils de traduction automatique. En cas de conflit entre le contenu d'une traduction et celui de la version originale en anglais, la version anglaise prévaudra.
AWS Glue API
Cette section décrit les types de données et les primitives utilisés par les AWS Glue SDK et les outils. Il existe trois méthodes générales d'interaction AWS Glue programmatique en dehors du AWS Management Console, chacune avec sa propre documentation :
-
Les bibliothèques SDK linguistiques vous permettent d'accéder aux ressources AWS provenant de langages de programmation courants. Pour plus d'informations, consultez Outils pour créer sur AWS
. -
Vous AWS CLI permet d'accéder aux AWS ressources depuis la ligne de commande. Pour plus d'informations, consultez Référence des commandes AWS CLI.
-
AWS CloudFormation vous permet de définir un ensemble de AWS ressources à provisionner ensemble de manière cohérente. Pour plus d'informations, consultez AWS CloudFormation: référence AWS Glue des types de ressources.
Cette section documente les primitives partagées indépendamment de ces kits SDK et outils. Les outils utilisent le AWS Glue Web API Reference pour communiquer avec AWS.
Table des matières
- API de sécurité dans AWS Glue
- Types de données
- DataCatalogEncryptionSettings structure
- EncryptionAtRest structure
- ConnectionPasswordEncryption structure
- EncryptionConfiguration structure
- Structure S3Encryption
- CloudWatchEncryption structure
- JobBookmarksEncryption structure
- SecurityConfiguration structure
- GluePolicy structure
- Opérations
- GetDataCatalogEncryptionSettings action (Python : get_data_catalog_encryption_settings)
- PutDataCatalogEncryptionSettings action (Python : put_data_catalog_encryption_settings)
- PutResourcePolicy action (Python : put_resource_policy)
- GetResourcePolicy action (Python : get_resource_policy)
- DeleteResourcePolicy action (Python : delete_resource_policy)
- CreateSecurityConfiguration action (Python : create_security_configuration)
- DeleteSecurityConfiguration action (Python : delete_security_configuration)
- GetSecurityConfiguration action (Python : get_security_configuration)
- GetSecurityConfigurations action (Python : get_security_configurations)
- GetResourcePolicies action (Python : get_resource_policies)
- Catalogue API
- API d'une base de données
- Types de données
- Structure Database
- DatabaseInput structure
- PrincipalPermissions structure
- DataLakePrincipal structure
- DatabaseIdentifier structure
- FederatedDatabase structure
- Opérations
- CreateDatabase action (Python : créer_base de données)
- UpdateDatabase action (Python : update_database)
- DeleteDatabase action (Python : supprimer_base de données)
- GetDatabase action (Python : get_database)
- GetDatabases action (Python : get_databases)
- Tableau API
- Types de données
- Structure de table
- TableInput structure
- FederatedTable structure
- Structure de colonne
- StorageDescriptor structure
- SchemaReference structure
- SerDeInfo structure
- Structure de tri
- SkewedInfo structure
- TableVersion structure
- TableError structure
- TableVersionError structure
- SortCriterion structure
- TableIdentifier structure
- KeySchemaElement structure
- PartitionIndex structure
- PartitionIndexDescriptor structure
- BackfillError structure
- IcebergInput structure
- OpenTableFormatInput structure
- ViewDefinition structure
- ViewDefinitionInput structure
- ViewRepresentation structure
- ViewRepresentationInput structure
- Opérations
- CreateTable action (Python : créer_table)
- UpdateTable action (Python : update_table)
- DeleteTable action (Python : supprimer_table)
- BatchDeleteTable action (Python : batch_delete_table)
- GetTable action (Python : get_table)
- GetTables action (Python : get_tables)
- GetTableVersion action (Python : get_table_version)
- GetTableVersions action (Python : get_table_versions)
- DeleteTableVersion action (Python : supprimer_table_version)
- BatchDeleteTableVersion action (Python : batch_delete_table_version)
- SearchTables action (Python : tables de recherche)
- GetPartitionIndexes action (Python : get_partition_indexes)
- CreatePartitionIndex action (Python : create_partition_index)
- DeletePartitionIndex action (Python : delete_partition_index)
- GetColumnStatisticsForTable action (Python : get_column_statistics_for_table)
- UpdateColumnStatisticsForTable action (Python : update_column_statistics_for_table)
- DeleteColumnStatisticsForTable action (Python : delete_column_statistics_for_table)
- API de partition
- Types de données
- Structure de partition
- PartitionInput structure
- PartitionSpecWithSharedStorageDescriptor structure
- PartitionListComposingSpec structure
- PartitionSpecProxy structure
- PartitionValueList structure
- Structure d'un segment
- PartitionError structure
- BatchUpdatePartitionFailureEntry structure
- BatchUpdatePartitionRequestEntry structure
- StorageDescriptor structure
- SchemaReference structure
- SerDeInfo structure
- SkewedInfo structure
- Opérations
- CreatePartition action (Python : créer_partition)
- BatchCreatePartition action (Python : batch_create_partition)
- UpdatePartition action (Python : update_partition)
- DeletePartition action (Python : supprimer_partition)
- BatchDeletePartition action (Python : batch_supprimer_partition)
- GetPartition action (Python : get_partition)
- GetPartitions action (Python : get_partitions)
- BatchGetPartition action (Python : batch_get_partition)
- BatchUpdatePartition action (Python : batch_update_partition)
- GetColumnStatisticsForPartition action (Python : get_column_statistics_for_partition)
- UpdateColumnStatisticsForPartition action (Python : update_column_statistics_for_partition)
- DeleteColumnStatisticsForPartition action (Python : supprimer_column_statistics_for_partition)
- Raccordement API
- Types de données
- Structure de connexion
- ConnectionInput structure
- PhysicalConnectionRequirements structure
- GetConnectionsFilter structure
- Opérations
- CreateConnection action (Python : créer_connexion)
- DeleteConnection action (Python : supprimer_connexion)
- GetConnection action (Python : get_connection)
- GetConnections action (Python : get_connections)
- UpdateConnection action (Python : update_connection)
- BatchDeleteConnection action (Python : batch_delete_connection)
- Configuration de l'authentification
- AuthenticationConfiguration structure
- AuthenticationConfigurationInput structure
- OAuth2Propertiesstructure
- OAuth2PropertiesInputstructure
- OAuth2ClientApplicationstructure
- AuthorizationCodeProperties structure
- API de fonction définie par l'utilisateur
- Types de données
- Structure UserDefinedFunction
- Structure UserDefinedFunctionInput
- Opérations
- Action CreateUserDefinedFunction (Python : create_user_defined_function)
- Action UpdateUserDefinedFunction (Python : update_user_defined_function)
- Action DeleteUserDefinedFunction (Python : delete_user_defined_function)
- Action GetUserDefinedFunction (Python : get_user_defined_function)
- Action GetUserDefinedFunctions (Python : get_user_defined_functions)
- Importation d'un catalogue Athena vers AWS Glue
- API d'une base de données
- Optimiseur de tables API
- Types de données
- TableOptimizer structure
- TableOptimizerConfiguration structure
- TableOptimizerRun structure
- BatchGetTableOptimizerEntry structure
- BatchTableOptimizer structure
- BatchGetTableOptimizerError structure
- RetentionConfiguration structure
- IcebergRetentionConfiguration structure
- OrphanFileDeletionConfiguration structure
- IcebergOrphanFileDeletionConfiguration structure
- CompactionMetrics structure
- RetentionMetrics structure
- OrphanFileDeletionMetrics structure
- IcebergCompactionMetrics structure
- IcebergRetentionMetrics structure
- IcebergOrphanFileDeletionMetrics structure
- RunMetrics structure
- Opérations
- GetTableOptimizer action (Python : get_table_optimizer)
- BatchGetTableOptimizer action (Python : batch_get_table_optimizer)
- ListTableOptimizerRuns action (Python : list_table_optimizer_runs)
- CreateTableOptimizer action (Python : create_table_optimizer)
- DeleteTableOptimizer action (Python : delete_table_optimizer)
- UpdateTableOptimizer action (Python : update_table_optimizer)
- API de classifieurs et d'crawlers
- API du classifieur
- Types de données
- Structure du classifieur
- Structure du GrokClassifier
- Structure du XMLClassifier
- Structure du JsonClassifier
- Structure du CsvClassifier
- Structure de CreateGrokClassifierRequest
- Structure de UpdateGrokClassifierRequest
- Structure de CreateXMLClassifierRequest
- Structure de UpdateXMLClassifierRequest
- Structure de CreateJsonClassifierRequest
- Structure de UpdateJsonClassifierRequest
- Structure de CreateCsvClassifierRequest
- Structure de UpdateCsvClassifierRequest
- Opérations
- Action CreateClassifier (Python : create_classifier)
- Action DeleteClassifier (Python : delete_classifier)
- Action GetClassifier (Python : get_classifier)
- Action GetClassifiers (Python : get_classifiers)
- Action UpdateClassifier (Python : update_classifier)
- chenille API
- Types de données
- Structure du crawler
- Structure du planificateur
- CrawlerTargets structure
- Structure de la S3Target
- DeltaCatalogTarget Structure S3
- DeltaDirectTarget Structure S3
- JdbcTarget structure
- ongoDBTarget Structure en M
- ynamoDBTarget Structure en D
- DeltaTarget structure
- IcebergTarget structure
- HudiTarget structure
- CatalogTarget structure
- CrawlerMetrics structure
- CrawlerHistory structure
- CrawlsFilter structure
- SchemaChangePolicy structure
- LastCrawlInfo structure
- RecrawlPolicy structure
- LineageConfiguration structure
- LakeFormationConfiguration structure
- Opérations
- CreateCrawler action (Python : create_crawler)
- DeleteCrawler action (Python : delete_crawler)
- GetCrawler action (Python : get_crawler)
- GetCrawlers action (Python : get_crawlers)
- GetCrawlerMetrics action (Python : get_crawler_metrics)
- UpdateCrawler action (Python : update_crawler)
- StartCrawler action (Python : start_crawler)
- StopCrawler action (Python : stop_crawler)
- BatchGetCrawlers action (Python : batch_get_crawlers)
- ListCrawlers action (Python : list_crawlers)
- ListCrawls action (Python : list_crawls)
- API de statistiques de colonne
- Types de données
- Structure ColumnStatisticsTaskRun
- Structure ColumnStatisticsTaskRunningException
- Structure ColumnStatisticsTaskNotRunningException
- Structure ColumnStatisticsTaskStoppingException
- Opérations
- Action StartColumnStatisticsTaskRun (Python : start_column_statistics_task_run)
- Action GetColumnStatisticsTaskRun (Python : get_column_statistics_task_run)
- Action GetColumnStatisticsTaskRuns (Python : get_column_statistics_task_runs)
- Action ListColumnStatisticsTaskRuns (Python : list_column_statistics_task_runs)
- Action StopColumnStatisticsTaskRun (Python : stop_column_statistics_task_run)
- API du planificateur du crawler
- API du classifieur
- Génération automatique d'API de scripts ETL
- Types de données
- Structure CodeGenNode
- Structure CodeGenNodeArg
- Structure CodeGenEdge
- Structure de l'emplacement
- Structure CatalogEntry
- Structure MappingEntry
- Opérations
- Action CreateScript (Python : create_script)
- Action GetDataflowGraph (Python : get_dataflow_graph)
- Action GetMapping (Python : get_mapping)
- Action GetPlan (Python : get_plan)
- Travail visuel API
- Types de données
- CodeGenConfigurationNode structure
- JDBCConnectorOptionsstructure
- StreamingDataPreviewOptions structure
- AthenaConnectorSource structure
- JDBCConnectorSourcestructure
- SparkConnectorSource structure
- CatalogSource structure
- M Structure ySQLCatalog de la source
- P Structure ostgreSQLCatalog de la source
- O Structure racleSQLCatalog de la source
- icrosoftSQLServerCatalogSource Structure en M
- CatalogKinesisSource structure
- DirectKinesisSource structure
- KinesisStreamingSourceOptions structure
- CatalogKafkaSource structure
- DirectKafkaSource structure
- KafkaStreamingSourceOptions structure
- RedshiftSource structure
- AmazonRedshiftSource structure
- AmazonRedshiftNodeData structure
- AmazonRedshiftAdvancedOption structure
- Structure de l'option
- CatalogSource Structure S3
- SourceAdditionalOptions Structure S3
- CsvSource Structure S3
- irectJDBCSource Structure en D
- DirectSourceAdditionalOptions Structure S3
- JsonSource Structure S3
- ParquetSource Structure S3
- DeltaSource Structure S3
- CatalogDeltaSource Structure S3
- CatalogDeltaSource structure
- HudiSource Structure S3
- CatalogHudiSource Structure S3
- CatalogHudiSource structure
- D Structure ynamoDBCatalog de la source
- RelationalCatalogSource structure
- JDBCConnectorTargetstructure
- SparkConnectorTarget structure
- BasicCatalogTarget structure
- M Structure de la ySQLCatalog cible
- P Structure de la ostgreSQLCatalog cible
- O Structure racleSQLCatalog cible
- icrosoftSQLServerCatalogTarget Structure en M
- RedshiftTarget structure
- AmazonRedshiftTarget structure
- UpsertRedshiftTargetOptions structure
- CatalogTarget Structure S3
- GlueParquetTarget Structure S3
- CatalogSchemaChangePolicy structure
- DirectTarget Structure S3
- HudiCatalogTarget Structure S3
- HudiDirectTarget Structure S3
- DeltaCatalogTarget Structure S3
- DeltaDirectTarget Structure S3
- DirectSchemaChangePolicy structure
- ApplyMapping structure
- Structure de mappage
- SelectFields structure
- DropFields structure
- RenameField structure
- Structure Spigot
- Structure Join
- JoinColumn structure
- SplitFields structure
- SelectFromCollection structure
- FillMissingValues structure
- Structure Filtre
- FilterExpression structure
- FilterValue structure
- CustomCode structure
- SQLStructure Spark
- SqlAlias structure
- DropNullFields structure
- NullCheckBoxList structure
- NullValueField structure
- Structure Datatype
- Structure Fusion
- Structure Union
- PIIDetectionstructure
- Structure Aggregate
- DropDuplicates structure
- GovernedCatalogTarget structure
- GovernedCatalogSource structure
- AggregateOperation structure
- GlueSchema structure
- GlueStudioSchemaColumn structure
- GlueStudioColumn structure
- DynamicTransform structure
- TransformConfigParameter structure
- EvaluateDataQuality structure
- DQResultsPublishingOptionsstructure
- DQStopJobOnFailureOptionsstructure
- EvaluateDataQualityMultiFrame structure
- Structure de la recette
- RecipeReference structure
- SnowflakeNodeData structure
- SnowflakeSource structure
- SnowflakeTarget structure
- ConnectorDataSource structure
- ConnectorDataTarget structure
- RecipeStep structure
- RecipeAction structure
- ConditionExpression structure
- API de tâches
- Tâches
- Types de données
- Structure Job
- ExecutionProperty structure
- NotificationProperty structure
- JobCommand structure
- ConnectionsList structure
- JobUpdate structure
- SourceControlDetails structure
- Opérations
- CreateJob action (Python : create_job)
- UpdateJob action (Python : update_job)
- GetJob action (Python : get_job)
- GetJobs action (Python : get_jobs)
- DeleteJob action (Python : supprimer_tâche)
- ListJobs action (Python : list_jobs)
- BatchGetJobs action (Python : batch_get_jobs)
- Exécutions de tâches
- Types de données
- JobRun structure
- Structure de Predecessor
- JobBookmarkEntry structure
- BatchStopJobRunSuccessfulSubmission structure
- BatchStopJobRunError structure
- NotificationProperty structure
- Opérations
- StartJobRun action (Python : start_job_run)
- BatchStopJobRun action (Python : batch_stop_job_run)
- GetJobRun action (Python : get_job_run)
- GetJobRuns action (Python : get_job_runs)
- GetJobBookmark action (Python : get_job_bookmark)
- GetJobBookmarks action (Python : get_job_bookmarks)
- ResetJobBookmark action (Python : reset_job_bookmark)
- Déclencheurs
- Types de données
- Structure Trigger
- TriggerUpdate structure
- Structure Predicate
- Structure Condition
- Structure Action
- EventBatchingCondition structure
- Opérations
- CreateTrigger action (Python : create_trigger)
- StartTrigger action (Python : start_trigger)
- GetTrigger action (Python : get_trigger)
- GetTriggers action (Python : get_triggers)
- UpdateTrigger action (Python : update_trigger)
- StopTrigger action (Python : stop_trigger)
- DeleteTrigger action (Python : delete_trigger)
- ListTriggers action (Python : list_triggers)
- BatchGetTriggers action (Python : batch_get_triggers)
- Tâches
- Séances interactives API
- Types de données
- Structure de séance
- SessionCommand structure
- Structure de la déclaration
- StatementOutput structure
- StatementOutputData structure
- ConnectionsList structure
- Opérations
- CreateSession action (Python : créer_session)
- StopSession action (Python : stop_session)
- DeleteSession action (Python : supprimer_session)
- GetSession action (Python : get_session)
- ListSessions action (Python : list_sessions)
- RunStatement action (Python : run_statement)
- CancelStatement action (Python : annuler_statement)
- GetStatement action (Python : get_statement)
- ListStatements action (Python : list_statements)
- API de points de terminaison de développement
- Types de données
- DevEndpoint structure
- DevEndpointCustomLibraries structure
- Opérations
- CreateDevEndpoint action (Python : create_dev_endpoint)
- UpdateDevEndpoint action (Python : update_dev_endpoint)
- DeleteDevEndpoint action (Python : delete_dev_endpoint)
- GetDevEndpoint action (Python : get_dev_endpoint)
- GetDevEndpoints action (Python : get_dev_endpoints)
- BatchGetDevEndpoints action (Python : batch_get_dev_endpoints)
- ListDevEndpoints action (Python : list_dev_endpoints)
- Registre de schémas
- Types de données
- RegistryId structure
- RegistryListItem structure
- MetadataInfo structure
- OtherMetadataValueListItem structure
- SchemaListItem structure
- SchemaVersionListItem structure
- MetadataKeyValuePair structure
- SchemaVersionErrorItem structure
- ErrorDetails structure
- SchemaVersionNumber structure
- SchemaId structure
- Opérations
- CreateRegistry action (Python : create_registry)
- CreateSchema action (Python : créer_schéma)
- GetSchema action (Python : get_schema)
- ListSchemaVersions action (Python : list_schema_versions)
- GetSchemaVersion action (Python : get_schema_version)
- GetSchemaVersionsDiff action (Python : get_schema_versions_diff)
- ListRegistries action (Python : list_registries)
- ListSchemas action (Python : list_schemas)
- RegisterSchemaVersion action (Python : register_schema_version)
- UpdateSchema action (Python : update_schema)
- CheckSchemaVersionValidity action (Python : check_schema_version_validity)
- UpdateRegistry action (Python : update_registry)
- GetSchemaByDefinition action (Python : get_schema_by_definition)
- GetRegistry action (Python : get_registry)
- PutSchemaVersionMetadata action (Python : put_schema_version_metadata)
- QuerySchemaVersionMetadata action (Python : query_schema_version_metadata)
- RemoveSchemaVersionMetadata action (Python : remove_schema_version_metadata)
- DeleteRegistry action (Python : supprimer_registre)
- DeleteSchema action (Python : supprimer_schéma)
- DeleteSchemaVersions action (Python : delete_schema_versions)
- Flux de travail
- Types de données
- JobNodeDetails structure
- CrawlerNodeDetails structure
- TriggerNodeDetails structure
- Structure Crawl
- Structure de nœud
- Structure Edge
- Structure de flux de travail
- WorkflowGraph structure
- WorkflowRun structure
- WorkflowRunStatistics structure
- StartingEventBatchCondition structure
- Structure du plan
- BlueprintDetails structure
- LastActiveDefinition structure
- BlueprintRun structure
- Opérations
- CreateWorkflow action (Python : create_workflow)
- UpdateWorkflow action (Python : update_workflow)
- DeleteWorkflow action (Python : delete_workflow)
- GetWorkflow action (Python : get_workflow)
- ListWorkflows action (Python : list_workflows)
- BatchGetWorkflows action (Python : batch_get_workflows)
- GetWorkflowRun action (Python : get_workflow_run)
- GetWorkflowRuns action (Python : get_workflow_runs)
- GetWorkflowRunProperties action (Python : get_workflow_run_properties)
- PutWorkflowRunProperties action (Python : put_workflow_run_properties)
- CreateBlueprint action (Python : créer_blueprint)
- UpdateBlueprint action (Python : update_blueprint)
- DeleteBlueprint action (Python : delete_blueprint)
- ListBlueprints action (Python : list_blueprints)
- BatchGetBlueprints action (Python : batch_get_blueprints)
- StartBlueprintRun action (Python : start_blueprint_run)
- GetBlueprintRun action (Python : get_blueprint_run)
- GetBlueprintRuns action (Python : get_blueprint_runs)
- StartWorkflowRun action (Python : start_workflow_run)
- StopWorkflowRun action (Python : stop_workflow_run)
- ResumeWorkflowRun action (Python : resume_workflow_run)
- Profils d'utilisation
- Types de données
- ProfileConfiguration structure
- ConfigurationObject structure
- UsageProfileDefinition structure
- Opérations
- CreateUsageProfile action (Python : create_usage_profile)
- GetUsageProfile action (Python : get_usage_profile)
- UpdateUsageProfile action (Python : update_usage_profile)
- DeleteUsageProfile action (Python : delete_usage_profile)
- ListUsageProfiles action (Python : list_usage_profiles)
- API de Machine Learning
- Types de données
- TransformParameters structure
- EvaluationMetrics structure
- Structure MLTransform
- FindMatchesParameters structure
- FindMatchesMetrics structure
- ConfusionMatrix structure
- GlueTable structure
- TaskRun structure
- TransformFilterCriteria structure
- TransformSortCriteria structure
- TaskRunFilterCriteria structure
- TaskRunSortCriteria structure
- TaskRunProperties structure
- FindMatchesTaskRunProperties structure
- ImportLabelsTaskRunProperties structure
- ExportLabelsTaskRunProperties structure
- LabelingSetGenerationTaskRunProperties structure
- SchemaColumn structure
- TransformEncryption structure
- UserDataEncryption Structure du ML
- ColumnImportance structure
- Opérations
- CreateMLTransform Action (Python : create_ml_transform)
- Action UpdateMLTransform (Python : update_ml_transform)
- Action DeleteMLTransform (Python : delete_ml_transform)
- Action GetMLTransform (Python : get_ml_transform)
- Action GetMLTransforms (Python : get_ml_transforms)
- ListMLTransforms Action (Python: list_ml_transforms)
- EvaluationTaskRun Action StartML (Python : start_ml_evaluation_task_run)
- LabelingSetGenerationTaskRun Action StartML (Python : start_ml_labeling_set_generation_task_run)
- TaskRun Action GetML (Python : get_ml_task_run)
- TaskRuns Action GetML (Python : get_ml_task_runs)
- TaskRun Action CancelML (Python : cancel_ml_task_run)
- StartExportLabelsTaskRun action (Python : start_export_labels_task_run)
- StartImportLabelsTaskRun action (Python : start_import_labels_task_run)
- Qualité des données API
- Types de données
- DataSource structure
- DataQualityRulesetListDetails structure
- DataQualityTargetTable structure
- DataQualityRulesetEvaluationRunDescription structure
- DataQualityRulesetEvaluationRunFilter structure
- DataQualityEvaluationRunAdditionalRunOptions structure
- DataQualityRuleRecommendationRunDescription structure
- DataQualityRuleRecommendationRunFilter structure
- DataQualityResult structure
- DataQualityAnalyzerResult structure
- DataQualityObservation structure
- MetricBasedObservation structure
- DataQualityMetricValues structure
- DataQualityRuleResult structure
- DataQualityResultDescription structure
- DataQualityResultFilterCriteria structure
- DataQualityRulesetFilterCriteria structure
- StatisticAnnotation structure
- TimestampedInclusionAnnotation structure
- AnnotationError structure
- DatapointInclusionAnnotation structure
- StatisticSummaryList liste
- StatisticSummary structure
- RunIdentifier structure
- StatisticModelResult structure
- Opérations
- StartDataQualityRulesetEvaluationRun action (Python : start_data_quality_ruleset_evaluation_run)
- CancelDataQualityRulesetEvaluationRun action (Python : cancel_data_quality_ruleset_evaluation_run)
- GetDataQualityRulesetEvaluationRun action (Python : get_data_quality_ruleset_evaluation_run)
- ListDataQualityRulesetEvaluationRuns action (Python : list_data_quality_ruleset_evaluation_runs)
- StartDataQualityRuleRecommendationRun action (Python : start_data_quality_rule_recommendation_run)
- CancelDataQualityRuleRecommendationRun action (Python : cancel_data_quality_rule_recommendation_run)
- GetDataQualityRuleRecommendationRun action (Python : get_data_quality_rule_recommendation_run)
- ListDataQualityRuleRecommendationRuns action (Python : list_data_quality_rule_recommendation_runs)
- GetDataQualityResult action (Python : get_data_quality_result)
- BatchGetDataQualityResult action (Python : batch_get_data_quality_result)
- ListDataQualityResults action (Python : list_data_quality_results)
- CreateDataQualityRuleset action (Python : create_data_quality_ruleset)
- DeleteDataQualityRuleset action (Python : delete_data_quality_ruleset)
- GetDataQualityRuleset action (Python : get_data_quality_ruleset)
- ListDataQualityRulesets action (Python : list_data_quality_rulesets)
- UpdateDataQualityRuleset action (Python : update_data_quality_ruleset)
- ListDataQualityStatistics action (Python : list_data_quality_statistics)
- TimestampFilter structure
- CreateDataQualityRulesetRequest structure
- GetDataQualityRulesetResponse structure
- GetDataQualityResultResponse structure
- StartDataQualityRuleRecommendationRunRequest structure
- GetDataQualityRuleRecommendationRunResponse structure
- BatchPutDataQualityStatisticAnnotation action (Python : batch_put_data_quality_statistic_annotation)
- GetDataQualityModel action (Python : get_data_quality_model)
- GetDataQualityModelResult action (Python : get_data_quality_model_result)
- ListDataQualityStatisticAnnotations action (Python : list_data_quality_statistic_annotations)
- PutDataQualityProfileAnnotation action (Python : put_data_quality_profile_annotation)
- API Détection des données sensibles
- Types de données
- Structure CustomEntityType
- Opérations
- Action CreateCustomEntityType (Python : create_custom_entity_type)
- Action DeleteCustomEntityType (Python : delete_custom_entity_type)
- Action GetCustomEntityType (Python : get_custom_entity_type)
- Action BatchGetCustomEntityTypes (Python : batch_get_custom_entity_types)
- Action ListCustomEntityTypes (Python : list_custom_entity_types)
- API de balisage dans AWS Glue
- Types de données courants
- Structure de balise
- DecimalNumber structure
- ErrorDetail structure
- PropertyPredicate structure
- ResourceUri structure
- ColumnStatistics structure
- ColumnStatisticsError structure
- ColumnError structure
- ColumnStatisticsData structure
- BooleanColumnStatisticsData structure
- DateColumnStatisticsData structure
- DecimalColumnStatisticsData structure
- DoubleColumnStatisticsData structure
- LongColumnStatisticsData structure
- StringColumnStatisticsData structure
- BinaryColumnStatisticsData structure
- Modèles de chaîne
- Exceptions
- AccessDeniedException structure
- AlreadyExistsException structure
- ConcurrentModificationException structure
- ConcurrentRunsExceededException structure
- CrawlerNotRunningException structure
- CrawlerRunningException structure
- CrawlerStoppingException structure
- EntityNotFoundException structure
- FederationSourceException structure
- FederationSourceRetryableException structure
- GlueEncryptionException structure
- IdempotentParameterMismatchException structure
- IllegalWorkflowStateException structure
- InternalServiceException structure
- InvalidExecutionEngineException structure
- InvalidInputException structure
- InvalidStateException structure
- InvalidTaskStatusTransitionException structure
- JobDefinitionErrorException structure
- JobRunInTerminalStateException structure
- JobRunInvalidStateTransitionException structure
- JobRunNotInTerminalStateException structure
- LateRunnerException structure
- NoScheduleException structure
- OperationTimeoutException structure
- ResourceNotReadyException structure
- ResourceNumberLimitExceededException structure
- SchedulerNotRunningException structure
- SchedulerRunningException structure
- SchedulerTransitioningException structure
- UnrecognizedRunnerException structure
- ValidationException structure
- VersionMismatchException structure