package spark.connect

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

service SparkConnectService

base.proto:1060

Main interface for the SparkConnect service.

message AddArtifactsRequest.ArtifactChunk

base.proto:596

A chunk of an Artifact.

Used in: AddArtifactsRequest, BeginChunkedArtifact, SingleChunkArtifact

message AddArtifactsRequest.Batch

base.proto:618

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

Used in: AddArtifactsRequest

message AddArtifactsRequest.BeginChunkedArtifact

base.proto:625

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:605

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:665

Metadata of an artifact.

Used in: AddArtifactsResponse

message Aggregate

relations.proto:338

Relation of type [[Aggregate]].

Used in: Relation

enum Aggregate.GroupType

relations.proto:357

Used in: Aggregate

message Aggregate.GroupingSets

relations.proto:377

Used in: Aggregate

message Aggregate.Pivot

relations.proto:366

Used in: Aggregate

message AnalyzePlanRequest.DDLParse

base.proto:162

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.Explain

base.proto:105

Explains the input plan based on a configurable mode.

Used in: AnalyzePlanRequest

enum AnalyzePlanRequest.Explain.ExplainMode

base.proto:113

Plan explanation mode.

Used in: Explain

message AnalyzePlanRequest.GetStorageLevel

base.proto:198

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.InputFiles

base.proto:155

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.IsLocal

base.proto:145

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.IsStreaming

base.proto:150

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.Persist

base.proto:182

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.SameSemantics

base.proto:169

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

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.Schema

base.proto:99

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.SemanticHash

base.proto:177

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.SparkVersion

base.proto:160

Used in: AnalyzePlanRequest

(message has no fields)

message AnalyzePlanRequest.TreeString

base.proto:137

Used in: AnalyzePlanRequest

message AnalyzePlanRequest.Unpersist

base.proto:190

Used in: AnalyzePlanRequest

message AnalyzePlanResponse.DDLParse

base.proto:258

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.Explain

base.proto:233

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.GetStorageLevel

base.proto:274

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.InputFiles

base.proto:249

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.IsLocal

base.proto:241

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.IsStreaming

base.proto:245

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.Persist

base.proto:270

Used in: AnalyzePlanResponse

(message has no fields)

message AnalyzePlanResponse.SameSemantics

base.proto:262

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.Schema

base.proto:229

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.SemanticHash

base.proto:266

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.SparkVersion

base.proto:254

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.TreeString

base.proto:237

Used in: AnalyzePlanResponse

message AnalyzePlanResponse.Unpersist

base.proto:272

Used in: AnalyzePlanResponse

(message has no fields)

message ApplyInPandasWithState

relations.proto:993

Used in: Relation

message ArtifactStatusesResponse.ArtifactStatus

base.proto:718

Used in: ArtifactStatusesResponse

message AsOfJoin

relations.proto:1097

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

Used in: Relation

message CacheTable

catalog.proto:201

See `spark.catalog.cacheTable`

Used in: Catalog

message CachedLocalRelation

relations.proto:444

A local relation that has been cached already.

Used in: Relation

message CachedRemoteRelation

relations.proto:456

Represents a remote relation that has been cached on server.

Used in: CheckpointCommandResult, Relation, RemoveCachedRemoteRelationCommand

message CallFunction

expressions.proto:411

Used in: Expression

message Catalog

catalog.proto:30

Catalog messages are marked as unstable.

Used in: Relation

message CheckpointCommand

commands.proto:500

Used in: Command

message CheckpointCommandResult

base.proto:1054

Used in: ExecutePlanResponse

message ClearCache

catalog.proto:216

See `spark.catalog.clearCache`

Used in: Catalog

(message has no fields)

message CoGroupMap

relations.proto:970

Used in: Relation

message CollectMetrics

relations.proto:1065

Collect arbitrary (named) metrics from a dataset.

Used in: Relation

message Command

commands.proto:33

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:1046

Used in: Command, Relation

message CommonInlineUserDefinedFunction

expressions.proto:354

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

message CommonInlineUserDefinedTableFunction

relations.proto:1016

Used in: Command, Relation

message ConfigRequest.Get

base.proto:519

Used in: Operation

message ConfigRequest.GetAll

base.proto:534

Used in: Operation

message ConfigRequest.GetOption

base.proto:529

Used in: Operation

message ConfigRequest.GetWithDefault

base.proto:524

Used in: Operation

message ConfigRequest.IsModifiable

base.proto:544

Used in: Operation

message ConfigRequest.Operation

base.proto:502

Used in: ConfigRequest

message ConfigRequest.Set

base.proto:514

Used in: Operation

message ConfigRequest.Unset

base.proto:539

Used in: Operation

message CreateDataFrameViewCommand

commands.proto:88

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

Used in: Command

message CreateExternalTable

catalog.proto:145

See `spark.catalog.createExternalTable`

Used in: Catalog

message CreateResourceProfileCommand

commands.proto:483

Command to create ResourceProfile

Used in: Command

message CreateResourceProfileCommandResult

commands.proto:489

Response for command 'CreateResourceProfileCommand'.

Used in: ExecutePlanResponse

message CreateTable

catalog.proto:160

See `spark.catalog.createTable`

Used in: Catalog

message CurrentCatalog

catalog.proto:231

See `spark.catalog.currentCatalog`

Used in: Catalog

(message has no fields)

message CurrentDatabase

catalog.proto:62

See `spark.catalog.currentDatabase`

Used in: Catalog

(message has no fields)

message DataType

types.proto:28

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

Used in: 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:172

Used in: DataType

message DataType.Binary

types.proto:107

Used in: DataType

message DataType.Boolean

types.proto:74

Used in: DataType

message DataType.Byte

types.proto:78

Used in: DataType

message DataType.CalendarInterval

types.proto:127

Used in: DataType

message DataType.Char

types.proto:144

Start compound types.

Used in: DataType

message DataType.Date

types.proto:119

Used in: DataType

message DataType.DayTimeInterval

types.proto:137

Used in: DataType

message DataType.Decimal

types.proto:154

Used in: DataType

message DataType.Double

types.proto:98

Used in: DataType

message DataType.Float

types.proto:94

Used in: DataType

message DataType.Integer

types.proto:86

Used in: DataType

message DataType.Long

types.proto:90

Used in: DataType

message DataType.Map

types.proto:178

Used in: DataType

message DataType.NULL

types.proto:111

Used in: DataType

message DataType.Short

types.proto:82

Used in: DataType

message DataType.String

types.proto:102

Used in: DataType

message DataType.Struct

types.proto:167

Used in: DataType

message DataType.StructField

types.proto:160

Used in: Struct

message DataType.Timestamp

types.proto:115

Used in: DataType

message DataType.TimestampNTZ

types.proto:123

Used in: DataType

message DataType.UDT

types.proto:189

Used in: DataType

message DataType.Unparsed

types.proto:197

Used in: DataType

message DataType.VarChar

types.proto:149

Used in: DataType

message DataType.Variant

types.proto:185

Used in: DataType

message DataType.YearMonthInterval

types.proto:131

Used in: DataType

message DatabaseExists

catalog.proto:123

See `spark.catalog.databaseExists`

Used in: Catalog

message Deduplicate

relations.proto:411

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:397

Drop specified columns.

Used in: Relation

message DropGlobalTempView

catalog.proto:183

See `spark.catalog.dropGlobalTempView`

Used in: Catalog

message DropTempView

catalog.proto:177

See `spark.catalog.dropTempView`

Used in: Catalog

message ExamplePluginCommand

example_plugins.proto:40

message ExamplePluginExpression

example_plugins.proto:35

message ExamplePluginRelation

example_plugins.proto:29

message ExecutePlanRequest.RequestOption

base.proto:320

Used in: ExecutePlanRequest

message ExecutePlanResponse

base.proto:337

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:408

Batch results of metrics.

Used in: ExecutePlanResponse

message ExecutePlanResponse.ExecutionProgress

base.proto:450

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

Used in: ExecutePlanResponse

message ExecutePlanResponse.ExecutionProgress.StageInfo

base.proto:457

Used in: ExecutionProgress

message ExecutePlanResponse.Metrics

base.proto:418

Used in: ExecutePlanResponse

message ExecutePlanResponse.Metrics.MetricObject

base.proto:422

Used in: Metrics

message ExecutePlanResponse.Metrics.MetricValue

base.proto:429

Used in: MetricObject

message ExecutePlanResponse.ObservedMetrics

base.proto:436

Used in: ExecutePlanResponse

message ExecutePlanResponse.ResultComplete

base.proto:443

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:403

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:51

An executor resource request.

Used in: ResourceProfile

message Expression

expressions.proto:32

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

Used in: 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, MergeAction, MergeAction.Assignment, MergeIntoTableCommand, NamedArgumentExpression, Project, RepartitionByExpression, SQL, SqlCommand, StatSampleBy, Transpose, Unpivot, Unpivot.Values, WriteOperationV2

message Expression.Alias

expressions.proto:318

Used in: Expression, WithColumns

message Expression.Cast

expressions.proto:144

Used in: Expression

enum Expression.Cast.EvalMode

expressions.proto:158

Used in: Cast

message Expression.ExpressionString

expressions.proto:265

Expression as string.

Used in: Expression

message Expression.LambdaFunction

expressions.proto:331

Used in: Expression

message Expression.Literal

expressions.proto:166

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:213

Used in: Literal

message Expression.Literal.CalendarInterval

expressions.proto:207

Used in: Literal

message Expression.Literal.Decimal

expressions.proto:197

Used in: Literal

message Expression.Literal.Map

expressions.proto:218

Used in: Literal

message Expression.Literal.Struct

expressions.proto:225

Used in: Literal

message Expression.SortOrder

expressions.proto:121

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:137

Used in: SortOrder

enum Expression.SortOrder.SortDirection

expressions.proto:131

Used in: SortOrder

message Expression.UnresolvedAttribute

expressions.proto:233

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:294

Extracts a value or values from an Expression

Used in: Expression

message Expression.UnresolvedFunction

expressions.proto:247

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:342

Used in: Expression, LambdaFunction

message Expression.UnresolvedRegex

expressions.proto:285

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:271

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

Used in: Expression

message Expression.UpdateFields

expressions.proto:305

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

Used in: Expression

message Expression.Window

expressions.proto:63

Expression for the OVER clause or WINDOW clause.

Used in: Expression

message Expression.Window.WindowFrame

expressions.proto:80

The window frame

Used in: Window

message Expression.Window.WindowFrame.FrameBoundary

expressions.proto:102

Used in: WindowFrame

enum Expression.Window.WindowFrame.FrameType

expressions.proto:91

Used in: WindowFrame

message ExpressionCommon

expressions.proto:349

Used in: Expression

message FetchErrorDetailsResponse.Error

base.proto:1035

Error defines the schema for the representing exception.

Used in: FetchErrorDetailsResponse

message FetchErrorDetailsResponse.QueryContext

base.proto:984

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:986

The type of this query context.

Used in: QueryContext

message FetchErrorDetailsResponse.SparkThrowable

base.proto:1019

SparkThrowable defines the schema for SparkThrowable exceptions.

Used in: Error

message FetchErrorDetailsResponse.StackTraceElement

base.proto:968

Used in: Error

message Filter

relations.proto:219

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

Used in: Relation

message FunctionExists

catalog.proto:137

See `spark.catalog.functionExists`

Used in: Catalog

message GetDatabase

catalog.proto:101

See `spark.catalog.getDatabase`

Used in: Catalog

message GetFunction

catalog.proto:115

See `spark.catalog.getFunction`

Used in: Catalog

message GetResourcesCommand

commands.proto:475

Command to get the output of 'SparkContext.resources'

Used in: Command

(message has no fields)

message GetResourcesCommandResult

commands.proto:478

Response for command 'GetResourcesCommand'.

Used in: ExecutePlanResponse

message GetTable

catalog.proto:107

See `spark.catalog.getTable`

Used in: Catalog

message GroupMap

relations.proto:940

Used in: Relation

message Hint

relations.proto:856

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

Used in: Relation

message HtmlString

relations.proto:545

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

Used in: Relation

enum InterruptRequest.InterruptType

base.proto:750

Used in: InterruptRequest

message IsCached

catalog.proto:195

See `spark.catalog.isCached`

Used in: Catalog

message JavaUDF

expressions.proto:395

Used in: CommonInlineUserDefinedFunction

message Join

relations.proto:230

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

Used in: Relation

message Join.JoinDataType

relations.proto:266

Used in: Join

enum Join.JoinType

relations.proto:252

Used in: Join

message KeyValue

base.proto:468

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

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

message Limit

relations.proto:310

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

Used in: Relation

message ListCatalogs

catalog.proto:240

See `spark.catalog.listCatalogs`

Used in: Catalog

message ListColumns

catalog.proto:93

See `spark.catalog.listColumns`

Used in: Catalog

message ListDatabases

catalog.proto:71

See `spark.catalog.listDatabases`

Used in: Catalog

message ListFunctions

catalog.proto:85

See `spark.catalog.listFunctions`

Used in: Catalog

message ListTables

catalog.proto:77

See `spark.catalog.listTables`

Used in: Catalog

message LocalRelation

relations.proto:430

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

Used in: Relation

message MapPartitions

relations.proto:926

Used in: Relation

message MergeAction

expressions.proto:427

Used in: Expression

enum MergeAction.ActionType

expressions.proto:437

Used in: MergeAction

message MergeAction.Assignment

expressions.proto:446

Used in: MergeAction

message MergeIntoTableCommand

commands.proto:512

Used in: Command

message NADrop

relations.proto:738

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:721

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:762

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:774

Used in: NAReplace

message NamedArgumentExpression

expressions.proto:419

Used in: Expression

message Offset

relations.proto:320

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

Used in: Relation

message Origin

common.proto:85

Used in: ExpressionCommon, RelationCommon

message Parse

relations.proto:1076

Used in: Relation

enum Parse.ParseFormat

relations.proto:1087

Used in: Parse

message Plan

base.proto:37

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:207

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:1056

Used in: CommonInlineUserDefinedDataSource

message PythonOrigin

common.proto:92

Used in: Origin

message PythonUDF

expressions.proto:369

Used in: CommonInlineUserDefinedFunction, StreamingForeachFunction, StreamingQueryManagerCommand.StreamingQueryListenerCommand

message PythonUDTF

relations.proto:1032

Used in: CommonInlineUserDefinedTableFunction

message Range

relations.proto:487

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

Used in: Relation

message Read

relations.proto:160

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

Used in: Relation

message Read.DataSource

relations.proto:177

Used in: Read

message Read.NamedTable

relations.proto:169

Used in: Read

message ReattachOptions

base.proto:785

Used in: ExecutePlanRequest.RequestOption

message RecoverPartitions

catalog.proto:189

See `spark.catalog.recoverPartitions`

Used in: Catalog

message RefreshByPath

catalog.proto:225

See `spark.catalog.refreshByPath`

Used in: Catalog

message RefreshTable

catalog.proto:219

See `spark.catalog.refreshTable`

Used in: Catalog

message Relation

relations.proto:36

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: 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, MergeIntoTableCommand, 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, Transpose, Unpivot, WithColumns, WithColumnsRenamed, WithRelations, WithWatermark, WriteOperation, WriteOperationV2, WriteStreamOperationStart

message RelationCommon

relations.proto:110

Common metadata of all relations.

Used in: Relation

message ReleaseExecuteRequest.ReleaseAll

base.proto:868

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:875

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:495

Command to remove `CashedRemoteRelation`

Used in: Command

message Repartition

relations.proto:515

Relation repartition.

Used in: Relation

message RepartitionByExpression

relations.proto:915

Used in: Relation

message ResourceInformation

common.proto:43

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:75

Used in: CreateResourceProfileCommand

message SQL

relations.proto:122

Relation that uses a SQL query to generate the output.

Used in: Relation

message Sample

relations.proto:462

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

Used in: Relation

message ScalarScalaUDF

expressions.proto:382

Used in: CommonInlineUserDefinedFunction, StreamingForeachFunction, TypedAggregateExpression

message SetCurrentCatalog

catalog.proto:234

See `spark.catalog.setCurrentCatalog`

Used in: Catalog

message SetCurrentDatabase

catalog.proto:65

See `spark.catalog.setCurrentDatabase`

Used in: Catalog

message SetOperation

relations.proto:275

Relation of type [[SetOperation]]

Used in: Relation

enum SetOperation.SetOpType

relations.proto:301

Used in: SetOperation

message ShowString

relations.proto:528

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

Used in: Relation

message Sort

relations.proto:384

Relation of type [[Sort]].

Used in: Relation

message SqlCommand

commands.proto:65

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:645

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:626

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:612

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:595

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:584

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:668

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:685

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:702

Used in: StatSampleBy

message StatSummary

relations.proto:560

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:27

StorageLevel for persisting Datasets/Tables.

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

message StreamingForeachFunction

commands.proto:248

Used in: WriteStreamOperationStart

message StreamingQueryCommand

commands.proto:287

Commands for a streaming query.

Used in: Command

message StreamingQueryCommand.AwaitTerminationCommand

commands.proto:318

Used in: StreamingQueryCommand

message StreamingQueryCommand.ExplainCommand

commands.proto:312

Used in: StreamingQueryCommand

message StreamingQueryCommandResult

commands.proto:324

Response for commands on a streaming query.

Used in: ExecutePlanResponse

message StreamingQueryCommandResult.AwaitTerminationResult

commands.proto:364

Used in: StreamingQueryCommandResult

message StreamingQueryCommandResult.ExceptionResult

commands.proto:354

Used in: StreamingQueryCommandResult

message StreamingQueryCommandResult.ExplainResult

commands.proto:349

Used in: StreamingQueryCommandResult

message StreamingQueryCommandResult.RecentProgressResult

commands.proto:344

Used in: StreamingQueryCommandResult

message StreamingQueryCommandResult.StatusResult

commands.proto:336

Used in: StreamingQueryCommandResult

enum StreamingQueryEventType

commands.proto:454

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:273

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:444

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:462

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

Used in: StreamingQueryListenerEventsResult

message StreamingQueryListenerEventsResult

commands.proto:469

Used in: ExecutePlanResponse

message StreamingQueryManagerCommand

commands.proto:370

Commands for the streaming query manager.

Used in: Command

message StreamingQueryManagerCommand.AwaitAnyTerminationCommand

commands.proto:390

Used in: StreamingQueryManagerCommand

message StreamingQueryManagerCommand.StreamingQueryListenerCommand

commands.proto:395

Used in: StreamingQueryManagerCommand

message StreamingQueryManagerCommandResult

commands.proto:403

Response for commands on the streaming query manager.

Used in: ExecutePlanResponse

message StreamingQueryManagerCommandResult.ActiveResult

commands.proto:414

Used in: StreamingQueryManagerCommandResult

message StreamingQueryManagerCommandResult.AwaitAnyTerminationResult

commands.proto:425

Used in: StreamingQueryManagerCommandResult

message StreamingQueryManagerCommandResult.ListStreamingQueryListenerResult

commands.proto:433

Used in: StreamingQueryManagerCommandResult

message StreamingQueryManagerCommandResult.StreamingQueryInstance

commands.proto:418

Used in: StreamingQueryManagerCommandResult, ActiveResult

message StreamingQueryManagerCommandResult.StreamingQueryListenerInstance

commands.proto:429

message SubqueryAlias

relations.proto:503

Relation alias.

Used in: Relation

message TableExists

catalog.proto:129

See `spark.catalog.tableExists`

Used in: Catalog

message Tail

relations.proto:329

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:66

A task resource request.

Used in: ResourceProfile

message ToDF

relations.proto:789

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

Used in: Relation

message ToSchema

relations.proto:905

Used in: Relation

message Transpose

relations.proto:896

Transpose a DataFrame, switching rows to columns. Transforms the DataFrame such that the values in the specified index column become the new columns of the DataFrame.

Used in: Relation

message TypedAggregateExpression

expressions.proto:406

Used in: Expression

message UncacheTable

catalog.proto:210

See `spark.catalog.uncacheTable`

Used in: Catalog

message Unknown

relations.proto:107

Used for testing purposes only.

Used in: Relation

(message has no fields)

message Unpivot

relations.proto:872

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

Used in: Relation

message Unpivot.Values

relations.proto:888

Used in: Unpivot

message UserContext

base.proto:48

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:827

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

Used in: Relation

message WithColumnsRenamed

relations.proto:802

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

Used in: Relation

message WithColumnsRenamed.Rename

relations.proto:817

Used in: WithColumnsRenamed

message WithRelations

relations.proto:148

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:843

Used in: Relation

message WriteOperation

commands.proto:106

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

Used in: Command

message WriteOperation.BucketBy

commands.proto:155

Used in: WriteOperation

enum WriteOperation.SaveMode

commands.proto:160

Used in: WriteOperation

message WriteOperation.SaveTable

commands.proto:142

Used in: WriteOperation

enum WriteOperation.SaveTable.TableSaveMethod

commands.proto:148

Used in: SaveTable

message WriteOperationV2

commands.proto:170

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

Used in: Command

enum WriteOperationV2.Mode

commands.proto:194

Used in: WriteOperationV2

message WriteStreamOperationStart

commands.proto:213

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:255

Used in: ExecutePlanResponse