Skip to main content

Databricks Runtime 17.2 (Beta)

The following release notes provide information about Databricks Runtime 17.2 (Beta), powered by Apache Spark 4.0.0.

Databricks released this version in August 2025.

Beta

Databricks Runtime 17.2 is in Beta. The contents of the supported environments might change during the Beta. Changes can include the list of packages or versions of installed packages.

New features and improvements

ST_ExteriorRing function is now supported

You can now use the ST_ExteriorRing function to extract the outer boundary of a polygon and return it as a linestring. See st_exteriorring function.

Show pushdown details in DESCRIBE and Spark UI for remote scans

The DESCRIBE command and Spark UI for RemoteSparkConnectScan on dedicated compute now display predicates, aggregations, group by clauses, limits, and samples that are pushed down into the remote scan.

Support TEMPORARY keyword for metric view creation

You can now use the TEMPORARY keyword when creating a metric view. Temporary metric views are visible only in the session that created them and are dropped when the session ends. See CREATE VIEW.

Support additional commands with fine-grained access control

Fine-grained access control on dedicated compute now supports the FSCK REPAIR TABLE and DESCRIBE DETAIL commands.

Use native I/O for LokiFileSystem.getFileStatus on S3

LokiFileSystem.getFileStatus now uses the native I/O stack for Amazon S3 traffic and returns org.apache.hadoop.fs.FileStatus objects instead of shaded.databricks.org.apache.hadoop.fs.s3a.S3AFileStatus.

ANSI mode enabled by default for Pandas API on Spark

ANSI_MODE is now enabled by default for Pandas API on Spark with compute.ansi_mode_support=True, which ensures ANSI compliance parity with native pandas. The compute.fail_on_ansi_mode option still applies if compute.ansi_mode_support is set to False.

Behavioral changes

DESCRIBE CONNECTION shows environment settings for JDBC connections

Databricks now includes user-defined environment settings in the DESCRIBE CONNECTION output for JDBC connections that support custom drivers and run in isolation. Other connection types remain unchanged.

Option to truncate uniform history during managed tables migration

You can now truncate uniform history when migrating tables with Uniform/Iceberg enabled using ALTER TABLE...SET MANAGED. This simplifies migrations and reduces downtime compared to disabling and re-enabling Uniform manually.

SQL syntax for Delta read options in streaming queries

You can now specify Delta read options for SQL-based streaming queries using the WITH clause. For example:

SELECT * FROM STREAM tbl WITH (SKIPCHANGECOMMITS=true, STARTINGVERSION=X);

Correct results for split with empty regex and positive limit

Databricks now returns correct results when using split function with an empty regex and a positive limit. Previously, the function incorrectly truncated the remaining string instead of including it in the last element.

Fix url_decode and try_url_decode error handling in Photon

In Photon, try_url_decode() and url_decode() with failOnError = false now return NULL for invalid URL-encoded strings instead of failing the query.

Shared execution environment for Unity Catalog Python UDTFs

Databricks now shares the execution environment for Python user-defined table functions (UDTFs) from the same owner and Spark session. An optional STRICT ISOLATION clause is available to disable sharing for UDTFs with side effects, such as modifying environment variables or executing arbitrary code.

Library upgrades

Upgraded Python libraries:

No Python libraries were upgraded in this version.

Upgraded R libraries:

No R libraries were upgraded in this version.

Upgraded Java libraries:

  • io.delta.delta-sharing-client_2.13 from 1.3.3 to 1.3.5

Apache Spark

Databricks Runtime 17.2 (Beta) includes Apache Spark 4.0.0. This release includes all Spark fixes and improvements included in version 17.1, as well as the following additional bug fixes and improvements made to Spark:

  • SPARK-53183 Use Java Files.readString instead of o.a.s.sql.catalyst.util.fileToString
  • SPARK-51817 Re-introduce ansiConfig fields in messageParameters of CAST_INVALID_INPUT and CAST_OVERFLOW
  • SPARK-53124 Prune unnecessary fields from JsonTuple
  • SPARK-53106 Add schema evolution tests for TWS Scala spark connect suites
  • SPARK-53201 Use SparkFileUtils.contentEquals instead of Files.equal
  • SPARK-53308 Don't remove aliases in RemoveRedundantAliases that would cause duplicates
  • SPARK-53241 Support createArray in SparkCollectionUtils
  • SPARK-53239 Improve MapSort and SortArray performance via parallelSort
  • SPARK-53184 Fix melt() when value columns mix strings and numbers
  • SPARK-53144 Make CreateViewCommand in SparkConnectPlanner side effect free
  • SPARK-53303 Use the empty state encoder when the initial state is not provided in TWS
  • SPARK-52917 Read support to enable round-trip for binary in xml format
  • SPARK-53110 Implement the time_trunc function in PySpark
  • SPARK-53107 Implement the time_trunc function in Scala
  • SPARK-52146 Detect cyclic function references in SQL UDFs
  • SPARK-52469 Use JEP 223 API to process Java version
  • SPARK-53094 Fix CUBE with aggregate containing HAVING clauses
  • SPARK-51874 Add TypedConfigBuilder for Scala Enumeration
  • SPARK-53287 Add ANSI Migration Guide
  • SPARK-43100 Push Based Shuffle metrics must be deserialized correctly
  • SPARK-53045 DESCRIBE EXTENDED should be resilient to corrupt metadata
  • SPARK-53114 Support join in JavaUtils
  • SPARK-53297 Fix StreamingTable Declarative Pipelines API docstring
  • SPARK-53181 Enable doc tests under ANSI
  • SPARK-52482 Improve exception handling for reading certain corrupt zstd files
  • SPARK-52990 Support StringSubstitutor
  • SPARK-51874 Add TypedConfigBuilder for Scala Enumeration
  • SPARK-53169 Remove comments related to "Set the logger level of File Appender to" from log4j2.properties
  • SPARK-53080 Support cleanDirectory in SparkFileUtils and JavaUtils
  • SPARK-53045 DESCRIBE EXTENDED should be resilient to corrupt metadata
  • SPARK-53000 Rename StringUtils.scala to StringConcat.scala in sql/api module
  • SPARK-52952 Add PySpark UDF Type Coercion Dev Script
  • SPARK-52998 Multiple variables inside declare
  • SPARK-51817 Re-introduce ansiConfig fields in messageParameters of CAST_INVALID_INPUT and CAST_OVERFLOW
  • SPARK-52820 Capture full plans in golden files
  • SPARK-53274 Support left and right join pushdown in JDBCScanBuilder
  • SPARK-52110 Implement SQL syntax support for pipelines
  • SPARK-52950 Enable ANSI mode in DataSourceV2StrategySuite
  • SPARK-52947 Fix image path in declarative pipelines programming guide
  • SPARK-52592 Support creating a ps.Series from a ps.Series
  • SPARK-53301 Differentiate type hints of Pandas UDF and Arrow UDF
  • SPARK-53146 Make MergeIntoTable in SparkConnectPlanner side effect free
  • SPARK-53166 Use SparkExitCode.EXIT_FAILURE in SparkPipelines object
  • SPARK-53288 Fix assertion error with streaming global limit
  • SPARK-52394 Fix autocorr divide-by-zero error under ANSI mode
  • SPARK-51555 Add the time_diff() function
  • SPARK-52948 Enable test_np_spark_compat_frame under ANSI
  • SPARK-53134 Clean up unused ANSI imports in tests
  • SPARK-52593 Avoid CAST_INVALID_INPUT of MultiIndex.to_series, Series.dot and DataFrame.dot in ANSI mode
  • SPARK-53291 Fix nullability for value column
  • SPARK-53097 Make WriteOperationV2 in SparkConnectPlanner side effect free
  • SPARK-53305 Support TimeType in createDataFrame
  • SPARK-52914 Support On-Demand Log Loading for rolling logs in History Server
  • SPARK-33538 Directly push IN/NOT predicates to the Hive Metastore
  • SPARK-52849 Add stringifyException to o.a.s.util.Utils
  • SPARK-52771 Fix float32 type widening in truediv/floordiv
  • SPARK-52502 Thread count overview
  • SPARK-52788 Fix error of converting binary value in BinaryType to XML
  • SPARK-53123 Support getRootCause in SparkErrorUtils
  • SPARK-53129 Improve SparkShell to import java.net._ by default
  • SPARK-53061 Support copyFileToDirectory in SparkFileUtils
  • SPARK-52683 Support ExternalCatalog alterTableSchema
  • SPARK-52871 Merge o.a.s.sql.catalyst.util.SparkStringUtils to o.a.s.util.SparkStringUtils
  • SPARK-52817 Fix Like Expression performance
  • SPARK-52545 Standardize double-quote escaping to follow SQL specification
  • SPARK-52711 Fix float32 type widening in mul/rmul under ANSI
  • SPARK-52615 Replace File.mkdirs with Utils.createDirectory
  • SPARK-52381 JsonProtocol: Only accept subclasses of SparkListenerEvent
  • SPARK-52613 Restore printing full stacktrace when HBase/Hive DelegationTokenProvider hit exception
  • SPARK-52651 Handle User Defined Type in Nested ColumnVector
  • SPARK-52611 Fix SQLConf version for excludeSubqueryRefsFromRemoveRedundantAliases…
  • SPARK-52552 Skip CHECK constraint enforcement for deletion vector deletes
  • SPARK-52587 spark-shell 2.13 support -i -I parameter
  • SPARK-52492 Make InMemoryRelation.convertToColumnarIfPossible customizable
  • SPARK-52451 Make WriteOperation in SparkConnectPlanner side effect free
  • SPARK-53272 Refactor SPJ pushdown logic out of BatchScanExec
  • SPARK-53071 Support copyFile in SparkFileUtils
  • SPARK-51415 Support the time type by make_timestamp()
  • SPARK-51554 Add the time_trunc() function
  • SPARK-52426 Support redirecting stdout/stderr to logging system
  • SPARK-51834 Support end-to-end table constraint management
  • SPARK-53063 Implement and call new APIs in FileCommitProtocol instead of the deprecated
  • SPARK-52546 check sparkContext if has stopped when running catch code block in execute(), otherwise, it will return wrong state.
  • SPARK-53023 Remove commons-io dependency from sql/api module
  • SPARK-52396 Artifact Root Directory should use tmpdir
  • SPARK-53131 Improve SparkShell to import java.nio.file._ by default
  • SPARK-42322 Assign name to_LEGACY_ERROR_TEMP_2235
  • SPARK-51834 Support end-to-end table constraint management
  • SPARK-52484 Skip child.supportsColumnar assertion from driver side in ColumnarToRowExec
  • SPARK-52384 Fix bug Connect should insensitive for JDBC options
  • SPARK-52034 Add common methods in SparkOperation trait for thriftserver operations
  • SPARK-53031 Support getFile in SparkFileUtils
  • SPARK-52976 Fix Python UDF not accepting collated string as input param/return type (17.x)
  • SPARK-52943 Enable arrow_cast for all pandas UDF eval types
  • SPARK-53263 Support TimeType in df.toArrow
  • SPARK-53141 Add APIs to get overhead memory size and offheap memory size from resource profile
  • SPARK-53259 Correct the message for INVALID_UDF_EVAL_TYPE
  • SPARK-53167 Spark launcher isRemote also respects properties file
  • SPARK-53165 Add SparkExitCode.CLASS_NOT_FOUND
  • SPARK-53171 Improvement UTF8String repeat
  • SPARK-53170 Improve SparkUserAppException to have cause parameter
  • SPARK-52989 Add explicit close() API to State Store iterators
  • SPARK-53074 Avoid partial clustering in SPJ to meet a child's required distribution
  • SPARK-52252 ScalaUDF encoders in subquery should be resolved
  • SPARK-53244 Don't store dual-run enabled and tentative mode enabled confs during view creation
  • SPARK-53192 Always cache a DataSource in the Spark Connect Plan Cache
  • SPARK-51813 Add a nonnullable DefaultCachedBatchKryoSerializer to avoid null propagating in DefaultCachedBatch serde
  • SPARK-52904 Reapply "[SC-202233][python] Enable convertToArrowArrayS…
  • SPARK-53253 Fix register UDF of type SQL_SCALAR_ARROW_ITER_UDF
  • SPARK-53243 List the supported eval types in arrow nodes
  • SPARK-53130 Fix toJson behavior of collated string types
  • SPARK-53003 Support strip in SparkStringUtils
  • SPARK-51902 Sync OSS: Enforce check constraint on table insertion
  • SPARK-52047 Raise PySparkValueError for unsupported plot kinds
  • SPARK-53004 Support abbreviate in SparkStringUtils
  • SPARK-53066 Improve EXPLAIN output for DSv2 Join pushdown
  • SPARK-30848 Remove productHash from TreeNode
  • SPARK-53046 Use Java readAllBytes instead of IOUtils.toByteArray
  • SPARK-53206 Use SparkFileUtils.move instead of com.google.common.io.Files.move
  • SPARK-53066 Improve EXPLAIN output for DSv2 Join pushdown
  • SPARK-53069 Fix incorrect state store metrics with virtual column families
  • SPARK-52904 Enable convertToArrowArraySafely by default [17.x]
  • SPARK-52821 add int->DecimalType pyspark udf return type coercion
  • SPARK-51562 Add time function
  • SPARK-52971 Limit idle Python worker queue size
  • SPARK-53057 Support sizeOf in SparkFileUtils and JavaUtils
  • SPARK-53040 Ban self references inside topmost CTEs in Recursive CTEs
  • SPARK-53104 Introduce ansi_mode_context to avoid multiple config checks per API call
  • SPARK-47547 Add BloomFilter V2 and use it as default
  • SPARK-53098 DeduplicateRelations shouldn't remap expressions if old ExprId still exists in output
  • SPARK-53049 Support toString in SparkStreamUtils
  • SPARK-53062 Support deleteQuietly in SparkFileUtils and JavaUtils
  • SPARK-53070 Support is(Not)?Empty in SparkCollectionUtils
  • SPARK-53020 JPMS args should also apply to non-SparkSubmit process
  • SPARK-52968 Emit additional state store metrics
  • SPARK-52975 Simplify field names in pushdown join sql
  • SPARK-52926 Added SQLMetric for remote schema fetching time duration.
  • SPARK-53059 Arrow UDF no need to depend on pandas
  • SPARK-52646 Avoid CAST_INVALID_INPUT of __eq__ in ANSI mode
  • SPARK-52622 Avoid CAST_INVALID_INPUT of DataFrame.melt in ANSI mode
  • SPARK-52985 Raise TypeError for pandas numpy operand in comparison operators
  • SPARK-52580 Avoid CAST_INVALID_INPUT of replace in ANSI mode
  • SPARK-52549 Disable Recursive CTE self-references from window functions and inside sorts
  • SPARK-52895 Don't add duplicate elements in resolveExprsWithAggregate
  • SPARK-50748 Fix a race condition issue which happens when operations are interrupted
  • SPARK-52737 Pushdown predicate and number of apps to FsHistoryProvider when listing applications
  • SPARK-53018 ArrowStreamArrowUDFSerializer should respect argument arrow_cast
  • SPARK-53013 Fix Arrow-optimized Python UDTF returning no rows on lateral join
  • SPARK-51834 Sync OSS: support end-to-end table constraint alter add/drop constraint
  • SPARK-52921 Specify outputPartitioning for UnionExec for same output partitoning as children operators
  • SPARK-52908 Prevent for iterator variable name clashing with names of labels in the path to the root of AST
  • SPARK-52954 Arrow UDF support return type coercion
  • SPARK-52925 Return correct error message for anchor self references in rCTEs
  • SPARK-52889 Implement the current_time function in PySpark
  • SPARK-52675 Interrupt hanging ML handlers in tests
  • SPARK-52959 Support UDT in Arrow-optimized Python UDTF
  • SPARK-52962 BroadcastExchangeExec should not reset metrics
  • SPARK-52956 Preserve alias metadata when collapsing projects
  • SPARK-52890 Implement the to_time and try_to_time functions in PySpark
  • SPARK-52888 Implement the make_time function in PySpark
  • SPARK-52892 Support TIME in the hour, minute, and second functions in PySpark
  • SPARK-52837 Support TimeType in pyspark
  • SPARK-52023 Fix data corruption/segfault returning Option[Product] from udaf
  • SPARK-52955 Change return types of WindowResolution.resolveOrder and WindowResolution.resolveFrame to WindowExpression
  • SPARK-52166 Add support for PipelineEvents
  • SPARK-51834 Fix: remove valid from toDDL
  • SPARK-52735 Fix missing error conditions for SQL UDFs
  • SPARK-51834 Sync OSS Support end-to-end create/replace table with constraint
  • SPARK-51834 Sync OSS update ResolvedIdentifier unapply calls
  • SPARK-52929 Support MySQL and SQLServer connector for DSv2 Join pushdown
  • SPARK-52448 Add simplified Struct Expression.Literal
  • SPARK-52882 Implement the current_time function in Scala
  • SPARK-52905 Arrow UDF for window
  • SPARK-52876 Fix a typo buffer to body in ChunkFetchSuccess.toString
  • SPARK-52883 Implement the to_time and try_to_time functions in Scala
  • SPARK-52751 Don't eagerly validate column name in dataframe['col_name']
  • SPARK-52791 Fix error when inferring a UDT with a null first element
  • SPARK-52686 Union should be resolved only if there are no duplicates
  • SPARK-52881 Implement the make_time function in Scala
  • SPARK-52919 Fix DSv2 Join pushdown to use previously aliased column
  • SPARK-52866 Add support for try_to_date
  • SPARK-52846 Add a metric in JDBCRDD for how long it takes to fetch the resultset
  • SPARK-52859 Add SparkSystemUtils trait
  • SPARK-52823 Support DSv2 Join pushdown for Oracle connector
  • SPARK-52165 Setup build scaffolding for the pipelines project
  • SPARK-52869 Add FrameLessOffsetWindowFunction validation to validateResolvedWindowExpression for reuse in single-pass analyzer
  • SPARK-52885 Implement the hour, minute, and second functions in Scala for the TIME type
  • SPARK-52903 Trim non-top-level aliases before LCA resolution
  • SPARK-52832 Fix JDBC dialect identifier quoting
  • SPARK-52870 Properly quote variable names in FOR statement
  • SPARK-52859 Add SparkSystemUtils trait
  • SPARK-52900 Use SparkStringUtils.stringToSeq in FsHistoryProvider
  • SPARK-52809 Don't hold reader and iterator references for all partitions in task completion listeners for metric update
  • SPARK-52815 Improve SparkClassUtils to support getAllInterfaces
  • SPARK-52795 Include runId in state store logs
  • SPARK-52779 Support TimeType literal in Connect
  • SPARK-52899 Fix QueryExecutionErrorsSuite test to register H2Dialect back
  • SPARK-52862 Fix the nullability check of Decimal('NaN')
  • SPARK-52214 Arrow UDF for aggregation
  • SPARK-52787 Reorganize streaming execution dir around runtime and checkpoint areas
  • SPARK-51564 TIME parsing in the 12hr clock format
  • SPARK-52859 Add SparkSystemUtils trait
  • SPARK-51562 Add time function
  • SPARK-52850 Skip calling conversions if identity function
  • SPARK-52863 Clean up code paths for old pandas versions
  • SPARK-52516 Don't hold previous iterator reference after advancing to next file in ParquetPartitionReaderFactory
  • SPARK-52848 Avoid cast to Double in casting TIME/TIMESTAMP to DECIMAL
  • SPARK-52770 Support TIME type in connect proto
  • SPARK-52842 New functionality and bugfixes for single-pass analyzer
  • SPARK-52620 Support casting of TIME to DECIMAL
  • SPARK-52783 Refactor windowFunction validation logic from checkAnalysis for reuse in single-pass analyzer
  • SPARK-51695 Sync OSS create/replace/alter table for unique constraint via DSv2
  • SPARK-51695 Sync OSS drop constraint via DSv2
  • SPARK-52824 CheckpointFileManager error classification
  • SPARK-52829 Fix LocalDataToArrowConversion.convert to handle empty rows properly
  • SPARK-52811 Optimize ArrowTableToRowsConversion.convert to improve its performance
  • SPARK-52796 Optimize LocalDataToArrowConversion.convert to improve its performance
  • SPARK-51695 Sync OSS Alter Table Add Constraint parser changes
  • SPARK-52619 Cast TimeType to IntegralType
  • SPARK-52187 Introduce Join pushdown for DSv2
  • SPARK-52782 Return NULL from +/- on datetime with NULL
  • SPARK-51695 Introduce Parser Changes for Table Constraints (CHECK, PK, FK)
  • SPARK-52808 spark.history.retainedApplications should be positive
  • SPARK-52776 Do not split the comm field in ProcfsMetricsGetter
  • SPARK-52793 Support isUnix at o.a.s.util.Utils
  • SPARK-52792 Remove commons-lang3 dependency from network-common
  • SPARK-52797 Use Utils.isWindows instead of re-evaluating in PythonWorkerFactory
  • SPARK-52784 Add TimeZoneAware casting in WindowFrameTypeCoercion.createBoundaryCast
  • SPARK-52725 Delay resource profile manager initialization until plugin is loaded
  • SPARK-52565 Enforce ordinal resolution before other sort order expressions
  • SPARK-52740 Fix NPE in HDFSBackedStateStoreProvider accessing StateStoreConf.sqlConf when checkpoint format version is >=2
  • SPARK-52673 Add grpc RetryInfo handling to Spark Connect retry policies
  • SPARK-52724 Enhance broadcast join OOM error handling with SHUFFLE_MERGE hint support
  • SPARK-52781 Fix dtyeps typo in internal.py
  • SPARK-52730 Store underlying driver and database version in JDBCRDD
  • SPARK-52727 Refactor Window resolution in order to reuse it in single-pass analyzer
  • SPARK-52695 User Defined Type write support for xml file format
  • SPARK-52722 Deprecate JdbcRDD class
  • SPARK-51695 Introduce Parser Changes for Table Constraints (CHECK, PK, FK)
  • SPARK-52763 Support TIME subtract
  • SPARK-52768 Fix typo "moveing" in pandas/series.py
  • SPARK-52730 Store underlying driver and database version in JDBCRDD
  • SPARK-52694 Add o.a.s.sql.Encoders#udtAPI
  • SPARK-52720 Fix float32 type widening in add/radd under ANSI
  • SPARK-52723 Server side column name validation
  • SPARK-52760 Fix float32 type widening in sub/rsub under ANSI
  • SPARK-52738 Support aggregating the TIME type with a UDAF when the underlying buffer is an UnsafeRow
  • SPARK-52704 Simplify interoperations between SQLConf and file-format options in TextBasedFileFormats
  • SPARK-52706 Fix inconsistencies and refactor primitive types in parser
  • SPARK-52718 Fix float32 type widening in rmod/mod under ANSI
  • SPARK-52736 Fix typos 'moveing' in pyspark/pandas/generic.py

Databricks ODBC/JDBC driver support

Databricks supports ODBC/JDBC drivers released in the past 2 years. Please download the recently released drivers and upgrade (download ODBC, download JDBC).

System environment

  • Operating System: Ubuntu 24.04.3 LTS
  • Java: Zulu17.58+21-CA
  • Scala: 2.13.16
  • Python: 3.12.3
  • R: 4.4.2
  • Delta Lake: 4.0.0

Installed Python libraries

Library

Version

Library

Version

Library

Version

annotated-types

0.7.0

anyio

4.6.2

argon2-cffi

21.3.0

argon2-cffi-bindings

21.2.0

arrow

1.3.0

asttokens

2.0.5

astunparse

1.6.3

async-lru

2.0.4

attrs

24.3.0

autocommand

2.2.2

azure-common

1.1.28

azure-core

1.34.0

azure-identity

1.20.0

azure-mgmt-core

1.5.0

azure-mgmt-web

8.0.0

azure-storage-blob

12.23.0

azure-storage-file-datalake

12.17.0

babel

2.16.0

backports.tarfile

1.2.0

beautifulsoup4

4.12.3

black

24.10.0

bleach

6.2.0

blinker

1.7.0

boto3

1.36.2

botocore

1.36.3

cachetools

5.5.1

certifi

2025.1.31

cffi

1.17.1

chardet

4.0.0

charset-normalizer

3.3.2

click

8.1.7

cloudpickle

3.0.0

comm

0.2.1

contourpy

1.3.1

cryptography

43.0.3

cycler

0.11.0

Cython

3.0.12

databricks-sdk

0.49.0

dbus-python

1.3.2

debugpy

1.8.11

decorator

5.1.1

defusedxml

0.7.1

Deprecated

1.2.13

distlib

0.3.9

docstring-to-markdown

0.11

executing

0.8.3

facets-overview

1.1.1

fastapi

0.115.12

fastjsonschema

2.21.1

filelock

3.18.0

fonttools

4.55.3

fqdn

1.5.1

fsspec

2023.5.0

gitdb

4.0.11

GitPython

3.1.43

google-api-core

2.20.0

google-auth

2.40.0

google-cloud-core

2.4.3

google-cloud-storage

3.1.0

google-crc32c

1.7.1

google-resumable-media

2.7.2

googleapis-common-protos

1.65.0

grpcio

1.67.0

grpcio-status

1.67.0

h11

0.14.0

httpcore

1.0.2

httplib2

0.20.4

httpx

0.27.0

idna

3.7

importlib-metadata

6.6.0

importlib_resources

6.4.0

inflect

7.3.1

iniconfig

1.1.1

ipyflow-core

0.0.209

ipykernel

6.29.5

ipython

8.30.0

ipython-genutils

0.2.0

ipywidgets

7.8.1

isodate

0.6.1

isoduration

20.11.0

jaraco.context

5.3.0

jaraco.functools

4.0.1

jaraco.text

3.12.1

jedi

0.19.2

Jinja2

3.1.5

jmespath

1.0.1

joblib

1.4.2

json5

0.9.25

jsonpointer

3.0.0

jsonschema

4.23.0

jsonschema-specifications

2023.7.1

jupyter-events

0.10.0

jupyter-lsp

2.2.0

jupyter_client

8.6.3

jupyter_core

5.7.2

jupyter_server

2.14.1

jupyter_server_terminals

0.4.4

jupyterlab

4.3.4

jupyterlab-pygments

0.1.2

jupyterlab-widgets

1.0.0

jupyterlab_server

2.27.3

kiwisolver

1.4.8

launchpadlib

1.11.0

lazr.restfulclient

0.14.6

lazr.uri

1.0.6

markdown-it-py

2.2.0

MarkupSafe

3.0.2

matplotlib

3.10.0

matplotlib-inline

0.1.7

mccabe

0.7.0

mdurl

0.1.0

mistune

2.0.4

mlflow-skinny

3.0.1

mmh3

5.1.0

more-itertools

10.3.0

msal

1.32.3

msal-extensions

1.3.1

mypy-extensions

1.0.0

nbclient

0.8.0

nbconvert

7.16.4

nbformat

5.10.4

nest-asyncio

1.6.0

nodeenv

1.9.1

notebook

7.3.2

notebook_shim

0.2.3

numpy

2.1.3

oauthlib

3.2.2

opentelemetry-api

1.32.1

opentelemetry-sdk

1.32.1

opentelemetry-semantic-conventions

0.53b1

overrides

7.4.0

packaging

24.2

pandas

2.2.3

pandocfilters

1.5.0

parso

0.8.4

pathspec

0.10.3

patsy

1.0.1

pexpect

4.8.0

pillow

11.1.0

pip

25.0.1

platformdirs

3.10.0

plotly

5.24.1

pluggy

1.5.0

prometheus_client

0.21.0

prompt-toolkit

3.0.43

proto-plus

1.26.1

protobuf

5.29.4

psutil

5.9.0

psycopg2

2.9.3

ptyprocess

0.7.0

pure-eval

0.2.2

pyarrow

19.0.1

pyasn1

0.4.8

pyasn1-modules

0.2.8

pyccolo

0.0.71

pycparser

2.21

pydantic

2.10.6

pydantic_core

2.27.2

pyflakes

3.2.0

Pygments

2.15.1

PyGObject

3.48.2

pyiceberg

0.9.0

PyJWT

2.10.1

pyodbc

5.2.0

pyparsing

3.2.0

pyright

1.1.394

pytest

8.3.5

python-dateutil

2.9.0.post0

python-json-logger

3.2.1

python-lsp-jsonrpc

1.1.2

python-lsp-server

1.12.0

pytoolconfig

1.2.6

pytz

2024.1

PyYAML

6.0.2

pyzmq

26.2.0

referencing

0.30.2

requests

2.32.3

rfc3339-validator

0.1.4

rfc3986-validator

0.1.1

rich

13.9.4

rope

1.12.0

rpds-py

0.22.3

rsa

4.9.1

s3transfer

0.11.3

scikit-learn

1.6.1

scipy

1.15.1

seaborn

0.13.2

Send2Trash

1.8.2

setuptools

74.0.0

six

1.16.0

smmap

5.0.0

sniffio

1.3.0

sortedcontainers

2.4.0

soupsieve

2.5

sqlparse

0.5.3

ssh-import-id

5.11

stack-data

0.2.0

starlette

0.46.2

statsmodels

0.14.4

strictyaml

1.7.3

tenacity

9.0.0

terminado

0.17.1

threadpoolctl

3.5.0

tinycss2

1.4.0

tokenize_rt

6.1.0

tomli

2.0.1

tornado

6.4.2

traitlets

5.14.3

typeguard

4.3.0

types-python-dateutil

2.9.0.20241206

typing_extensions

4.12.2

tzdata

2024.1

ujson

5.10.0

unattended-upgrades

0.1

uri-template

1.3.0

urllib3

2.3.0

uvicorn

0.34.2

virtualenv

20.29.3

wadllib

1.3.6

wcwidth

0.2.5

webcolors

24.11.1

webencodings

0.5.1

websocket-client

1.8.0

whatthepatch

1.0.2

wheel

0.45.1

widgetsnbextension

3.6.6

wrapt

1.17.0

yapf

0.40.2

zipp

3.21.0

Installed R libraries

R libraries are installed from the Posit Package Manager CRAN snapshot on 2025-03-20.

Library

Version

Library

Version

Library

Version

arrow

19.0.1

askpass

1.2.1

assertthat

0.2.1

backports

1.5.0

base

4.4.2

base64enc

0.1-3

bigD

0.3.0

bit

4.6.0

bit64

4.6.0-1

bitops

1.0-9

blob

1.2.4

boot

1.3-30

brew

1.0-10

brio

1.1.5

broom

1.0.7

bslib

0.9.0

cachem

1.1.0

callr

3.7.6

caret

7.0-1

cellranger

1.1.0

chron

2.3-62

class

7.3-22

cli

3.6.5

clipr

0.8.0

clock

0.7.2

cluster

2.1.6

codetools

0.2-20

colorspace

2.1-1

commonmark

1.9.5

compiler

4.4.2

config

0.3.2

conflicted

1.2.0

cpp11

0.5.2

crayon

1.5.3

credentials

2.0.2

curl

6.4.0

data.table

1.17.0

datasets

4.4.2

DBI

1.2.3

dbplyr

2.5.0

desc

1.4.3

devtools

2.4.5

diagram

1.6.5

diffobj

0.3.5

digest

0.6.37

downlit

0.4.4

dplyr

1.1.4

dtplyr

1.3.1

e1071

1.7-16

ellipsis

0.3.2

evaluate

1.0.3

fansi

1.0.6

farver

2.1.2

fastmap

1.2.0

fontawesome

0.5.3

forcats

1.0.0

foreach

1.5.2

foreign

0.8-86

forge

0.2.0

fs

1.6.5

future

1.34.0

future.apply

1.11.3

gargle

1.5.2

generics

0.1.4

gert

2.1.4

ggplot2

3.5.1

gh

1.4.1

git2r

0.35.0

gitcreds

0.1.2

glmnet

4.1-8

globals

0.18.0

glue

1.8.0

googledrive

2.1.1

googlesheets4

1.1.1

gower

1.0.2

graphics

4.4.2

grDevices

4.4.2

grid

4.4.2

gridExtra

2.3

gsubfn

0.7

gt

0.11.1

gtable

0.3.6

hardhat

1.4.1

haven

2.5.4

highr

0.11

hms

1.1.3

htmltools

0.5.8.1

htmlwidgets

1.6.4

httpuv

1.6.15

httr

1.4.7

httr2

1.1.1

ids

1.0.1

ini

0.3.1

ipred

0.9-15

isoband

0.2.7

iterators

1.0.14

jquerylib

0.1.4

jsonlite

1.9.1

juicyjuice

0.1.0

KernSmooth

2.23-22

knitr

1.50

labeling

0.4.3

later

1.4.1

lattice

0.22-5

lava

1.8.1

lifecycle

1.0.4

listenv

0.9.1

lubridate

1.9.4

magrittr

2.0.3

markdown

1.13

MASS

7.3-60.0.1

Matrix

1.6-5

memoise

2.0.1

methods

4.4.2

mgcv

1.9-1

mime

0.13

miniUI

0.1.1.1

mlflow

2.20.4

ModelMetrics

1.2.2.2

modelr

0.1.11

munsell

0.5.1

nlme

3.1-164

nnet

7.3-19

numDeriv

2016.8-1.1

openssl

2.3.3

parallel

4.4.2

parallelly

1.42.0

pillar

1.11.0

pkgbuild

1.4.6

pkgconfig

2.0.3

pkgdown

2.1.1

pkgload

1.4.0

plogr

0.2.0

plyr

1.8.9

praise

1.0.0

prettyunits

1.2.0

pROC

1.18.5

processx

3.8.6

prodlim

2024.06.25

profvis

0.4.0

progress

1.2.3

progressr

0.15.1

promises

1.3.2

proto

1.0.0

proxy

0.4-27

ps

1.9.0

purrr

1.0.4

R6

2.6.1

ragg

1.3.3

randomForest

4.7-1.2

rappdirs

0.3.3

rcmdcheck

1.4.0

RColorBrewer

1.1-3

Rcpp

1.0.14

RcppEigen

0.3.4.0.2

reactable

0.4.4

reactR

0.6.1

readr

2.1.5

readxl

1.4.5

recipes

1.2.0

rematch

2.0.0

rematch2

2.1.2

remotes

2.5.0

reprex

2.1.1

reshape2

1.4.4

rlang

1.1.6

rmarkdown

2.29

RODBC

1.3-26

roxygen2

7.3.2

rpart

4.1.23

rprojroot

2.0.4

Rserve

1.8-15

RSQLite

2.3.9

rstudioapi

0.17.1

rversions

2.1.2

rvest

1.0.4

sass

0.4.9

scales

1.3.0

selectr

0.4-2

sessioninfo

1.2.3

shape

1.4.6.1

shiny

1.10.0

sourcetools

0.1.7-1

sparklyr

1.9.1

SparkR

4.0.0

sparsevctrs

0.3.1

spatial

7.3-17

splines

4.4.2

sqldf

0.4-11

SQUAREM

2021.1

stats

4.4.2

stats4

4.4.2

stringi

1.8.7

stringr

1.5.1

survival

3.5-8

swagger

5.17.14.1

sys

3.4.3

systemfonts

1.2.1

tcltk

4.4.2

testthat

3.2.3

textshaping

1.0.0

tibble

3.3.0

tidyr

1.3.1

tidyselect

1.2.1

tidyverse

2.0.0

timechange

0.3.0

timeDate

4041.110

tinytex

0.56

tools

4.4.2

tzdb

0.5.0

urlchecker

1.0.1

usethis

3.1.0

utf8

1.2.6

utils

4.4.2

uuid

1.2-1

V8

6.0.2

vctrs

0.6.5

viridisLite

0.4.2

vroom

1.6.5

waldo

0.6.1

whisker

0.4.1

withr

3.0.2

xfun

0.51

xml2

1.3.8

xopen

1.0.1

xtable

1.8-4

yaml

2.3.10

zeallot

0.1.0

zip

2.3.2

Installed Java and Scala libraries (Scala 2.13 cluster version)

Group ID

Artifact ID

Version

antlr

antlr

2.7.7

com.amazonaws

amazon-kinesis-client

1.12.0

com.amazonaws

aws-java-sdk-autoscaling

1.12.638

com.amazonaws

aws-java-sdk-cloudformation

1.12.638

com.amazonaws

aws-java-sdk-cloudfront

1.12.638

com.amazonaws

aws-java-sdk-cloudhsm

1.12.638

com.amazonaws

aws-java-sdk-cloudsearch

1.12.638

com.amazonaws

aws-java-sdk-cloudtrail

1.12.638

com.amazonaws

aws-java-sdk-cloudwatch

1.12.638

com.amazonaws

aws-java-sdk-cloudwatchmetrics

1.12.638

com.amazonaws

aws-java-sdk-codedeploy

1.12.638

com.amazonaws

aws-java-sdk-cognitoidentity

1.12.638

com.amazonaws

aws-java-sdk-cognitosync

1.12.638

com.amazonaws

aws-java-sdk-config

1.12.638

com.amazonaws

aws-java-sdk-core

1.12.638

com.amazonaws

aws-java-sdk-datapipeline

1.12.638

com.amazonaws

aws-java-sdk-directconnect

1.12.638

com.amazonaws

aws-java-sdk-directory

1.12.638

com.amazonaws

aws-java-sdk-dynamodb

1.12.638

com.amazonaws

aws-java-sdk-ec2

1.12.638

com.amazonaws

aws-java-sdk-ecs

1.12.638

com.amazonaws

aws-java-sdk-efs

1.12.638

com.amazonaws

aws-java-sdk-elasticache

1.12.638

com.amazonaws

aws-java-sdk-elasticbeanstalk

1.12.638

com.amazonaws

aws-java-sdk-elasticloadbalancing

1.12.638

com.amazonaws

aws-java-sdk-elastictranscoder

1.12.638

com.amazonaws

aws-java-sdk-emr

1.12.638

com.amazonaws

aws-java-sdk-glacier

1.12.638

com.amazonaws

aws-java-sdk-glue

1.12.638

com.amazonaws

aws-java-sdk-iam

1.12.638

com.amazonaws

aws-java-sdk-importexport

1.12.638

com.amazonaws

aws-java-sdk-kinesis

1.12.638

com.amazonaws

aws-java-sdk-kms

1.12.638

com.amazonaws

aws-java-sdk-lambda

1.12.638

com.amazonaws

aws-java-sdk-logs

1.12.638

com.amazonaws

aws-java-sdk-machinelearning

1.12.638

com.amazonaws

aws-java-sdk-opsworks

1.12.638

com.amazonaws

aws-java-sdk-rds

1.12.638

com.amazonaws

aws-java-sdk-redshift

1.12.638

com.amazonaws

aws-java-sdk-route53

1.12.638

com.amazonaws

aws-java-sdk-s3

1.12.638

com.amazonaws

aws-java-sdk-ses

1.12.638

com.amazonaws

aws-java-sdk-simpledb

1.12.638

com.amazonaws

aws-java-sdk-simpleworkflow

1.12.638

com.amazonaws

aws-java-sdk-sns

1.12.638

com.amazonaws

aws-java-sdk-sqs

1.12.638

com.amazonaws

aws-java-sdk-ssm

1.12.638

com.amazonaws

aws-java-sdk-storagegateway

1.12.638

com.amazonaws

aws-java-sdk-sts

1.12.638

com.amazonaws

aws-java-sdk-support

1.12.638

com.amazonaws

aws-java-sdk-swf-libraries

1.11.22

com.amazonaws

aws-java-sdk-workspaces

1.12.638

com.amazonaws

jmespath-java

1.12.638

com.clearspring.analytics

stream

2.9.8

com.databricks

Rserve

1.8-3

com.databricks

databricks-sdk-java

0.27.0

com.databricks

jets3t

0.7.1-0

com.databricks.scalapb

scalapb-runtime_2.13

0.4.15-11

com.esotericsoftware

kryo-shaded

4.0.3

com.esotericsoftware

minlog

1.3.0

com.fasterxml

classmate

1.5.1

com.fasterxml.jackson.core

jackson-annotations

2.18.2

com.fasterxml.jackson.core

jackson-core

2.18.2

com.fasterxml.jackson.core

jackson-databind

2.18.2

com.fasterxml.jackson.dataformat

jackson-dataformat-cbor

2.18.2

com.fasterxml.jackson.dataformat

jackson-dataformat-yaml

2.15.2

com.fasterxml.jackson.datatype

jackson-datatype-joda

2.18.2

com.fasterxml.jackson.datatype

jackson-datatype-jsr310

2.18.2

com.fasterxml.jackson.module

jackson-module-paranamer

2.18.2

com.fasterxml.jackson.module

jackson-module-scala_2.13

2.18.2

com.github.ben-manes.caffeine

caffeine

2.9.3

com.github.blemale

scaffeine_2.13

4.1.0

com.github.fommil

jniloader

1.1

com.github.fommil.netlib

native_ref-java

1.1

com.github.fommil.netlib

native_ref-java

1.1-natives

com.github.fommil.netlib

native_system-java

1.1

com.github.fommil.netlib

native_system-java

1.1-natives

com.github.fommil.netlib

netlib-native_ref-linux-x86_64

1.1-natives

com.github.fommil.netlib

netlib-native_system-linux-x86_64

1.1-natives

com.github.luben

zstd-jni

1.5.6-10

com.github.virtuald

curvesapi

1.08

com.github.wendykierp

JTransforms

3.1

com.google.api.grpc

proto-google-common-protos

2.5.1

com.google.code.findbugs

jsr305

3.0.0

com.google.code.gson

gson

2.11.0

com.google.crypto.tink

tink

1.16.0

com.google.errorprone

error_prone_annotations

2.36.0

com.google.flatbuffers

flatbuffers-java

24.3.25

com.google.guava

failureaccess

1.0.2

com.google.guava

guava

33.4.0-jre

com.google.guava

listenablefuture

9999.0-empty-to-avoid-conflict-with-guava

com.google.j2objc

j2objc-annotations

3.0.0

com.google.protobuf

protobuf-java

3.25.5

com.google.protobuf

protobuf-java-util

3.25.5

com.helger

profiler

1.1.1

com.ibm.icu

icu4j

75.1

com.jcraft

jsch

0.1.55

com.lihaoyi

sourcecode_2.13

0.1.9

com.microsoft.azure

azure-data-lake-store-sdk

2.3.10

com.microsoft.sqlserver

mssql-jdbc

11.2.2.jre8

com.microsoft.sqlserver

mssql-jdbc

12.8.0.jre8

com.ning

compress-lzf

1.1.2

com.sun.mail

javax.mail

1.5.2

com.sun.xml.bind

jaxb-core

2.2.11

com.sun.xml.bind

jaxb-impl

2.2.11

com.tdunning

json

1.8

com.thoughtworks.paranamer

paranamer

2.8

com.trueaccord.lenses

lenses_2.13

0.4.13

com.twitter

chill-java

0.10.0

com.twitter

chill_2.13

0.10.0

com.twitter

util-app_2.13

19.8.1

com.twitter

util-core_2.13

19.8.1

com.twitter

util-function_2.13

19.8.1

com.twitter

util-jvm_2.13

19.8.1

com.twitter

util-lint_2.13

19.8.1

com.twitter

util-registry_2.13

19.8.1

com.twitter

util-stats_2.13

19.8.1

com.typesafe

config

1.4.3

com.typesafe.scala-logging

scala-logging_2.13

3.9.2

com.uber

h3

3.7.3

com.univocity

univocity-parsers

2.9.1

com.zaxxer

HikariCP

4.0.3

com.zaxxer

SparseBitSet

1.3

commons-cli

commons-cli

1.9.0

commons-codec

commons-codec

1.17.2

commons-collections

commons-collections

3.2.2

commons-dbcp

commons-dbcp

1.4

commons-fileupload

commons-fileupload

1.5

commons-httpclient

commons-httpclient

3.1

commons-io

commons-io

2.18.0

commons-lang

commons-lang

2.6

commons-logging

commons-logging

1.1.3

commons-pool

commons-pool

1.5.4

dev.ludovic.netlib

arpack

3.0.3

dev.ludovic.netlib

blas

3.0.3

dev.ludovic.netlib

lapack

3.0.3

info.ganglia.gmetric4j

gmetric4j

1.0.10

io.airlift

aircompressor

2.0.2

io.delta

delta-sharing-client_2.13

1.3.5

io.dropwizard.metrics

metrics-annotation

4.2.30

io.dropwizard.metrics

metrics-core

4.2.30

io.dropwizard.metrics

metrics-graphite

4.2.30

io.dropwizard.metrics

metrics-healthchecks

4.2.30

io.dropwizard.metrics

metrics-jetty9

4.2.30

io.dropwizard.metrics

metrics-jmx

4.2.30

io.dropwizard.metrics

metrics-json

4.2.30

io.dropwizard.metrics

metrics-jvm

4.2.30

io.dropwizard.metrics

metrics-servlets

4.2.30

io.github.java-diff-utils

java-diff-utils

4.15

io.netty

netty-all

4.1.118.Final

io.netty

netty-buffer

4.1.118.Final

io.netty

netty-codec

4.1.118.Final

io.netty

netty-codec-http

4.1.118.Final

io.netty

netty-codec-http2

4.1.118.Final

io.netty

netty-codec-socks

4.1.118.Final

io.netty

netty-common

4.1.118.Final

io.netty

netty-handler

4.1.118.Final

io.netty

netty-handler-proxy

4.1.118.Final

io.netty

netty-resolver

4.1.118.Final

io.netty

netty-tcnative-boringssl-static

2.0.70.Final-db-r0-linux-aarch_64

io.netty

netty-tcnative-boringssl-static

2.0.70.Final-db-r0-linux-x86_64

io.netty

netty-tcnative-boringssl-static

2.0.70.Final-db-r0-osx-aarch_64

io.netty

netty-tcnative-boringssl-static

2.0.70.Final-db-r0-osx-x86_64

io.netty

netty-tcnative-boringssl-static

2.0.70.Final-db-r0-windows-x86_64

io.netty

netty-tcnative-classes

2.0.70.Final

io.netty

netty-transport

4.1.118.Final

io.netty

netty-transport-classes-epoll

4.1.118.Final

io.netty

netty-transport-classes-kqueue

4.1.118.Final

io.netty

netty-transport-native-epoll

4.1.118.Final

io.netty

netty-transport-native-epoll

4.1.118.Final-linux-aarch_64

io.netty

netty-transport-native-epoll

4.1.118.Final-linux-riscv64

io.netty

netty-transport-native-epoll

4.1.118.Final-linux-x86_64

io.netty

netty-transport-native-kqueue

4.1.118.Final-osx-aarch_64

io.netty

netty-transport-native-kqueue

4.1.118.Final-osx-x86_64

io.netty

netty-transport-native-unix-common

4.1.118.Final

io.prometheus

simpleclient

0.16.1-databricks

io.prometheus

simpleclient_common

0.16.1-databricks

io.prometheus

simpleclient_dropwizard

0.16.1-databricks

io.prometheus

simpleclient_pushgateway

0.16.1-databricks

io.prometheus

simpleclient_servlet

0.16.1-databricks

io.prometheus

simpleclient_servlet_common

0.16.1-databricks

io.prometheus

simpleclient_tracer_common

0.16.1-databricks

io.prometheus

simpleclient_tracer_otel

0.16.1-databricks

io.prometheus

simpleclient_tracer_otel_agent

0.16.1-databricks

io.prometheus.jmx

collector

0.18.0

jakarta.annotation

jakarta.annotation-api

1.3.5

jakarta.servlet

jakarta.servlet-api

4.0.3

jakarta.validation

jakarta.validation-api

2.0.2

jakarta.ws.rs

jakarta.ws.rs-api

2.1.6

javax.activation

activation

1.1.1

javax.annotation

javax.annotation-api

1.3.2

javax.el

javax.el-api

2.2.4

javax.jdo

jdo-api

3.0.1

javax.media

jai_core

jai_core_dummy

javax.transaction

jta

1.1

javax.transaction

transaction-api

1.1

javax.xml.bind

jaxb-api

2.2.11

javolution

javolution

5.5.1

jline

jline

2.14.6

joda-time

joda-time

2.13.0

net.java.dev.jna

jna

5.8.0

net.razorvine

pickle

1.5

net.sf.jpam

jpam

1.1

net.sf.opencsv

opencsv

2.3

net.sf.supercsv

super-csv

2.2.0

net.snowflake

snowflake-ingest-sdk

0.9.6

net.sourceforge.f2j

arpack_combined_all

0.1

org.acplt.remotetea

remotetea-oncrpc

1.1.2

org.antlr

ST4

4.0.4

org.antlr

antlr-runtime

3.5.2

org.antlr

antlr4-runtime

4.13.1

org.antlr

stringtemplate

3.2.1

org.apache.ant

ant

1.10.11

org.apache.ant

ant-jsch

1.10.11

org.apache.ant

ant-launcher

1.10.11

org.apache.arrow

arrow-format

18.2.0

org.apache.arrow

arrow-memory-core

18.2.0

org.apache.arrow

arrow-memory-netty

18.2.0

org.apache.arrow

arrow-memory-netty-buffer-patch

18.2.0

org.apache.arrow

arrow-vector

18.2.0

org.apache.avro

avro

1.12.0

org.apache.avro

avro-ipc

1.12.0

org.apache.avro

avro-mapred

1.12.0

org.apache.commons

commons-collections4

4.4

org.apache.commons

commons-compress

1.27.1

org.apache.commons

commons-crypto

1.1.0

org.apache.commons

commons-lang3

3.17.0

org.apache.commons

commons-math3

3.6.1

org.apache.commons

commons-text

1.13.0

org.apache.curator

curator-client

5.7.1

org.apache.curator

curator-framework

5.7.1

org.apache.curator

curator-recipes

5.7.1

org.apache.datasketches

datasketches-java

6.1.1

org.apache.datasketches

datasketches-memory

3.0.2

org.apache.derby

derby

10.14.2.0

org.apache.hadoop

hadoop-client-runtime

3.4.1

org.apache.hive

hive-beeline

2.3.10

org.apache.hive

hive-cli

2.3.10

org.apache.hive

hive-jdbc

2.3.10

org.apache.hive

hive-llap-client

2.3.10

org.apache.hive

hive-llap-common

2.3.10

org.apache.hive

hive-serde

2.3.10

org.apache.hive

hive-shims

2.3.10

org.apache.hive

hive-storage-api

2.8.1

org.apache.hive.shims

hive-shims-0.23

2.3.10

org.apache.hive.shims

hive-shims-common

2.3.10

org.apache.hive.shims

hive-shims-scheduler

2.3.10

org.apache.httpcomponents

httpclient

4.5.14

org.apache.httpcomponents

httpcore

4.4.16

org.apache.ivy

ivy

2.5.3

org.apache.logging.log4j

log4j-1.2-api

2.24.3

org.apache.logging.log4j

log4j-api

2.24.3

org.apache.logging.log4j

log4j-core

2.24.3

org.apache.logging.log4j

log4j-layout-template-json

2.24.3

org.apache.logging.log4j

log4j-slf4j2-impl

2.24.3

org.apache.orc

orc-core

2.1.1-shaded-protobuf

org.apache.orc

orc-format

1.1.0-shaded-protobuf

org.apache.orc

orc-mapreduce

2.1.1-shaded-protobuf

org.apache.orc

orc-shims

2.1.1

org.apache.poi

poi

5.4.1

org.apache.poi

poi-ooxml

5.4.1

org.apache.poi

poi-ooxml-full

5.4.1

org.apache.poi

poi-ooxml-lite

5.4.1

org.apache.thrift

libfb303

0.9.3

org.apache.thrift

libthrift

0.16.0

org.apache.ws.xmlschema

xmlschema-core

2.3.1

org.apache.xbean

xbean-asm9-shaded

4.26

org.apache.xmlbeans

xmlbeans

5.3.0

org.apache.yetus

audience-annotations

0.13.0

org.apache.zookeeper

zookeeper

3.9.3

org.apache.zookeeper

zookeeper-jute

3.9.3

org.checkerframework

checker-qual

3.43.0

org.codehaus.janino

commons-compiler

3.0.16

org.codehaus.janino

janino

3.0.16

org.datanucleus

datanucleus-api-jdo

4.2.4

org.datanucleus

datanucleus-core

4.1.17

org.datanucleus

datanucleus-rdbms

4.1.19

org.datanucleus

javax.jdo

3.2.0-m3

org.eclipse.jetty

jetty-client

9.4.53.v20231009

org.eclipse.jetty

jetty-continuation

9.4.53.v20231009

org.eclipse.jetty

jetty-http

9.4.53.v20231009

org.eclipse.jetty

jetty-io

9.4.53.v20231009

org.eclipse.jetty

jetty-jndi

9.4.53.v20231009

org.eclipse.jetty

jetty-plus

9.4.53.v20231009

org.eclipse.jetty

jetty-proxy

9.4.53.v20231009

org.eclipse.jetty

jetty-security

9.4.53.v20231009

org.eclipse.jetty

jetty-server

9.4.53.v20231009

org.eclipse.jetty

jetty-servlet

9.4.53.v20231009

org.eclipse.jetty

jetty-servlets

9.4.53.v20231009

org.eclipse.jetty

jetty-util

9.4.53.v20231009

org.eclipse.jetty

jetty-util-ajax

9.4.53.v20231009

org.eclipse.jetty

jetty-webapp

9.4.53.v20231009

org.eclipse.jetty

jetty-xml

9.4.53.v20231009

org.eclipse.jetty.websocket

websocket-api

9.4.53.v20231009

org.eclipse.jetty.websocket

websocket-client

9.4.53.v20231009

org.eclipse.jetty.websocket

websocket-common

9.4.53.v20231009

org.eclipse.jetty.websocket

websocket-server

9.4.53.v20231009

org.eclipse.jetty.websocket

websocket-servlet

9.4.53.v20231009

org.fusesource.leveldbjni

leveldbjni-all

1.8

org.glassfish.hk2

hk2-api

2.6.1

org.glassfish.hk2

hk2-locator

2.6.1

org.glassfish.hk2

hk2-utils

2.6.1

org.glassfish.hk2

osgi-resource-locator

1.0.3

org.glassfish.hk2.external

aopalliance-repackaged

2.6.1

org.glassfish.hk2.external

jakarta.inject

2.6.1

org.glassfish.jersey.containers

jersey-container-servlet

2.41

org.glassfish.jersey.containers

jersey-container-servlet-core

2.41

org.glassfish.jersey.core

jersey-client

2.41

org.glassfish.jersey.core

jersey-common

2.41

org.glassfish.jersey.core

jersey-server

2.41

org.glassfish.jersey.inject

jersey-hk2

2.41

org.hibernate.validator

hibernate-validator

6.2.5.Final

org.ini4j

ini4j

0.5.4

org.javassist

javassist

3.29.2-GA

org.jboss.logging

jboss-logging

3.4.1.Final

org.jdbi

jdbi

2.63.1

org.jetbrains

annotations

17.0.0

org.jline

jline

3.27.1-jdk8

org.joda

joda-convert

1.7

org.jodd

jodd-core

3.5.2

org.json4s

json4s-ast_2.13

4.0.7

org.json4s

json4s-core_2.13

4.0.7

org.json4s

json4s-jackson-core_2.13

4.0.7

org.json4s

json4s-jackson_2.13

4.0.7

org.json4s

json4s-scalap_2.13

4.0.7

org.lz4

lz4-java

1.8.0-databricks-1

org.mlflow

mlflow-spark_2.13

2.9.1

org.objenesis

objenesis

3.3

org.postgresql

postgresql

42.6.1

org.roaringbitmap

RoaringBitmap

1.2.1

org.rocksdb

rocksdbjni

9.8.4

org.rosuda.REngine

REngine

2.1.0

org.scala-lang

scala-compiler_2.13

2.13.16

org.scala-lang

scala-library_2.13

2.13.16

org.scala-lang

scala-reflect_2.13

2.13.16

org.scala-lang.modules

scala-collection-compat_2.13

2.11.0

org.scala-lang.modules

scala-java8-compat_2.13

0.9.1

org.scala-lang.modules

scala-parallel-collections_2.13

1.2.0

org.scala-lang.modules

scala-parser-combinators_2.13

2.4.0

org.scala-lang.modules

scala-xml_2.13

2.3.0

org.scala-sbt

test-interface

1.0

org.scalacheck

scalacheck_2.13

1.18.0

org.scalactic

scalactic_2.13

3.2.19

org.scalanlp

breeze-macros_2.13

2.1.0

org.scalanlp

breeze_2.13

2.1.0

org.scalatest

scalatest-compatible

3.2.19

org.scalatest

scalatest-core_2.13

3.2.19

org.scalatest

scalatest-diagrams_2.13

3.2.19

org.scalatest

scalatest-featurespec_2.13

3.2.19

org.scalatest

scalatest-flatspec_2.13

3.2.19

org.scalatest

scalatest-freespec_2.13

3.2.19

org.scalatest

scalatest-funspec_2.13

3.2.19

org.scalatest

scalatest-funsuite_2.13

3.2.19

org.scalatest

scalatest-matchers-core_2.13

3.2.19

org.scalatest

scalatest-mustmatchers_2.13

3.2.19

org.scalatest

scalatest-propspec_2.13

3.2.19

org.scalatest

scalatest-refspec_2.13

3.2.19

org.scalatest

scalatest-shouldmatchers_2.13

3.2.19

org.scalatest

scalatest-wordspec_2.13

3.2.19

org.scalatest

scalatest_2.13

3.2.19

org.slf4j

jcl-over-slf4j

2.0.16

org.slf4j

jul-to-slf4j

2.0.16

org.slf4j

slf4j-api

2.0.16

org.slf4j

slf4j-simple

1.7.25

org.threeten

threeten-extra

1.8.0

org.tukaani

xz

1.10

org.typelevel

algebra_2.13

2.8.0

org.typelevel

cats-kernel_2.13

2.8.0

org.typelevel

spire-macros_2.13

0.18.0

org.typelevel

spire-platform_2.13

0.18.0

org.typelevel

spire-util_2.13

0.18.0

org.typelevel

spire_2.13

0.18.0

org.wildfly.openssl

wildfly-openssl

1.1.3.Final

org.xerial

sqlite-jdbc

3.42.0.0

org.xerial.snappy

snappy-java

1.1.10.3

org.yaml

snakeyaml

2.0

oro

oro

2.0.8

pl.edu.icm

JLargeArrays

1.5

software.amazon.cryptools

AmazonCorrettoCryptoProvider

2.5.0-linux-x86_64

stax

stax-api

1.0.1

tip

To see release notes for Databricks Runtime versions that have reached end-of-support (EoS), see End-of-support Databricks Runtime release notes. The EoS Databricks Runtime versions have been retired and might not be updated.