Databricks Data Engineer Associate Dumps
Databricks Data Engineer Associate Dumps
2#A new data engineering team team. has been assigned to an ELT project. The new data
engineering team will need full privileges on the database customers to fully manage the project.
Which of the following commands can be used to grant full permissions on the database to the
new data engineering team?
3 A data engineer has a Job with multiple tasks that runs nightly. Each of the tasks runs slowly
because the clusters take a long time to start. Which of the following actions can the data
engineer perform to improve the start up time for the clusters used for the Job?
E. They can configure the dlusters to autoscale for larger data sizes
4 #A single Job runs two notebooks as two separate tasks. A data engineer has noticed that
one of the notebooks is running slowly in the Job's current run. The data engineer asks a tech
lead for help in identifying why this might be the case. Which of the following approaches can
the tech lead use to identify why the notebook is running slowly as part of the Job?
A. They can navigate to the Runs tab in the Jobs Ul to immediately review the processing
notebook.
B. They can navigate to the Tasks tab in the Jobs Ul and click on the active run to review the
processing noteboolk.
C. They can navigate to the Runs tab in the Jobs Ul and click on the active run to review the
processing notebook.
E. They can navigate to the Tasks tab in the Jobs Ul to immediately review the processing
notebook.
5 A data engineer has been using a Databricks SOL dashboard to monitor the cleanliness of the
input data to an ELT job. The ELT job has its Databricks SQL query that returns the number of
input records containing unexpected NULL values. The data engineer wants their entire team to
be notified via a messaging webhook whenever this value reaches 100. Which of the following
approaches can the data engineer use to notify their entire team via a messaging webhook
whenever the number of NULL values reaches 100?
6 #A data engineer wants to schedule their Databricks SOL dashboard to refresh once per day,
but they only want the associated SQL endpoint to be running when it is necessary. Which of the
following approaches can the data engineer use to minimize the total running time of the SQL
endpoint used in the refresh schedule of their dashboard?
A. They can ensure the dashboard's SQL endpoint matches each of the queries' SQL endpoints.
B. They can set up the dashboard's SQL endpoint to be serverless.
C. They can turn on the Auto Stop feature for the SQl endpoint.
E. They can ensure the dashboard's SQL endpoint is not one of the included query's SQL
endpoint.
7 # A data analysis team has noticed that their Databricks SOL queries are running too slowly
when connected to their always-on SOL endpoint. They claim that this issue is present when
many members of the team are running small queries simultaneously. They ask the data
engineering team for help. The data engineering team notices that each of the team's queries
uses the same SQL endpoint. Which of the following approaches can the data engineering team
use to improve the latency of the team's queries?
B. They can increase the maximum bound of the SQl endpoint's scaling range.
C. They can turn on the Auto Stop feature for the SQl endpoint.
D. They can turn on the Serverless feature for the SQL endpoint.
E. They can turn on the Serverless feature for the SQL endpoint and change the Spot Instance
Policy to "Reliability Optimized."
8 #An engineering manager wants to monitor the performance of a recent project using a
Databricks SQL query. For the first week following the project's release, the manager wants the
query results to be updated every minute. However, the manager is concerned that the compute
resources used for the query will be left running and cost the organization a lot of money
beyond the first week of the project's release. Which of the following approaches can the
engineering team use to ensure the query does not cost the organization any money beyond the
first week of the project's release?
A. They can set a limit to the number of DBUs that are consumed by the SQL Endpoint.
B. They can set the query's refresh schedule to end after a certain number of refreshes.
C. They cannot ensure the query does not cost the organization money bevond the first week of
the project's release.
D. They can set a limit to the number of individuals that are able to manage the query's refresh
schedule.
E. They can set the query's refresh schedule to end on a certain date in the query scheduler.
9 #A data engineer has a single-task Job that runs each morning before they begin working.
After identifying an upstream data issue, they need to set up another task to run a new
notebook prior to the original task. Which of the following approaches can the data engineer use
to set up the new task?
A. They can clone the existing task in the existing Job and update it to run the new notebook.
B. They can create a new task in the existing Job and then add it as a dependency of the original
task.
C. They can create a new task in the existing Job and then add the original task as a
dependency of the new task.
D. They can create a new job from scratch and add both tasks to run concurently.
E. They can clone the existing task to a new Jah and then edit it to run the new notebook.
10 #A data engineer has three tables in a Delta Live Tables (DLT) pipeline. They have configured
the pipeline to drop invalid records at each table. They notice that some data is being dropped
due to quality concerns at some point in the DLT pipeline. they would like to determine at which
table in their pipeline the data is being dropped. Which of the following approaches can the data
engineer take to identify the table that is dropping the records?
A. They can set up separate expectations for each table when developing their DLT pipeline.
C. They can set up DIT to notify them via email when records are dropped.
D. They can navigate to the DLT pipeline page, click on each table, and view the data quality
statistics.
E. They can navigate to the DlT pipeline page, click on the "Error" button, and review the present
errors.
1.# Which of the following Structured Streaming quertes is performing a hop from a Silver table
to a Gold table?
A.
(spark. readStream. load (rawSalesLocation)
.writeStream
.option("checkpointLocation", checkpointPath)
.outputMode("append")
.table("newSales")
B.
(spark.read.load(rawSalesLocation)
.writestream
.option("checkpointLocation", checkpointPath)
.outputMode ("append")
.table("newSales")
C.
(spark.table("sales")
.filter(col("units")>0)
.writestream
.option("checkpointLocation", checkpointPath)
.outputMode("append")
.table("newSales")
D.
(spark.table("sales")
.writestream
.option("checkpointLocation", checkpointPath)
.outputMode("append")
.table("newSales")
E.
(spark.table("sales")
.groupBy("store").agg(sum("sales")).writestream
.option("checkpointLocation", checkpointPath)
.outputMode("complete")
.table("newSales")
12 # A data engineer is designing a data pipeline. The source system generates files in a shared
directory that is also used by other processes. As a result, the files should be kept as is and will
accumulate in the directory. The data engineer needs to identify which files are new since the
previous run in the pipeline, and set up the pipeline to only ingest those new files with each run.
Which of the following tools can the data engineer use to solve this problem?
A. Unity Catalog
B. Delta Lake
C. Databricks SQL
D. Data Explorer
E. Auto Loader
13 #A dataset has been defined using Delta Live Tables and includes an expectations clause:
What is the expected behavior when a batch of data containing data that violates these
constraints is
processed?
A. Records that violate the expectation are dropped from the target dataset and loaded into a
quarantine table.
B. Records that violate the expectation are added to the target dataset and flagged as invalid in
a field added to the target dataset.
C. Records that violate the expectation are dropped from the target dataset and recorded as
invalid in the event log.
D. Records that violate the expectation are added to the target dataset and recorded as invalid
in the event log.
14 #A data engineer has configured a Structured Streaming job to read from a table, manipulate
the data, and then perform a streaming write into a new table. The cade block used by the data
engineer is below:
(spark.table("sales")
.option("checkpointLocation", checkpointpath)
.outputMode("complete")
._______
.table("new_sales")
If the data engineer only wants the query to execute a micro-batch to process data every 5
seconds,
which of the following lines of code should the data engineer use to fill in the blank?
A. trigger("5 seconds")
B. trigger()
C. trigger(once="5 seconds")
D. trigger(processingTime-"5 seconds")
E. trigger(continuous="5 seconds")
15 # Which of the following tools is used by Auto Loader process data incrementally?
A. Checkpointing
C. Data Explorer
D.Unity Catalog
E. Databricks SQL
16 # Which of the following describes the relationship between Bronze tables and raw data?
D. Bronze tables contain a less refined view of data than raw data.
17 # Which of the following describes the relationship between Gold tables and Silver tables?
A. Gold tables are more likely to contain aggregations than Silver tables.
B. Gold tables are more likely to contain valuable data than Silver tables.
C. Gold tables are more likely to contain a less refined view of data than Silver tables.
D. Gold tables are more likely to contain more data than Silver tables.
E. Gold tables are more likely to contain truthful data than Silver tables.
18 # In order for Structured Streaming to reliably track the exact progress of the processing so
that it can handle any kind of failure by restarting and/or reprocessing, which of the following,
two approaches is used by Spark to record the offset range of the data being processed in each
trigger?
B. Structured Streaming cannot record the offset range of the data being processed in each
trigger.
A.All datasets will be updated at set intervals until the pipeline is shut down. The compute
resources will persist to allow for additional testing.
B.All datasets will be updated once and the pipeline will persist without any processing. The
compute resources will persist but go unused.
C.All datasets will be updated at set intervals until the pipeline is shut down. The compute
resources will be deployed for the update and terminated when the pipeline is stopped.
D.All datasets will be updated once and the pipeline will shut down. The compute resources will
be terminated.
E. All datasets will be updated once and the pipeline will shut down. The compute resources will
persist to allow for additional testing.
20 # A data engineer is maintaining a data pipeline. Upon data ingestion, the data engineer
notices that the source data is starting to have a lower level of quality. The data engineer would
like to automate the process of monitoring the quality level. Which of the following tools can the
data engineer use to solve this problem?
A. Unity Catalog
B. Data Explorer
C. Delta Lake
E. Auto Loader
21 # A data engineer wants to create a data entity from a couple of tables. The data entity must
be used by other data engineers in other sessions. It also must be saved to a physical location.
Which of the foliowing data entities should the data engineer create?
A. Database
B. Function
C. View
D. Temporary view
E. Table
22 #A data engineer is attempting to drop a Spark SQL table my _table. The data engineer wants
to delete all table metadata and data. They run the following command:
DROP TABLE IF EXISTS my _table - While the object no longer appears when they run SHOW
TABLES,the data files still exist. Which of the following describes why the data files still exist
and the metadata files were deleted?
23 # A data engineer only wants to execute the final block of a Python program if the Python
variable day_of_week is equal to 1 and the Python variable review_period is True. Which of the
following control flow statements should the data engineer use to begin this conditionally
executed code block?
24 #A data engineering team has two tables. The first table march transactions is a collection
of all retail transactions in the month of March. The second table april transactions is a
collection of all retail transactions in the month of April. There are no duplicate records between
the tables.Which of the following commands should be run to create a new table
all_transactions that contains all records from march_ transactions and april transactions
without duplicate records?
B.
D.
E.
25 #A data engineer needs to create a table in Databricks using data from their organization's
existing
OPTIONS (
url "jdbc:sqlite:/customers.db",
dbtable "customer360"
Which of the following lines of code fills in the above blank to successfully complete the task?
A. org.apache.spark.sql.jdbc
B. autoloader
C. DELTA
D. sglite
E. org.apache.spark.sql.sqlite
26 #A data engineer runs a statement every day to copy the previous day's sales into the table
transactions. Each day's sales are in their own file in the location "/transactions/raw". Today, the
data
FROM "/transactions/raw"
FILEFORMAT = PARQUET;
After running the command today, the data engineer notices that the number of records in table
transactions has not changed. Which of the following describes why the statement might not
have copied any new records into the table?
A. The format of the files to be copied were not included with the FORMAT_OPTIONS keyword.
B. The names of the files to be copied were not included with the FILES keyword.
C. The previous day's file has already been copied into the table.
E. The COPY INTO statement requires the table to be refreshed to view the copied rows.
27 # A data analyst has a series of queries in a SQL program. The data analyst wants this
program to run every day. They only want the final query in the program to run on Sundays. They
ask for help from the data engineering team to complete this task. Which of the following
approaches could be used by the data engineering team to complete this task?
A. They could submit a feature request with Databricks to add this functionality.
B. They could wrap the queries using PySpark and use Python's control flow system to
determine when to run the final query.
D. They could automaticaliy restrict access lo the source tabie in the final query so that it is only
accessible on Sundays.
E. They could redesign the data model to separate the data used in the final query into a new
table.
28 A data engineer needs to apply custom logic to string column city in table stores for a
specific use case. In order to apply this custom logic at scale, the data engineer wants to create
a SQL userdefined function (UDF). Which of the following code blocks creates this SQL UDF?
A.
RETURNS STRING
RETURN CASE
ELSE city
END;
B.
RETURNS STRING
CASE
ELSE city
END;
C.
RETURN CASE
ELSE city
END;
D.
RETURN CASE
ELSE city
END;
E.
RETURNS STRING
RETURN CASE
ELSE city
END;
29 # Which of the following commands can be used to write data into a Delta table while
avoiding the writing of duplicate records?
A.DROP
B. IGNORE
C. MERGE
D. APPEND
E. INSERT
30 # Which of the following benefits is provided by the array functions from Spark soL?
D. An ability to work with complex, nested data ingested from JSON files
31 #A data engineer wants to create a new table containing the names of customers that live in
firstName,
lastName,
FROM customerLocations
A senior data engineer mentions that it is organization policy to include a table property
indicating that
Which of the follawing ines of code fils in the above blank to successfully complete the task?
B."COMMENT PI"
C. TBLPROPERTIES PI
E. PII
32 # Which of the following commands will return the location of database customer360?
33 # A data analyst has created a Delta table sales that is used by the entire data analysis team.
They want help from the data engineering team to implement a series of tests to ensure the
data is clean.However, the data engineering team uses Python for its tests rather than SQL.
Which of the following commands could the data engineering team use to access sales in
PySpark?
C. spark.sql("sales")
D. spark.delta.table("sales")
E. spark.table("sales")
34 #A data engineer has left the organization. The data team needs to transfer ownership of the
data engineer's Delta tables to a new data, engineer. The new data engineer is the lead engineer
on the data team. Assuming the original data engineer no longer has access, which of the
following individuals must be the one to transfer ownership of the Delta tables in Data Explorer?
C. Workspace administrator
35 #A data engineer needs to determine whether to use the built-in Databricks Notebooks
versioning or version their project using Databricks Repos. Which of the following is an
advantage of using Databricks Repos over the Databricks Notebooks versioning?
36 # Which of the following datalakehouse features results in improved data quality over a
traditional
data lake?
A. A data lakehouse provides storage solutions for structured and unstructured data.
37 # Which of the following Git operations must be performed outside of Databricks Repos?
A.Commit
B. Pull
C. Push
D. Clone
E. Merge
38 # A data engineer has realized that they made a mistake when making a daily update to a
table.They need to use Delta time travel to restore the table to a version that is 3 days old.
However, when the data engineer attempts to time travel to the older version, they are unable to
restore the data because the data files have been deleted. Which of the following explains why
the data files are no longer present?
39 # Which of the following code blocks will remove the rows where the value in column age is
greater than 25 from the existing Delta table my_table and save the updated table?
A. Delta tables are stored in a single file that contains data, history, metadata, and other
attributes.
B. Delta tables store their data in a single file and all metadata in a collection of files in a
separate location.
C. Delta tables are stored in a collection of files that contain data, history, metadata, and other
attributes.
D. Delta tables are stored in a collection of files that contain only the data stored within the table.
E. Delta tables are stored in a single file that contains only the data stored within the table.
41 # Which of the following benefits of using the Databricks Lakehouse Platform is provided by
Delta Lake?
42 # Which of the following is hosted completely in the control plane of the classic-Databricks
architecture?
A.Worker node
D. Databricks Filesystem
E. Driver node
43 # Which of the following describes a scenario in which a data team will want to utilize cluster
pools?
44 # A data organization leader is upset about the data analysis team's reports being different
from the data engineering team's reports. The leader believes the siloed nature of their
organization's data engineering and data analysis architectures is to blame. Which of the
following describes how a data lakehouse could alleviate this issue?
B. Both teams would use the same source of truth for their work
45 #A new data engineering team team has been assigned to an ELT project: The new data
engineering team will need full privileges on the table sales to fully manage the project.Which of
the following commands can be used to grant full permissions on the database to the new data
engineering team?
46 #A data engineer is running code in a Databricks Repo that is cloned from a central Git
repository.A colleague of the data engineer informs them that changes have been made and
synced to the central Git repository. The data engineer now needs to sync their Databricks Repo
to get the changes from the central Git repository.
Which of the following Git operations does the data engineer need to run to accomplish this
task?
A. Merge
B. Push
C. Pull
D. Commit
E. Clone
47 # Which of the following is a benefit of the Databricks Lakehouse Platform embracing open
source téchnologies?
A. Cloud-specific integrations
B. Simplified governance
48 #A data engineer needs to use a Delta table as part of a data pipeline, but they do not know if
they have the appropriate permissions.
In which of the following locations can the data engineer review their permissions on the table?
A. Databricks Filesystem
B. Jobs
C. Dashboards
D. Repos
E. Data Explorer
49 # Which of the following describes a scenario in which a data engineer will want to use a
single node cluster?
D. When they are concerned about the ability to automatically scale with larger data
E. When they are manually running reports with a large amount of data
rank INTEGER=6
Which of the following SQL commands can be used to append the new record to an existing
Delta table
my.table?
51 #A data engineer has realized that the data files associated with a Delta table are incredibly
small.
They want to compact the small files to form larger files to improve performance.
Which of the following keywords can be used to compact the small files?
A. REDUCE
B. OPTIMIZE
C. COMPACTION
D. REPARTITION
E. VACUUM
52 # In which of the following file formats is data from Delta Lake tables primarily stored?
A. Delta
B.CSV
C. Parquet
D. JSON
C. Repos
D. Data
E. Notebooks
54 #.Which of the following can be used to simplify and unify siloed data architectures that are
A. None of these
B. Data lake
C. Data warehouse
D. All of these
E. Data lakehouse
55 #A data architect has determined that a table of the following format is necessary.
a1 2009-01-06 5.5
a2 2018-11-21 7.1
- - -
Which of the following code blocks uses SOL DDL commands to create an empty Delta table in
the above format regardless of whether a table already exists with this name?
A.
CREATE TABLE IE NOT EXISTS table_name (
employeeId STRING,
startDate DATE,
avgRating FLOAT
B.
SELECT
employeeId STRING,
startDate DATE,
avgRating FLOAT
USING DELTA
C.
employeeId STRING,
startDate DATE,
avgRating FLOAT
) USING DELTA
D.
SELECT
employeeId STRING,
startDate DATE,
avgRating FLOAT
E.
CREATE OR REPLACE TABLE table_name (
employeeId STRING,
startDate DATE,
avgRating FLOAT
56 #A data engineer has a Python notebook in Databricks, but they need to use SQL to
accomplish a specific task within a cell. They still want all of the other cells to use Python
without making any changes to those cells.
Which of the following describes how the data engineer can use SQL within a cell of their
Python notebook?
B. They can attach the cell to a SQL endpoint rather than a Databricks cluster
57 # Which of the following SQL keywords can be used to convert a table from a long format tò
a wide format?
A. TRANSFORM
B. PIVOT
C. SUM
D. CONVERT
E. WHERE
58 # Which of the following describes a benefit of creating an external table from Parquet rather
than CSV when using a CREATE TABLE AS SELECT statement?
A. Parquet files can be partitioned
59 # A data engineer wants to create a relational object by pulling data from two tables. The
relational object does not need to be used by other data engineers in other sessions. In order to
save on storage costs, the data engineer wants to avoid copying and storing physical data
Which of the following relational objects should the data engineer create?
B. View
C. Database
D. Temporary view
E. Delta Table
60 #A data analyst has developed a query that runs against Delta table. They want help from the
data engineering team to implement a series of tests to ensure the data returned by the query is
clean.However, the data engineering team uses Python for its tests rather than SQL.
Which of the following operations could the data engineering team use to run the query and
operate with the results in PySpark?
B. spark.delta.table
C. spark.sql
E. spark.table
61 # Which of the following commands will return the number of null values in the member_id
column?
62.A data engineer needs to apply custom logic to identify employees with more than 5 years of
experience in array column employees in table stores. The custom logic should create a new
column exp_employees that is an array of all of the employees with more than 5 years of
experience for each row. In order to apply this custom logic at scale, the data engineer wants
to.use the FILTER higher-order function.
A.
SELECT
store_id,
employees,
FROM stores;
B.
SELECT
store _id,
employees,
FROM stores;
C.
SELECT
store_id,
employees,
FROM stores;
D.
SELECT
store id,
employees
ELSE NULL
END AS exp_employees
FROM stores;
E.
SELECT
store_id,
employees,
63 #A data engineer has a Python variable table_name that they would like to use in a SQL query.
They
want to construct a Python code block that will run the query using table _name.
Which of the following can be used to fill in the blank to successfully complete the task?
A. spark.delta.sql
B. spark.delta.table
C. spark.table
D. dbutils.sql
E. spark.sql
64 #A data engineer has created a new database using the foliowing command:
A. dbfs:/user/hive/database/customer360
B. dbfs:/user/hive/warehouse
C. dbfs:/user/hive/customer360
E. dbfs:/user/hive/database
65 # A data engineer is attempting to drop a Spark SoL table my table and runs the follawing
command:
After nunning this command, the engineer notices that the data files and metadata files have
been deleted from the file system.
Which of the following describes why all of these files were deleted?
Which of the following code blocks can the data engineer use to complete this task?
A.
return x + y
B.
function add_integers(x,y):
x+y
C.
print(x+ y)
D.
return x + y
E.
x+y
67 # In which of the following scenarios should a data engineer use the MERGE INTO command
instead of the INSERT INTO command?
68 #A data engineer is working with two tables. Each of these tables is displayed below ìn its
entirety.
The data engineer runs the following query to join these tables together:
/path/to/csv.
Which of the following lines of code fills in the above blank to successfully complete the task?
A. None of these lines of code are needed to successfully complete the task
B. USING CSV
C. FROM CSV
D. USING DELTA
E. FROM"path/to/csv"
70 # A data engineer has configured a Structured Streaming job to read from a table,
manipulate the data, and then perform a streaming write into a new table.
If the data engineer only wants the query to process all of the available data in as many batches
as required, which of the following lines of code should the data engineer use to fill in the blank?
A. processingTime(1)
B. trigger(availableNow=True)
C. trigger(parallelBatch=True)
D. trigger(processingTime-"once")
E. trigger(continuous="once")
71#A data engineer has developed a data pipeline to ingest data from a JSON source using
Auto toader, but the engineer has not provided any type inference or schema hints in their
pipeline. Upon reviewing the data, the data engineer has noticed that all of the columns in the
target table are of the string type despite some of the fields only including float or boolean
values.
Which of the following describes why Auto Loader inferred all of the columns to be of the string
type?
A. There was a type mismatch between the specific schema and the inferred schema
72 #A Delta Live Table pipeline includes two datasets defined using STREAMING LIVE TABLE.
Three datasets are defined against Delta Lake table sources using LIVE TABLE.
The table is configured to run in Development mode using the Continuous Pipeline Mode.
Assuming previously unprocessed data exists and all definitions are valid, what is the expected
A. All datasets will be updated once and the pipeline will shut down. The compute resources will
be terminated.
B. All datasets will be updated at set intervals until the pipeline is shut down. The compute
resources will persist until the pipeline is shut down.
C. All datasets will be updated once and the pipeline will persist without any processing. The
compute resources will persist but go unused.
D. All datasets will be updated once and the pipeline will shut down. The compute resources will
persist to allow for additional testing.
E. All datasets will be updated at set intervals until the pipeline is shut down. The compute
resources will persist to allow for additional testing.
73 # Which of the following data workloads will utilize a Gold table as its source?
A. A job that enriches data by parsing its timestamps into a human-readable format
E. A job that ingests raw data from a streaming source into the Lakehouse
74 # Which of the following must be specified when creating a new Delta Live Tables pipeline?
75 # A data engineer has joined an existing project and they see the following query in the
project repository:
SELECT customer_id-
FROM STREAM(LIVE.customers)
Which of the following describes why the STREAM function is included in the query?
E. The data in the customers table has been updated since its last run.
76 # Which of the following describes the type of workloads that are always compatible with
Auto Loader?
A. Streaming workloads
C. Serverless workloads
D. Batch workloads
E. Dashboard workloads
77 # A data engineer and data analyst are working together on a data pipeline. The data
engineer is working on the raw, bronze, and silver layers of the pipeline using Python, and the
data analyst is working on the gold layer of the pipeline using SOL. The raw source of the
pipeline is a streaming input.They now want to migrate their pipeline to use Delta Live Tables.
Which of the following changes will need to be made to the pipeline when migrating to Delta
Live Tables?
B. The pipeline will need to stop using the medallion-based multi-hop architecture
D. The pipeline will need to use a batch source in place of a streaming source
78 #A data engineer is using the following code block as part of a batch ingestion pipeline to
read from a composable table:
Which of the following changes needs to be made so this code block will work when the
transactions table is a stream source?
A. Replace predict with a stream-friendly prediction function
C. Replace "transactions" with the path to the location of the Delta table
79 # A dataset has been defined using Delta Live Tables and includes an expectations
clause:CONSTRAINT valid_timestamp EXPECT (timestamp >"2020-01-01') ON VIOLATION FAIL
UPDATE What is the expected behavior when a batch of data containing data that violates these
constraints is processed?
A. Records that violate the expectation are dropped from the target dataset and recorded as
invalid in the event log.
C. Records that violate the expectation are dropped from the target dataset and loaded into a
quarantine table.
D. Records that violate the expectation are added to the target dataset and recorded as invalid
in the event log.
E. Records that violate the expectation are added to the target dataset and flagged as invalid in
a field added to the target dataset.
80 # Which of the following statements regarding the relationship between Silver tables and
Bronze tàbles is always true?
A. Silver tables contain a less refined, less clean view of data than Bronze data.
B. Silver tables contain aggregates while Bronze data is unaggregated.
D. Silver tables contain a more refined and cleaner view of data than Bronze tables.
81 # A data engineering team has noticed that their Databricks SOL queries are running too
slowly when they are submitted to a non-running SQL endpoint. The data engineering team
wants this issue to be resolved.
which of the following approaches can the team use to reduce the time it takes to return results
in this scenario?
A. They can turn on the Serverless feature for the Sal endpoint and change the Spot Instance
Polioy to "Reliability Optimized."
B. They can turn on the Auto Stop feature for the SQL endpoint.
D. They can turn on the Serverless feature for the SQL endpoint.
E. They can increase the maximum bound of the SQL endpoint's scaling range
82 # A data engineer has a Job that has a complex run schedule, and they want to transfer that
schedule to other Jobs.
Rather than manually selecting each value in the scheduling form in Databricks, which of the
following tools can the data engineer use to represent and submit the schedule
programmatically?
A. pyspark.sql.types.DateType
B. datetime
C. pyspark.sql.types.TimestampType
D. Cron syntax
D. There is no way to notify the Job owner in the case of Job failure
84 #An engineering manager uses a Databricks SQL query to monitor ingestion latency for each
data source. The manager checks the results of the query every day, but they are manually
rerunning the qúery each day and waiting for the results.
Which of the following approaches can the manager use to ensure the results of the query are
updated each day?
A. They can schedule the query to refresh every 1 day from the SOL endpoint's page in
Databricks SQL.
B. They can schedule the query to refresh every 12 hours from the SOL endpoint's page in
Databricks SQL.
C. They can schedule the query to refresh every 1 day from the query's page in Databricks SQL.
D. They can schedule the query to run every 1 day from the Jobs Ul.
E. They can schedule the query to run every 12 hours from the Jobs UI.
85 # In which of the following scenarios should a data engineer select a Task in the Depends On
field of a new Databricks Job Task?
B. When another task needs to fail before the new task begins
C. When another task has the same dependency libraries as the new task
E. When another task needs to successfully complete before the new task begins
86 #A data engineer has been using a Databricks SQL dashboard to monitor the cleanliness of
the input data to a data analytics dashboard for a retail use case. The job has a Databricks SQL
query that returns the number of store-level records where sales is equal to zero. The data
engineer wants their entire team to be notified via a messaging webhook whenever this value is
greater than 0.
Which of the following approaches can the data engineer use to notify their entire team via a
messaging webhook whenever the number of stores with S0 in sales is greater than zero?
87 #A data engineer wants to schedule their Databricks SOL dashboard to refresh every hour,
but they only. want the associated SOL endpoint to be running when it is necessary. The
dashboard has multiple queries on multiple datasets associated with it. The data that feeds the
dashboard is automatically processed using a Databricks Job.
Which of the following approaches can the data engineer use to minimize the total running time
of the SQL endpoint used in the refresh schedule of their dashboard?
A. They can turn on the Auto Stop feature for the SQL endpoint.
B. They can ensure the dashboard's SQL endpoint is not one of the included query's sQl
endpoint.
D. They can ensure the dashboard's SQL endpoint matches each of the queries' SQl endpoints.
88 #A data engineer needs access to a table new table, but they do not have the correct
permissions.
They can ask the table owner for permission, but they do not know who the table owner is.
Which of the folliowing approaches can be used to identify the owner of new_table?
B. All of these options can be used to identify the owner of the table
D. Review the Owner field in the table's page in the cloud storage solution