package spark.connect

Mouse Melon logoGet desktop application:
View/edit binary Protocol Buffers messages

service SparkConnectService

base.proto:1081

Main interface for the SparkConnect service.

message AddArtifactsRequest.ArtifactChunk

base.proto:617

A chunk of an Artifact.

Used in: AddArtifactsRequest, BeginChunkedArtifact, SingleChunkArtifact

message AddArtifactsRequest.Batch

base.proto:639

A number of `SingleChunkArtifact` batched into a single RPC.

Used in: AddArtifactsRequest

message AddArtifactsRequest.BeginChunkedArtifact

base.proto:646

Signals the beginning/start of a chunked artifact. A large artifact is transferred through a payload of `BeginChunkedArtifact` followed by a sequence of `ArtifactChunk`s.

Used in: AddArtifactsRequest

message AddArtifactsRequest.SingleChunkArtifact

base.proto:626

An artifact that is contained in a single `ArtifactChunk`. Generally, this message represents tiny artifacts such as REPL-generated class files.

Used in: Batch

message AddArtifactsResponse.ArtifactSummary

base.proto:686

Metadata of an artifact.

Used in: AddArtifactsResponse

message Aggregate

relations.proto:354

Relation of type [[Aggregate]].

Used in: Relation

enum Aggregate.GroupType

relations.proto:373

Used in: Aggregate

message Aggregate.GroupingSets

relations.proto:393

Used in: Aggregate

message Aggregate.Pivot

relations.proto:382

Used in: Aggregate

message AnalyzePlanRequest.DDLParse

base.proto:183

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.Explain

base.proto:126

Explains the input plan based on a configurable mode.

Used in: AnalyzePlanRequest

enum AnalyzePlanRequest.Explain.ExplainMode

base.proto:134

Plan explanation mode.

Used in: Explain

message AnalyzePlanRequest.GetStorageLevel

base.proto:219

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.InputFiles

base.proto:176

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.IsLocal

base.proto:166

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.IsStreaming

base.proto:171

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.Persist

base.proto:203

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.SameSemantics

base.proto:190

Returns `true` when the logical query plans are equal and therefore return same results.

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.Schema

base.proto:120

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.SemanticHash

base.proto:198

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.SparkVersion

base.proto:181

Used in: AnalyzePlanRequest

(message has no fields)

message AnalyzePlanRequest.TreeString

base.proto:158

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.Unpersist

base.proto:211

Used in: AnalyzePlanRequest

message AnalyzePlanResponse.DDLParse

base.proto:279

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.Explain

base.proto:254

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.GetStorageLevel

base.proto:295

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.InputFiles

base.proto:270

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.IsLocal

base.proto:262

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.IsStreaming

base.proto:266

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.Persist

base.proto:291

Used in: AnalyzePlanResponse

(message has no fields)

message AnalyzePlanResponse.SameSemantics

base.proto:283

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.Schema

base.proto:250

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.SemanticHash

base.proto:287

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.SparkVersion

base.proto:275

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.TreeString

base.proto:258

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.Unpersist

base.proto:293

Used in: AnalyzePlanResponse

(message has no fields)

message ApplyInPandasWithState

relations.proto:997

Used in: Relation

message ArtifactStatusesResponse.ArtifactStatus

base.proto:739

Used in: ArtifactStatusesResponse

message AsOfJoin

relations.proto:1101

Relation of type [[AsOfJoin]]. `left` and `right` must be present.

Used in: Relation

message CacheTable

catalog.proto:222

See `spark.catalog.cacheTable`

Used in: Catalog

message CachedLocalRelation

relations.proto:460

A local relation that has been cached already.

Used in: Relation

message CachedRemoteRelation

relations.proto:472

Represents a remote relation that has been cached on server.

Used in: CheckpointCommandResult, Relation, RemoveCachedRemoteRelationCommand

message CallFunction

expressions.proto:414

Used in: Expression

message Catalog

catalog.proto:51

Catalog messages are marked as unstable.

Used in: Relation

message CheckpointCommand

commands.proto:517

Used in: Command

message CheckpointCommandResult

base.proto:1075

Used in: ExecutePlanResponse

message ClearCache

catalog.proto:237

See `spark.catalog.clearCache`

Used in: Catalog

(message has no fields)

message CoGroupMap

relations.proto:974

Used in: Relation

message CollectMetrics

relations.proto:1069

Collect arbitrary (named) metrics from a dataset.

Used in: Relation

message Command

commands.proto:54

A [[Command]] is an operation that is executed by the server that does not directly consume or produce a relational result.

Used in: Plan

message CommonInlineUserDefinedDataSource

relations.proto:1050

Used in: Command, Relation

message CommonInlineUserDefinedFunction

expressions.proto:366

Used in: ApplyInPandasWithState, CoGroupMap, Command, Expression, GroupMap, MapPartitions

message CommonInlineUserDefinedTableFunction

relations.proto:1020

Used in: Command, Relation

message ConfigRequest.Get

base.proto:540

Used in: Operation

message ConfigRequest.GetAll

base.proto:555

Used in: Operation

message ConfigRequest.GetOption

base.proto:550

Used in: Operation

message ConfigRequest.GetWithDefault

base.proto:545

Used in: Operation

message ConfigRequest.IsModifiable

base.proto:565

Used in: Operation

message ConfigRequest.Operation

base.proto:523

Used in: ConfigRequest

message ConfigRequest.Set

base.proto:535

Used in: Operation

message ConfigRequest.Unset

base.proto:560

Used in: Operation

message CreateDataFrameViewCommand

commands.proto:108

A command that can create DataFrame global temp view or local temp view.

Used in: Command

message CreateExternalTable

catalog.proto:166

See `spark.catalog.createExternalTable`

Used in: Catalog

message CreateResourceProfileCommand

commands.proto:500

Command to create ResourceProfile

Used in: Command

message CreateResourceProfileCommandResult

commands.proto:506

Response for command 'CreateResourceProfileCommand'.

Used in: ExecutePlanResponse

message CreateTable

catalog.proto:181

See `spark.catalog.createTable`

Used in: Catalog

message CurrentCatalog

catalog.proto:252

See `spark.catalog.currentCatalog`

Used in: Catalog

(message has no fields)

message CurrentDatabase

catalog.proto:83

See `spark.catalog.currentDatabase`

Used in: Catalog

(message has no fields)

message DataType

types.proto:49

This message describes the logical [[DataType]] of something. It does not carry the value itself but only describes it.

Used in: delta.connect.ConvertToDelta, AnalyzePlanResponse.DDLParse, AnalyzePlanResponse.Schema, CreateExternalTable, CreateTable, DataType.Array, DataType.Map, DataType.StructField, DataType.UDT, ExecutePlanResponse, Expression.Cast, Expression.Literal, Expression.Literal.Array, Expression.Literal.Map, Expression.Literal.Struct, JavaUDF, Parse, PythonUDF, PythonUDTF, ScalarScalaUDF, ToSchema

message DataType.Array

types.proto:193

Used in: DataType

message DataType.Binary

types.proto:128

Used in: DataType

message DataType.Boolean

types.proto:95

Used in: DataType

message DataType.Byte

types.proto:99

Used in: DataType

message DataType.CalendarInterval

types.proto:148

Used in: DataType

message DataType.Char

types.proto:165

Start compound types.

Used in: DataType

message DataType.Date

types.proto:140

Used in: DataType

message DataType.DayTimeInterval

types.proto:158

Used in: DataType

message DataType.Decimal

types.proto:175

Used in: DataType

message DataType.Double

types.proto:119

Used in: DataType

message DataType.Float

types.proto:115

Used in: DataType

message DataType.Integer

types.proto:107

Used in: DataType

message DataType.Long

types.proto:111

Used in: DataType

message DataType.Map

types.proto:199

Used in: DataType

message DataType.NULL

types.proto:132

Used in: DataType

message DataType.Short

types.proto:103

Used in: DataType

message DataType.String

types.proto:123

Used in: DataType

message DataType.Struct

types.proto:188

Used in: DataType

message DataType.StructField

types.proto:181

Used in: Struct

message DataType.Timestamp

types.proto:136

Used in: DataType

message DataType.TimestampNTZ

types.proto:144

Used in: DataType

message DataType.UDT

types.proto:210

Used in: DataType

message DataType.Unparsed

types.proto:218

Used in: DataType

message DataType.VarChar

types.proto:170

Used in: DataType

message DataType.Variant

types.proto:206

Used in: DataType

message DataType.YearMonthInterval

types.proto:152

Used in: DataType

message DatabaseExists

catalog.proto:144

See `spark.catalog.databaseExists`

Used in: Catalog

message Deduplicate

relations.proto:427

Relation of type [[Deduplicate]] which have duplicate rows removed, could consider either only the subset of columns or all the columns.

Used in: Relation

message Drop

relations.proto:413

Drop specified columns.

Used in: Relation

message DropGlobalTempView

catalog.proto:204

See `spark.catalog.dropGlobalTempView`

Used in: Catalog

message DropTempView

catalog.proto:198

See `spark.catalog.dropTempView`

Used in: Catalog

message ExamplePluginCommand

example_plugins.proto:61

message ExamplePluginExpression

example_plugins.proto:56

message ExamplePluginRelation

example_plugins.proto:50

message ExecutePlanRequest.RequestOption

base.proto:341

Used in: ExecutePlanRequest

message ExecutePlanResponse

base.proto:358

The response of a query, can be one or more for each request. Responses belonging to the same input query, carry the same `session_id`. Next ID: 17

Used as response type in: SparkConnectService.ExecutePlan, SparkConnectService.ReattachExecute

message ExecutePlanResponse.ArrowBatch

base.proto:429

Batch results of metrics.

Used in: ExecutePlanResponse

message ExecutePlanResponse.ExecutionProgress

base.proto:471

This message is used to communicate progress about the query progress during the execution.

Used in: ExecutePlanResponse

message ExecutePlanResponse.ExecutionProgress.StageInfo

base.proto:478

Used in: ExecutionProgress

message ExecutePlanResponse.Metrics

base.proto:439

Used in: ExecutePlanResponse

message ExecutePlanResponse.Metrics.MetricObject

base.proto:443

Used in: Metrics

message ExecutePlanResponse.Metrics.MetricValue

base.proto:450

Used in: MetricObject

message ExecutePlanResponse.ObservedMetrics

base.proto:457

Used in: ExecutePlanResponse

message ExecutePlanResponse.ResultComplete

base.proto:464

If present, in a reattachable execution this means that after server sends onComplete, the execution is complete. If the server sends onComplete without sending a ResultComplete, it means that there is more, and the client should use ReattachExecute RPC to continue.

Used in: ExecutePlanResponse

(message has no fields)

message ExecutePlanResponse.SqlCommandResult

base.proto:424

A SQL command returns an opaque Relation that can be directly used as input for the next call.

Used in: ExecutePlanResponse

message ExecutorResourceRequest

common.proto:72

An executor resource request.

Used in: ResourceProfile

message Expression

expressions.proto:52

Expression used to refer to fields, functions and similar. This can be used everywhere expressions in SQL appear.

Used in: delta.connect.Assignment, delta.connect.DeleteFromTable, delta.connect.UpdateTable, Aggregate, Aggregate.GroupingSets, Aggregate.Pivot, ApplyInPandasWithState, AsOfJoin, CallFunction, CoGroupMap, CollectMetrics, CommonInlineUserDefinedFunction, CommonInlineUserDefinedTableFunction, Drop, ExamplePluginExpression, Expression.Alias, Expression.Cast, Expression.LambdaFunction, Expression.SortOrder, Expression.UnresolvedExtractValue, Expression.UnresolvedFunction, Expression.UpdateFields, Expression.Window, Expression.Window.WindowFrame.FrameBoundary, Filter, GroupMap, Hint, Join, NamedArgumentExpression, Project, RepartitionByExpression, SQL, SqlCommand, StatSampleBy, Unpivot, Unpivot.Values, WriteOperationV2

message Expression.Alias

expressions.proto:335

Used in: Expression, WithColumns

message Expression.Cast

expressions.proto:161

Used in: Expression

enum Expression.Cast.EvalMode

expressions.proto:175

Used in: Cast

message Expression.ExpressionString

expressions.proto:282

Expression as string.

Used in: Expression

message Expression.LambdaFunction

expressions.proto:348

Used in: Expression

message Expression.Literal

expressions.proto:183

Used in: Aggregate.Pivot, ExecutePlanResponse.ObservedMetrics, Expression, Literal.Array, Literal.Map, Literal.Struct, NAFill, NAReplace.Replacement, SQL, SqlCommand, StatSampleBy.Fraction

message Expression.Literal.Array

expressions.proto:230

Used in: Literal

message Expression.Literal.CalendarInterval

expressions.proto:224

Used in: Literal

message Expression.Literal.Decimal

expressions.proto:214

Used in: Literal

message Expression.Literal.Map

expressions.proto:235

Used in: Literal

message Expression.Literal.Struct

expressions.proto:242

Used in: Literal

message Expression.SortOrder

expressions.proto:138

SortOrder is used to specify the data ordering, it is normally used in Sort and Window. It is an unevaluable expression and cannot be evaluated, so can not be used in Projection.

Used in: Expression, Window, Sort

enum Expression.SortOrder.NullOrdering

expressions.proto:154

Used in: SortOrder

enum Expression.SortOrder.SortDirection

expressions.proto:148

Used in: SortOrder

message Expression.UnresolvedAttribute

expressions.proto:250

An unresolved attribute that is not explicitly bound to a specific column, but the column is resolved during analysis by name.

Used in: Expression

message Expression.UnresolvedExtractValue

expressions.proto:311

Extracts a value or values from an Expression

Used in: Expression

message Expression.UnresolvedFunction

expressions.proto:264

An unresolved function is not explicitly bound to one explicit function, but the function is resolved during analysis following Sparks name resolution rules.

Used in: Expression

message Expression.UnresolvedNamedLambdaVariable

expressions.proto:359

Used in: Expression, LambdaFunction

message Expression.UnresolvedRegex

expressions.proto:302

Represents all of the input attributes to a given relational operator, for example in "SELECT `(id)?+.+` FROM ...".

Used in: Expression

message Expression.UnresolvedStar

expressions.proto:288

UnresolvedStar is used to expand all the fields of a relation or struct.

Used in: Expression

message Expression.UpdateFields

expressions.proto:322

Add, replace or drop a field of `StructType` expression by name.

Used in: Expression

message Expression.Window

expressions.proto:80

Expression for the OVER clause or WINDOW clause.

Used in: Expression

message Expression.Window.WindowFrame

expressions.proto:97

The window frame

Used in: Window

message Expression.Window.WindowFrame.FrameBoundary

expressions.proto:119

Used in: WindowFrame

enum Expression.Window.WindowFrame.FrameType

expressions.proto:108

Used in: WindowFrame

message FetchErrorDetailsResponse.Error

base.proto:1056

Error defines the schema for the representing exception.

Used in: FetchErrorDetailsResponse

message FetchErrorDetailsResponse.QueryContext

base.proto:1005

QueryContext defines the schema for the query context of a SparkThrowable. It helps users understand where the error occurs while executing queries.

Used in: SparkThrowable

enum FetchErrorDetailsResponse.QueryContext.ContextType

base.proto:1007

The type of this query context.

Used in: QueryContext

message FetchErrorDetailsResponse.SparkThrowable

base.proto:1040

SparkThrowable defines the schema for SparkThrowable exceptions.

Used in: Error

message FetchErrorDetailsResponse.StackTraceElement

base.proto:989

Used in: Error

message Filter

relations.proto:235

Relation that applies a boolean expression `condition` on each row of `input` to produce the output result.

Used in: Relation

message FunctionExists

catalog.proto:158

See `spark.catalog.functionExists`

Used in: Catalog

message GetDatabase

catalog.proto:122

See `spark.catalog.getDatabase`

Used in: Catalog

message GetFunction

catalog.proto:136

See `spark.catalog.getFunction`

Used in: Catalog

message GetResourcesCommand

commands.proto:492

Command to get the output of 'SparkContext.resources'

Used in: Command

(message has no fields)

message GetResourcesCommandResult

commands.proto:495

Response for command 'GetResourcesCommand'.

Used in: ExecutePlanResponse

message GetTable

catalog.proto:128

See `spark.catalog.getTable`

Used in: Catalog

message GroupMap

relations.proto:944

Used in: Relation

message Hint

relations.proto:872

Specify a hint over a relation. Hint should have a name and optional parameters.

Used in: Relation

message HtmlString

relations.proto:561

Compose the string representing rows for output. It will invoke 'Dataset.htmlString' to compute the results.

Used in: Relation

enum InterruptRequest.InterruptType

base.proto:771

Used in: InterruptRequest

message IsCached

catalog.proto:216

See `spark.catalog.isCached`

Used in: Catalog

message JavaUDF

expressions.proto:403

Used in: CommonInlineUserDefinedFunction

message Join

relations.proto:246

Relation of type [[Join]]. `left` and `right` must be present.

Used in: Relation

message Join.JoinDataType

relations.proto:282

Used in: Join

enum Join.JoinType

relations.proto:268

Used in: Join

message KeyValue

base.proto:489

The key-value pair for the config request and response.

Used in: ConfigRequest.GetWithDefault, ConfigRequest.Set, ConfigResponse

message Limit

relations.proto:326

Relation of type [[Limit]] that is used to `limit` rows from the input relation.

Used in: Relation

message ListCatalogs

catalog.proto:261

See `spark.catalog.listCatalogs`

Used in: Catalog

message ListColumns

catalog.proto:114

See `spark.catalog.listColumns`

Used in: Catalog

message ListDatabases

catalog.proto:92

See `spark.catalog.listDatabases`

Used in: Catalog

message ListFunctions

catalog.proto:106

See `spark.catalog.listFunctions`

Used in: Catalog

message ListTables

catalog.proto:98

See `spark.catalog.listTables`

Used in: Catalog

message LocalRelation

relations.proto:446

A relation that does not need to be qualified by name.

Used in: Relation

message MapPartitions

relations.proto:930

Used in: Relation

message NADrop

relations.proto:754

Drop rows containing null values. It will invoke 'Dataset.na.drop' (same as 'DataFrameNaFunctions.drop') to compute the results.

Used in: Relation

message NAFill

relations.proto:737

Replaces null values. It will invoke 'Dataset.na.fill' (same as 'DataFrameNaFunctions.fill') to compute the results. Following 3 parameter combinations are supported: 1, 'values' only contains 1 item, 'cols' is empty: replaces null values in all type-compatible columns. 2, 'values' only contains 1 item, 'cols' is not empty: replaces null values in specified columns. 3, 'values' contains more than 1 items, then 'cols' is required to have the same length: replaces each specified column with corresponding value.

Used in: Relation

message NAReplace

relations.proto:778

Replaces old values with the corresponding values. It will invoke 'Dataset.na.replace' (same as 'DataFrameNaFunctions.replace') to compute the results.

Used in: Relation

message NAReplace.Replacement

relations.proto:790

Used in: NAReplace

message NamedArgumentExpression

expressions.proto:422

Used in: Expression

message Offset

relations.proto:336

Relation of type [[Offset]] that is used to read rows staring from the `offset` on the input relation.

Used in: Relation

message Parse

relations.proto:1080

Used in: Relation

enum Parse.ParseFormat

relations.proto:1091

Used in: Parse

message Plan

base.proto:58

A [[Plan]] is the structure that carries the runtime information for the execution from the client to the server. A [[Plan]] can either be of the type [[Relation]] which is a reference to the underlying logical plan or it can be of the [[Command]] type that is used to execute commands on the server.

Used in: AnalyzePlanRequest.Explain, AnalyzePlanRequest.InputFiles, AnalyzePlanRequest.IsLocal, AnalyzePlanRequest.IsStreaming, AnalyzePlanRequest.SameSemantics, AnalyzePlanRequest.Schema, AnalyzePlanRequest.SemanticHash, AnalyzePlanRequest.TreeString, ExecutePlanRequest

message Project

relations.proto:223

Projection of a bag of expressions for a given input relation. The input relation must be specified. The projected expression can be an arbitrary expression.

Used in: Relation

message PythonDataSource

relations.proto:1060

Used in: CommonInlineUserDefinedDataSource

message PythonUDF

expressions.proto:381

Used in: CommonInlineUserDefinedFunction, StreamingForeachFunction, StreamingQueryManagerCommand.StreamingQueryListenerCommand

message PythonUDTF

relations.proto:1036

Used in: CommonInlineUserDefinedTableFunction

message Range

relations.proto:503

Relation of type [[Range]] that generates a sequence of integers.

Used in: Relation

message Read

relations.proto:176

Relation that reads from a file / table or other data source. Does not have additional inputs.

Used in: Relation

message Read.DataSource

relations.proto:193

Used in: Read

message Read.NamedTable

relations.proto:185

Used in: Read

message ReattachOptions

base.proto:806

Used in: ExecutePlanRequest.RequestOption

message RecoverPartitions

catalog.proto:210

See `spark.catalog.recoverPartitions`

Used in: Catalog

message RefreshByPath

catalog.proto:246

See `spark.catalog.refreshByPath`

Used in: Catalog

message RefreshTable

catalog.proto:240

See `spark.catalog.refreshTable`

Used in: Catalog

message Relation

relations.proto:56

The main [[Relation]] type. Fundamentally, a relation is a typed container that has exactly one explicit relation type set. When adding new relation types, they have to be registered here.

Used in: delta.connect.DeleteFromTable, delta.connect.UpdateTable, Aggregate, AnalyzePlanRequest.GetStorageLevel, AnalyzePlanRequest.Persist, AnalyzePlanRequest.Unpersist, ApplyInPandasWithState, AsOfJoin, CheckpointCommand, CoGroupMap, CollectMetrics, CreateDataFrameViewCommand, Deduplicate, Drop, ExamplePluginRelation, ExecutePlanResponse.SqlCommandResult, Filter, GroupMap, Hint, HtmlString, Join, Limit, MapPartitions, NADrop, NAFill, NAReplace, Offset, Parse, Plan, Project, Repartition, RepartitionByExpression, Sample, SetOperation, ShowString, Sort, SqlCommand, StatApproxQuantile, StatCorr, StatCov, StatCrosstab, StatDescribe, StatFreqItems, StatSampleBy, StatSummary, SubqueryAlias, Tail, ToDF, ToSchema, Unpivot, WithColumns, WithColumnsRenamed, WithRelations, WithWatermark, WriteOperation, WriteOperationV2, WriteStreamOperationStart

message RelationCommon

relations.proto:129

Common metadata of all relations.

Used in: Relation

message ReleaseExecuteRequest.ReleaseAll

base.proto:889

Release and close operation completely. This will also interrupt the query if it is running execution, and wait for it to be torn down.

Used in: ReleaseExecuteRequest

(message has no fields)

message ReleaseExecuteRequest.ReleaseUntil

base.proto:896

Release all responses from the operation response stream up to and including the response with the given by response_id. While server determines by itself how much of a buffer of responses to keep, client providing explicit release calls will help reduce resource consumption. Noop if response_id not found in cached responses.

Used in: ReleaseExecuteRequest

message RemoveCachedRemoteRelationCommand

commands.proto:512

Command to remove `CashedRemoteRelation`

Used in: Command

message Repartition

relations.proto:531

Relation repartition.

Used in: Relation

message RepartitionByExpression

relations.proto:919

Used in: Relation

message ResourceInformation

common.proto:64

ResourceInformation to hold information about a type of Resource. The corresponding class is 'org.apache.spark.resource.ResourceInformation'

Used in: GetResourcesCommandResult

message ResourceProfile

common.proto:96

Used in: CreateResourceProfileCommand

message SQL

relations.proto:138

Relation that uses a SQL query to generate the output.

Used in: Relation

message Sample

relations.proto:478

Relation of type [[Sample]] that samples a fraction of the dataset.

Used in: Relation

message ScalarScalaUDF

expressions.proto:392

Used in: CommonInlineUserDefinedFunction, StreamingForeachFunction

message SetCurrentCatalog

catalog.proto:255

See `spark.catalog.setCurrentCatalog`

Used in: Catalog

message SetCurrentDatabase

catalog.proto:86

See `spark.catalog.setCurrentDatabase`

Used in: Catalog

message SetOperation

relations.proto:291

Relation of type [[SetOperation]]

Used in: Relation

enum SetOperation.SetOpType

relations.proto:317

Used in: SetOperation

message ShowString

relations.proto:544

Compose the string representing rows for output. It will invoke 'Dataset.showString' to compute the results.

Used in: Relation

message Sort

relations.proto:400

Relation of type [[Sort]].

Used in: Relation

message SqlCommand

commands.proto:85

A SQL Command is used to trigger the eager evaluation of SQL commands in Spark. When the SQL provide as part of the message is a command it will be immediately evaluated and the result will be collected and returned as part of a LocalRelation. If the result is not a command, the operation will simply return a SQL Relation. This allows the client to be almost oblivious to the server-side behavior.

Used in: Command

message StatApproxQuantile

relations.proto:661

Calculates the approximate quantiles of numerical columns of a DataFrame. It will invoke 'Dataset.stat.approxQuantile' (same as 'StatFunctions.approxQuantile') to compute the results.

Used in: Relation

message StatCorr

relations.proto:642

Calculates the correlation of two columns of a DataFrame. Currently only supports the Pearson Correlation Coefficient. It will invoke 'Dataset.stat.corr' (same as 'StatFunctions.pearsonCorrelation') to compute the results.

Used in: Relation

message StatCov

relations.proto:628

Calculate the sample covariance of two numerical columns of a DataFrame. It will invoke 'Dataset.stat.cov' (same as 'StatFunctions.calculateCov') to compute the results.

Used in: Relation

message StatCrosstab

relations.proto:611

Computes a pair-wise frequency table of the given columns. Also known as a contingency table. It will invoke 'Dataset.stat.crosstab' (same as 'StatFunctions.crossTabulate') to compute the results.

Used in: Relation

message StatDescribe

relations.proto:600

Computes basic statistics for numeric and string columns, including count, mean, stddev, min, and max. If no columns are given, this function computes statistics for all numerical or string columns.

Used in: Relation

message StatFreqItems

relations.proto:684

Finding frequent items for columns, possibly with false positives. It will invoke 'Dataset.stat.freqItems' (same as 'StatFunctions.freqItems') to compute the results.

Used in: Relation

message StatSampleBy

relations.proto:701

Returns a stratified sample without replacement based on the fraction given on each stratum. It will invoke 'Dataset.stat.freqItems' (same as 'StatFunctions.freqItems') to compute the results.

Used in: Relation

message StatSampleBy.Fraction

relations.proto:718

Used in: StatSampleBy

message StatSummary

relations.proto:576

Computes specified statistics for numeric and string columns. It will invoke 'Dataset.summary' (same as 'StatFunctions.summary') to compute the results.

Used in: Relation

message StorageLevel

common.proto:48

StorageLevel for persisting Datasets/Tables.

Used in: AnalyzePlanRequest.Persist, AnalyzePlanResponse.GetStorageLevel, CacheTable

message StreamingForeachFunction

commands.proto:265

Used in: WriteStreamOperationStart

message StreamingQueryCommand

commands.proto:304

Commands for a streaming query.

Used in: Command

message StreamingQueryCommand.AwaitTerminationCommand

commands.proto:335

Used in: StreamingQueryCommand

message StreamingQueryCommand.ExplainCommand

commands.proto:329

Used in: StreamingQueryCommand

message StreamingQueryCommandResult

commands.proto:341

Response for commands on a streaming query.

Used in: ExecutePlanResponse

message StreamingQueryCommandResult.AwaitTerminationResult

commands.proto:381

Used in: StreamingQueryCommandResult

message StreamingQueryCommandResult.ExceptionResult

commands.proto:371

Used in: StreamingQueryCommandResult

message StreamingQueryCommandResult.ExplainResult

commands.proto:366

Used in: StreamingQueryCommandResult

message StreamingQueryCommandResult.RecentProgressResult

commands.proto:361

Used in: StreamingQueryCommandResult

message StreamingQueryCommandResult.StatusResult

commands.proto:353

Used in: StreamingQueryCommandResult

enum StreamingQueryEventType

commands.proto:471

The enum used for client side streaming query listener event There is no QueryStartedEvent defined here, it is added as a field in WriteStreamOperationStartResult

Used in: StreamingQueryListenerEvent

message StreamingQueryInstanceId

commands.proto:290

A tuple that uniquely identifies an instance of streaming query run. It consists of `id` that persists across the streaming runs and `run_id` that changes between each run of the streaming query that resumes from the checkpoint.

Used in: StreamingQueryCommand, StreamingQueryCommandResult, StreamingQueryManagerCommandResult.StreamingQueryInstance, WriteStreamOperationStartResult

message StreamingQueryListenerBusCommand

commands.proto:461

The protocol for client-side StreamingQueryListener. This command will only be set when either the first listener is added to the client, or the last listener is removed from the client. The add_listener_bus_listener command will only be set true in the first case. The remove_listener_bus_listener command will only be set true in the second case.

Used in: Command

message StreamingQueryListenerEvent

commands.proto:479

The protocol for the returned events in the long-running response channel.

Used in: StreamingQueryListenerEventsResult

message StreamingQueryListenerEventsResult

commands.proto:486

Used in: ExecutePlanResponse

message StreamingQueryManagerCommand

commands.proto:387

Commands for the streaming query manager.

Used in: Command

message StreamingQueryManagerCommand.AwaitAnyTerminationCommand

commands.proto:407

Used in: StreamingQueryManagerCommand

message StreamingQueryManagerCommand.StreamingQueryListenerCommand

commands.proto:412

Used in: StreamingQueryManagerCommand

message StreamingQueryManagerCommandResult

commands.proto:420

Response for commands on the streaming query manager.

Used in: ExecutePlanResponse

message StreamingQueryManagerCommandResult.ActiveResult

commands.proto:431

Used in: StreamingQueryManagerCommandResult

message StreamingQueryManagerCommandResult.AwaitAnyTerminationResult

commands.proto:442

Used in: StreamingQueryManagerCommandResult

message StreamingQueryManagerCommandResult.ListStreamingQueryListenerResult

commands.proto:450

Used in: StreamingQueryManagerCommandResult

message StreamingQueryManagerCommandResult.StreamingQueryInstance

commands.proto:435

Used in: StreamingQueryManagerCommandResult, ActiveResult

message StreamingQueryManagerCommandResult.StreamingQueryListenerInstance

commands.proto:446

message SubqueryAlias

relations.proto:519

Relation alias.

Used in: Relation

message TableExists

catalog.proto:150

See `spark.catalog.tableExists`

Used in: Catalog

message Tail

relations.proto:345

Relation of type [[Tail]] that is used to fetch `limit` rows from the last of the input relation.

Used in: Relation

message TaskResourceRequest

common.proto:87

A task resource request.

Used in: ResourceProfile

message ToDF

relations.proto:805

Rename columns on the input relation by the same length of names.

Used in: Relation

message ToSchema

relations.proto:909

Used in: Relation

message UncacheTable

catalog.proto:231

See `spark.catalog.uncacheTable`

Used in: Catalog

message Unknown

relations.proto:126

Used for testing purposes only.

Used in: Relation

(message has no fields)

message Unpivot

relations.proto:888

Unpivot a DataFrame from wide format to long format, optionally leaving identifier columns set.

Used in: Relation

message Unpivot.Values

relations.proto:904

Used in: Unpivot

message UserContext

base.proto:69

User Context is used to refer to one particular user session that is executing queries in the backend.

Used in: AddArtifactsRequest, AnalyzePlanRequest, ArtifactStatusesRequest, ConfigRequest, ExecutePlanRequest, FetchErrorDetailsRequest, InterruptRequest, ReattachExecuteRequest, ReleaseExecuteRequest, ReleaseSessionRequest

message WithColumns

relations.proto:843

Adding columns or replacing the existing columns that have the same names.

Used in: Relation

message WithColumnsRenamed

relations.proto:818

Rename columns on the input relation by a map with name to name mapping.

Used in: Relation

message WithColumnsRenamed.Rename

relations.proto:833

Used in: WithColumnsRenamed

message WithRelations

relations.proto:164

Relation of type [[WithRelations]]. This relation contains a root plan, and one or more references that are used by the root plan. There are two ways of referencing a relation, by name (through a subquery alias), or by plan_id (using RelationCommon.plan_id). This relation can be used to implement CTEs, describe DAGs, or to reduce tree depth.

Used in: Relation

message WithWatermark

relations.proto:859

Used in: Relation

message WriteOperation

commands.proto:126

As writes are not directly handled during analysis and planning, they are modeled as commands.

Used in: Command

message WriteOperation.BucketBy

commands.proto:175

Used in: WriteOperation

enum WriteOperation.SaveMode

commands.proto:180

Used in: WriteOperation

message WriteOperation.SaveTable

commands.proto:162

Used in: WriteOperation

enum WriteOperation.SaveTable.TableSaveMethod

commands.proto:168

Used in: SaveTable

message WriteOperationV2

commands.proto:190

As writes are not directly handled during analysis and planning, they are modeled as commands.

Used in: Command

enum WriteOperationV2.Mode

commands.proto:214

Used in: WriteOperationV2

message WriteStreamOperationStart

commands.proto:233

Starts write stream operation as streaming query. Query ID and Run ID of the streaming query are returned.

Used in: Command

message WriteStreamOperationStartResult

commands.proto:272

Used in: ExecutePlanResponse