Packages

package proto

Type Members

  1. final class AddArtifactsRequest extends GeneratedMessage with AddArtifactsRequestOrBuilder

    Request to transfer client-local artifacts.
    

    Request to transfer client-local artifacts.
    

    Protobuf type spark.connect.AddArtifactsRequest

  2. trait AddArtifactsRequestOrBuilder extends MessageOrBuilder
  3. final class AddArtifactsResponse extends GeneratedMessage with AddArtifactsResponseOrBuilder

    Response to adding an artifact. Contains relevant metadata to verify successful transfer of
    artifact(s).
    Next ID: 4
    

    Response to adding an artifact. Contains relevant metadata to verify successful transfer of
    artifact(s).
    Next ID: 4
    

    Protobuf type spark.connect.AddArtifactsResponse

  4. trait AddArtifactsResponseOrBuilder extends MessageOrBuilder
  5. final class Aggregate extends GeneratedMessage with AggregateOrBuilder

    Relation of type [[Aggregate]].
    

    Relation of type [[Aggregate]].
    

    Protobuf type spark.connect.Aggregate

  6. trait AggregateOrBuilder extends MessageOrBuilder
  7. final class AnalyzePlanRequest extends GeneratedMessage with AnalyzePlanRequestOrBuilder

    Request to perform plan analyze, optionally to explain the plan.
    

    Request to perform plan analyze, optionally to explain the plan.
    

    Protobuf type spark.connect.AnalyzePlanRequest

  8. trait AnalyzePlanRequestOrBuilder extends MessageOrBuilder
  9. final class AnalyzePlanResponse extends GeneratedMessage with AnalyzePlanResponseOrBuilder

    Response to performing analysis of the query. Contains relevant metadata to be able to
    reason about the performance.
    Next ID: 16
    

    Response to performing analysis of the query. Contains relevant metadata to be able to
    reason about the performance.
    Next ID: 16
    

    Protobuf type spark.connect.AnalyzePlanResponse

  10. trait AnalyzePlanResponseOrBuilder extends MessageOrBuilder
  11. final class ApplyInPandasWithState extends GeneratedMessage with ApplyInPandasWithStateOrBuilder

    Protobuf type spark.connect.ApplyInPandasWithState

  12. trait ApplyInPandasWithStateOrBuilder extends MessageOrBuilder
  13. final class ArtifactStatusesRequest extends GeneratedMessage with ArtifactStatusesRequestOrBuilder

    Request to get current statuses of artifacts at the server side.
    

    Request to get current statuses of artifacts at the server side.
    

    Protobuf type spark.connect.ArtifactStatusesRequest

  14. trait ArtifactStatusesRequestOrBuilder extends MessageOrBuilder
  15. final class ArtifactStatusesResponse extends GeneratedMessage with ArtifactStatusesResponseOrBuilder

    Response to checking artifact statuses.
    Next ID: 4
    

    Response to checking artifact statuses.
    Next ID: 4
    

    Protobuf type spark.connect.ArtifactStatusesResponse

  16. trait ArtifactStatusesResponseOrBuilder extends MessageOrBuilder
  17. final class AsOfJoin extends GeneratedMessage with AsOfJoinOrBuilder

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

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

    Protobuf type spark.connect.AsOfJoin

  18. trait AsOfJoinOrBuilder extends MessageOrBuilder
  19. final class Base extends AnyRef
  20. final class Bools extends GeneratedMessage with BoolsOrBuilder

    Protobuf type spark.connect.Bools

  21. trait BoolsOrBuilder extends MessageOrBuilder
  22. final class CacheTable extends GeneratedMessage with CacheTableOrBuilder

    See `spark.catalog.cacheTable`
    

    See `spark.catalog.cacheTable`
    

    Protobuf type spark.connect.CacheTable

  23. trait CacheTableOrBuilder extends MessageOrBuilder
  24. final class CachedLocalRelation extends GeneratedMessage with CachedLocalRelationOrBuilder

    A local relation that has been cached already.
    

    A local relation that has been cached already.
    

    Protobuf type spark.connect.CachedLocalRelation

  25. trait CachedLocalRelationOrBuilder extends MessageOrBuilder
  26. final class CachedRemoteRelation extends GeneratedMessage with CachedRemoteRelationOrBuilder

    Represents a remote relation that has been cached on server.
    

    Represents a remote relation that has been cached on server.
    

    Protobuf type spark.connect.CachedRemoteRelation

  27. trait CachedRemoteRelationOrBuilder extends MessageOrBuilder
  28. final class CallFunction extends GeneratedMessage with CallFunctionOrBuilder

    Protobuf type spark.connect.CallFunction

  29. trait CallFunctionOrBuilder extends MessageOrBuilder
  30. final class Catalog extends GeneratedMessage with CatalogOrBuilder

    Catalog messages are marked as unstable.
    

    Catalog messages are marked as unstable.
    

    Protobuf type spark.connect.Catalog

  31. trait CatalogOrBuilder extends MessageOrBuilder
  32. final class CatalogOuterClass extends AnyRef
  33. final class CheckpointCommand extends GeneratedMessage with CheckpointCommandOrBuilder

    Protobuf type spark.connect.CheckpointCommand

  34. trait CheckpointCommandOrBuilder extends MessageOrBuilder
  35. final class CheckpointCommandResult extends GeneratedMessage with CheckpointCommandResultOrBuilder

    Protobuf type spark.connect.CheckpointCommandResult

  36. trait CheckpointCommandResultOrBuilder extends MessageOrBuilder
  37. final class ClearCache extends GeneratedMessage with ClearCacheOrBuilder

    See `spark.catalog.clearCache`
    

    See `spark.catalog.clearCache`
    

    Protobuf type spark.connect.ClearCache

  38. trait ClearCacheOrBuilder extends MessageOrBuilder
  39. final class CoGroupMap extends GeneratedMessage with CoGroupMapOrBuilder

    Protobuf type spark.connect.CoGroupMap

  40. trait CoGroupMapOrBuilder extends MessageOrBuilder
  41. final class CollectMetrics extends GeneratedMessage with CollectMetricsOrBuilder

    Collect arbitrary (named) metrics from a dataset.
    

    Collect arbitrary (named) metrics from a dataset.
    

    Protobuf type spark.connect.CollectMetrics

  42. trait CollectMetricsOrBuilder extends MessageOrBuilder
  43. final class Command extends GeneratedMessage with CommandOrBuilder

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

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

    Protobuf type spark.connect.Command

  44. trait CommandOrBuilder extends MessageOrBuilder
  45. final class Commands extends AnyRef
  46. final class Common extends AnyRef
  47. final class CommonInlineUserDefinedDataSource extends GeneratedMessage with CommonInlineUserDefinedDataSourceOrBuilder

    Protobuf type spark.connect.CommonInlineUserDefinedDataSource

  48. trait CommonInlineUserDefinedDataSourceOrBuilder extends MessageOrBuilder
  49. final class CommonInlineUserDefinedFunction extends GeneratedMessage with CommonInlineUserDefinedFunctionOrBuilder

    Protobuf type spark.connect.CommonInlineUserDefinedFunction

  50. trait CommonInlineUserDefinedFunctionOrBuilder extends MessageOrBuilder
  51. final class CommonInlineUserDefinedTableFunction extends GeneratedMessage with CommonInlineUserDefinedTableFunctionOrBuilder

    Protobuf type spark.connect.CommonInlineUserDefinedTableFunction

  52. trait CommonInlineUserDefinedTableFunctionOrBuilder extends MessageOrBuilder
  53. final class ConfigRequest extends GeneratedMessage with ConfigRequestOrBuilder

    Request to update or fetch the configurations.
    

    Request to update or fetch the configurations.
    

    Protobuf type spark.connect.ConfigRequest

  54. trait ConfigRequestOrBuilder extends MessageOrBuilder
  55. final class ConfigResponse extends GeneratedMessage with ConfigResponseOrBuilder

    Response to the config request.
    Next ID: 5
    

    Response to the config request.
    Next ID: 5
    

    Protobuf type spark.connect.ConfigResponse

  56. trait ConfigResponseOrBuilder extends MessageOrBuilder
  57. final class CreateDataFrameViewCommand extends GeneratedMessage with CreateDataFrameViewCommandOrBuilder

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

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

    Protobuf type spark.connect.CreateDataFrameViewCommand

  58. trait CreateDataFrameViewCommandOrBuilder extends MessageOrBuilder
  59. final class CreateExternalTable extends GeneratedMessage with CreateExternalTableOrBuilder

    See `spark.catalog.createExternalTable`
    

    See `spark.catalog.createExternalTable`
    

    Protobuf type spark.connect.CreateExternalTable

  60. trait CreateExternalTableOrBuilder extends MessageOrBuilder
  61. final class CreateResourceProfileCommand extends GeneratedMessage with CreateResourceProfileCommandOrBuilder

    Command to create ResourceProfile
    

    Command to create ResourceProfile
    

    Protobuf type spark.connect.CreateResourceProfileCommand

  62. trait CreateResourceProfileCommandOrBuilder extends MessageOrBuilder
  63. final class CreateResourceProfileCommandResult extends GeneratedMessage with CreateResourceProfileCommandResultOrBuilder

    Response for command 'CreateResourceProfileCommand'.
    

    Response for command 'CreateResourceProfileCommand'.
    

    Protobuf type spark.connect.CreateResourceProfileCommandResult

  64. trait CreateResourceProfileCommandResultOrBuilder extends MessageOrBuilder
  65. final class CreateTable extends GeneratedMessage with CreateTableOrBuilder

    See `spark.catalog.createTable`
    

    See `spark.catalog.createTable`
    

    Protobuf type spark.connect.CreateTable

  66. trait CreateTableOrBuilder extends MessageOrBuilder
  67. final class CurrentCatalog extends GeneratedMessage with CurrentCatalogOrBuilder

    See `spark.catalog.currentCatalog`
    

    See `spark.catalog.currentCatalog`
    

    Protobuf type spark.connect.CurrentCatalog

  68. trait CurrentCatalogOrBuilder extends MessageOrBuilder
  69. final class CurrentDatabase extends GeneratedMessage with CurrentDatabaseOrBuilder

    See `spark.catalog.currentDatabase`
    

    See `spark.catalog.currentDatabase`
    

    Protobuf type spark.connect.CurrentDatabase

  70. trait CurrentDatabaseOrBuilder extends MessageOrBuilder
  71. final class DataType extends GeneratedMessage with DataTypeOrBuilder

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

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

    Protobuf type spark.connect.DataType

  72. trait DataTypeOrBuilder extends MessageOrBuilder
  73. final class DatabaseExists extends GeneratedMessage with DatabaseExistsOrBuilder

    See `spark.catalog.databaseExists`
    

    See `spark.catalog.databaseExists`
    

    Protobuf type spark.connect.DatabaseExists

  74. trait DatabaseExistsOrBuilder extends MessageOrBuilder
  75. final class Deduplicate extends GeneratedMessage with DeduplicateOrBuilder

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

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

    Protobuf type spark.connect.Deduplicate

  76. trait DeduplicateOrBuilder extends MessageOrBuilder
  77. final class Doubles extends GeneratedMessage with DoublesOrBuilder

    Protobuf type spark.connect.Doubles

  78. trait DoublesOrBuilder extends MessageOrBuilder
  79. final class Drop extends GeneratedMessage with DropOrBuilder

    Drop specified columns.
    

    Drop specified columns.
    

    Protobuf type spark.connect.Drop

  80. final class DropGlobalTempView extends GeneratedMessage with DropGlobalTempViewOrBuilder

    See `spark.catalog.dropGlobalTempView`
    

    See `spark.catalog.dropGlobalTempView`
    

    Protobuf type spark.connect.DropGlobalTempView

  81. trait DropGlobalTempViewOrBuilder extends MessageOrBuilder
  82. trait DropOrBuilder extends MessageOrBuilder
  83. final class DropTempView extends GeneratedMessage with DropTempViewOrBuilder

    See `spark.catalog.dropTempView`
    

    See `spark.catalog.dropTempView`
    

    Protobuf type spark.connect.DropTempView

  84. trait DropTempViewOrBuilder extends MessageOrBuilder
  85. final class ExamplePluginCommand extends GeneratedMessage with ExamplePluginCommandOrBuilder

    Protobuf type spark.connect.ExamplePluginCommand

  86. trait ExamplePluginCommandOrBuilder extends MessageOrBuilder
  87. final class ExamplePluginExpression extends GeneratedMessage with ExamplePluginExpressionOrBuilder

    Protobuf type spark.connect.ExamplePluginExpression

  88. trait ExamplePluginExpressionOrBuilder extends MessageOrBuilder
  89. final class ExamplePluginRelation extends GeneratedMessage with ExamplePluginRelationOrBuilder

    Protobuf type spark.connect.ExamplePluginRelation

  90. trait ExamplePluginRelationOrBuilder extends MessageOrBuilder
  91. final class ExamplePlugins extends AnyRef
  92. final class ExecuteExternalCommand extends GeneratedMessage with ExecuteExternalCommandOrBuilder

    Execute an arbitrary string command inside an external execution engine
    

    Execute an arbitrary string command inside an external execution engine
    

    Protobuf type spark.connect.ExecuteExternalCommand

  93. trait ExecuteExternalCommandOrBuilder extends MessageOrBuilder
  94. final class ExecutePlanRequest extends GeneratedMessage with ExecutePlanRequestOrBuilder

    A request to be executed by the service.
    

    A request to be executed by the service.
    

    Protobuf type spark.connect.ExecutePlanRequest

  95. trait ExecutePlanRequestOrBuilder extends MessageOrBuilder
  96. final class ExecutePlanResponse extends GeneratedMessage with ExecutePlanResponseOrBuilder

    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
    

    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
    

    Protobuf type spark.connect.ExecutePlanResponse

  97. trait ExecutePlanResponseOrBuilder extends MessageOrBuilder
  98. final class ExecutorResourceRequest extends GeneratedMessage with ExecutorResourceRequestOrBuilder

    An executor resource request.
    

    An executor resource request.
    

    Protobuf type spark.connect.ExecutorResourceRequest

  99. trait ExecutorResourceRequestOrBuilder extends MessageOrBuilder
  100. final class Expression extends GeneratedMessage with ExpressionOrBuilder

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

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

    Protobuf type spark.connect.Expression

  101. final class ExpressionCommon extends GeneratedMessage with ExpressionCommonOrBuilder

    Protobuf type spark.connect.ExpressionCommon

  102. trait ExpressionCommonOrBuilder extends MessageOrBuilder
  103. trait ExpressionOrBuilder extends MessageOrBuilder
  104. final class Expressions extends AnyRef
  105. final class Fetch extends GeneratedMessage with FetchOrBuilder

    Message for fetching attribute from object on the server side.
    Fetch can be represented as a Relation or a ML command
    Command: model.coefficients, model.summary.weightedPrecision which
    returns the final literal result
    Relation: model.summary.roc which returns a DataFrame (Relation)
    

    Message for fetching attribute from object on the server side.
    Fetch can be represented as a Relation or a ML command
    Command: model.coefficients, model.summary.weightedPrecision which
    returns the final literal result
    Relation: model.summary.roc which returns a DataFrame (Relation)
    

    Protobuf type spark.connect.Fetch

  106. final class FetchErrorDetailsRequest extends GeneratedMessage with FetchErrorDetailsRequestOrBuilder

    Protobuf type spark.connect.FetchErrorDetailsRequest

  107. trait FetchErrorDetailsRequestOrBuilder extends MessageOrBuilder
  108. final class FetchErrorDetailsResponse extends GeneratedMessage with FetchErrorDetailsResponseOrBuilder

    Next ID: 5
    

    Next ID: 5
    

    Protobuf type spark.connect.FetchErrorDetailsResponse

  109. trait FetchErrorDetailsResponseOrBuilder extends MessageOrBuilder
  110. trait FetchOrBuilder extends MessageOrBuilder
  111. final class Filter extends GeneratedMessage with FilterOrBuilder

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

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

    Protobuf type spark.connect.Filter

  112. trait FilterOrBuilder extends MessageOrBuilder
  113. final class Floats extends GeneratedMessage with FloatsOrBuilder

    Protobuf type spark.connect.Floats

  114. trait FloatsOrBuilder extends MessageOrBuilder
  115. final class FunctionExists extends GeneratedMessage with FunctionExistsOrBuilder

    See `spark.catalog.functionExists`
    

    See `spark.catalog.functionExists`
    

    Protobuf type spark.connect.FunctionExists

  116. trait FunctionExistsOrBuilder extends MessageOrBuilder
  117. final class GetDatabase extends GeneratedMessage with GetDatabaseOrBuilder

    See `spark.catalog.getDatabase`
    

    See `spark.catalog.getDatabase`
    

    Protobuf type spark.connect.GetDatabase

  118. trait GetDatabaseOrBuilder extends MessageOrBuilder
  119. final class GetFunction extends GeneratedMessage with GetFunctionOrBuilder

    See `spark.catalog.getFunction`
    

    See `spark.catalog.getFunction`
    

    Protobuf type spark.connect.GetFunction

  120. trait GetFunctionOrBuilder extends MessageOrBuilder
  121. final class GetResourcesCommand extends GeneratedMessage with GetResourcesCommandOrBuilder

    Command to get the output of 'SparkContext.resources'
    

    Command to get the output of 'SparkContext.resources'
    

    Protobuf type spark.connect.GetResourcesCommand

  122. trait GetResourcesCommandOrBuilder extends MessageOrBuilder
  123. final class GetResourcesCommandResult extends GeneratedMessage with GetResourcesCommandResultOrBuilder

    Response for command 'GetResourcesCommand'.
    

    Response for command 'GetResourcesCommand'.
    

    Protobuf type spark.connect.GetResourcesCommandResult

  124. trait GetResourcesCommandResultOrBuilder extends MessageOrBuilder
  125. final class GetTable extends GeneratedMessage with GetTableOrBuilder

    See `spark.catalog.getTable`
    

    See `spark.catalog.getTable`
    

    Protobuf type spark.connect.GetTable

  126. trait GetTableOrBuilder extends MessageOrBuilder
  127. final class GroupMap extends GeneratedMessage with GroupMapOrBuilder

    Protobuf type spark.connect.GroupMap

  128. trait GroupMapOrBuilder extends MessageOrBuilder
  129. final class Hint extends GeneratedMessage with HintOrBuilder

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

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

    Protobuf type spark.connect.Hint

  130. trait HintOrBuilder extends MessageOrBuilder
  131. final class HtmlString extends GeneratedMessage with HtmlStringOrBuilder

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

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

    Protobuf type spark.connect.HtmlString

  132. trait HtmlStringOrBuilder extends MessageOrBuilder
  133. final class InterruptRequest extends GeneratedMessage with InterruptRequestOrBuilder

    Protobuf type spark.connect.InterruptRequest

  134. trait InterruptRequestOrBuilder extends MessageOrBuilder
  135. final class InterruptResponse extends GeneratedMessage with InterruptResponseOrBuilder

    Next ID: 4
    

    Next ID: 4
    

    Protobuf type spark.connect.InterruptResponse

  136. trait InterruptResponseOrBuilder extends MessageOrBuilder
  137. final class Ints extends GeneratedMessage with IntsOrBuilder

    Protobuf type spark.connect.Ints

  138. trait IntsOrBuilder extends MessageOrBuilder
  139. final class IsCached extends GeneratedMessage with IsCachedOrBuilder

    See `spark.catalog.isCached`
    

    See `spark.catalog.isCached`
    

    Protobuf type spark.connect.IsCached

  140. trait IsCachedOrBuilder extends MessageOrBuilder
  141. final class JavaUDF extends GeneratedMessage with JavaUDFOrBuilder

    Protobuf type spark.connect.JavaUDF

  142. trait JavaUDFOrBuilder extends MessageOrBuilder
  143. final class Join extends GeneratedMessage with JoinOrBuilder

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

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

    Protobuf type spark.connect.Join

  144. trait JoinOrBuilder extends MessageOrBuilder
  145. final class JvmOrigin extends GeneratedMessage with JvmOriginOrBuilder

    Protobuf type spark.connect.JvmOrigin

  146. trait JvmOriginOrBuilder extends MessageOrBuilder
  147. final class KeyValue extends GeneratedMessage with KeyValueOrBuilder

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

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

    Protobuf type spark.connect.KeyValue

  148. trait KeyValueOrBuilder extends MessageOrBuilder
  149. final class LateralJoin extends GeneratedMessage with LateralJoinOrBuilder

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

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

    Protobuf type spark.connect.LateralJoin

  150. trait LateralJoinOrBuilder extends MessageOrBuilder
  151. final class Limit extends GeneratedMessage with LimitOrBuilder

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

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

    Protobuf type spark.connect.Limit

  152. trait LimitOrBuilder extends MessageOrBuilder
  153. final class ListCatalogs extends GeneratedMessage with ListCatalogsOrBuilder

    See `spark.catalog.listCatalogs`
    

    See `spark.catalog.listCatalogs`
    

    Protobuf type spark.connect.ListCatalogs

  154. trait ListCatalogsOrBuilder extends MessageOrBuilder
  155. final class ListColumns extends GeneratedMessage with ListColumnsOrBuilder

    See `spark.catalog.listColumns`
    

    See `spark.catalog.listColumns`
    

    Protobuf type spark.connect.ListColumns

  156. trait ListColumnsOrBuilder extends MessageOrBuilder
  157. final class ListDatabases extends GeneratedMessage with ListDatabasesOrBuilder

    See `spark.catalog.listDatabases`
    

    See `spark.catalog.listDatabases`
    

    Protobuf type spark.connect.ListDatabases

  158. trait ListDatabasesOrBuilder extends MessageOrBuilder
  159. final class ListFunctions extends GeneratedMessage with ListFunctionsOrBuilder

    See `spark.catalog.listFunctions`
    

    See `spark.catalog.listFunctions`
    

    Protobuf type spark.connect.ListFunctions

  160. trait ListFunctionsOrBuilder extends MessageOrBuilder
  161. final class ListTables extends GeneratedMessage with ListTablesOrBuilder

    See `spark.catalog.listTables`
    

    See `spark.catalog.listTables`
    

    Protobuf type spark.connect.ListTables

  162. trait ListTablesOrBuilder extends MessageOrBuilder
  163. final class LocalRelation extends GeneratedMessage with LocalRelationOrBuilder

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

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

    Protobuf type spark.connect.LocalRelation

  164. trait LocalRelationOrBuilder extends MessageOrBuilder
  165. final class Longs extends GeneratedMessage with LongsOrBuilder

    Protobuf type spark.connect.Longs

  166. trait LongsOrBuilder extends MessageOrBuilder
  167. final class MapPartitions extends GeneratedMessage with MapPartitionsOrBuilder

    Protobuf type spark.connect.MapPartitions

  168. trait MapPartitionsOrBuilder extends MessageOrBuilder
  169. final class MergeAction extends GeneratedMessage with MergeActionOrBuilder

    Protobuf type spark.connect.MergeAction

  170. trait MergeActionOrBuilder extends MessageOrBuilder
  171. final class MergeIntoTableCommand extends GeneratedMessage with MergeIntoTableCommandOrBuilder

    Protobuf type spark.connect.MergeIntoTableCommand

  172. trait MergeIntoTableCommandOrBuilder extends MessageOrBuilder
  173. final class Ml extends AnyRef
  174. final class MlCommand extends GeneratedMessage with MlCommandOrBuilder

    Command for ML
    

    Command for ML
    

    Protobuf type spark.connect.MlCommand

  175. trait MlCommandOrBuilder extends MessageOrBuilder
  176. final class MlCommandResult extends GeneratedMessage with MlCommandResultOrBuilder

    The result of MlCommand
    

    The result of MlCommand
    

    Protobuf type spark.connect.MlCommandResult

  177. trait MlCommandResultOrBuilder extends MessageOrBuilder
  178. final class MlCommon extends AnyRef
  179. final class MlOperator extends GeneratedMessage with MlOperatorOrBuilder

    MLOperator represents the ML operators like (Estimator, Transformer or Evaluator)
    

    MLOperator represents the ML operators like (Estimator, Transformer or Evaluator)
    

    Protobuf type spark.connect.MlOperator

  180. trait MlOperatorOrBuilder extends MessageOrBuilder
  181. final class MlParams extends GeneratedMessage with MlParamsOrBuilder

    MlParams stores param settings for ML Estimator / Transformer / Evaluator
    

    MlParams stores param settings for ML Estimator / Transformer / Evaluator
    

    Protobuf type spark.connect.MlParams

  182. trait MlParamsOrBuilder extends MessageOrBuilder
  183. final class MlRelation extends GeneratedMessage with MlRelationOrBuilder

    Relation to represent ML world
    

    Relation to represent ML world
    

    Protobuf type spark.connect.MlRelation

  184. trait MlRelationOrBuilder extends MessageOrBuilder
  185. final class NADrop extends GeneratedMessage with NADropOrBuilder

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

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

    Protobuf type spark.connect.NADrop

  186. trait NADropOrBuilder extends MessageOrBuilder
  187. final class NAFill extends GeneratedMessage with NAFillOrBuilder

    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.
    

    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.
    

    Protobuf type spark.connect.NAFill

  188. trait NAFillOrBuilder extends MessageOrBuilder
  189. final class NAReplace extends GeneratedMessage with NAReplaceOrBuilder

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

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

    Protobuf type spark.connect.NAReplace

  190. trait NAReplaceOrBuilder extends MessageOrBuilder
  191. final class NamedArgumentExpression extends GeneratedMessage with NamedArgumentExpressionOrBuilder

    Protobuf type spark.connect.NamedArgumentExpression

  192. trait NamedArgumentExpressionOrBuilder extends MessageOrBuilder
  193. final class ObjectRef extends GeneratedMessage with ObjectRefOrBuilder

    Represents a reference to the cached object which could be a model
    or summary evaluated by a model
    

    Represents a reference to the cached object which could be a model
    or summary evaluated by a model
    

    Protobuf type spark.connect.ObjectRef

  194. trait ObjectRefOrBuilder extends MessageOrBuilder
  195. final class Offset extends GeneratedMessage with OffsetOrBuilder

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

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

    Protobuf type spark.connect.Offset

  196. trait OffsetOrBuilder extends MessageOrBuilder
  197. final class Origin extends GeneratedMessage with OriginOrBuilder

    Protobuf type spark.connect.Origin

  198. trait OriginOrBuilder extends MessageOrBuilder
  199. final class Parse extends GeneratedMessage with ParseOrBuilder

    Protobuf type spark.connect.Parse

  200. trait ParseOrBuilder extends MessageOrBuilder
  201. final class Plan extends GeneratedMessage with PlanOrBuilder

    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.
    

    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.
    

    Protobuf type spark.connect.Plan

  202. trait PlanOrBuilder extends MessageOrBuilder
  203. final class Project extends GeneratedMessage with ProjectOrBuilder

    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.
    

    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.
    

    Protobuf type spark.connect.Project

  204. trait ProjectOrBuilder extends MessageOrBuilder
  205. final class PythonDataSource extends GeneratedMessage with PythonDataSourceOrBuilder

    Protobuf type spark.connect.PythonDataSource

  206. trait PythonDataSourceOrBuilder extends MessageOrBuilder
  207. final class PythonOrigin extends GeneratedMessage with PythonOriginOrBuilder

    Protobuf type spark.connect.PythonOrigin

  208. trait PythonOriginOrBuilder extends MessageOrBuilder
  209. final class PythonUDF extends GeneratedMessage with PythonUDFOrBuilder

    Protobuf type spark.connect.PythonUDF

  210. trait PythonUDFOrBuilder extends MessageOrBuilder
  211. final class PythonUDTF extends GeneratedMessage with PythonUDTFOrBuilder

    Protobuf type spark.connect.PythonUDTF

  212. trait PythonUDTFOrBuilder extends MessageOrBuilder
  213. final class Range extends GeneratedMessage with RangeOrBuilder

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

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

    Protobuf type spark.connect.Range

  214. trait RangeOrBuilder extends MessageOrBuilder
  215. final class Read extends GeneratedMessage with ReadOrBuilder

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

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

    Protobuf type spark.connect.Read

  216. trait ReadOrBuilder extends MessageOrBuilder
  217. final class ReattachExecuteRequest extends GeneratedMessage with ReattachExecuteRequestOrBuilder

    Protobuf type spark.connect.ReattachExecuteRequest

  218. trait ReattachExecuteRequestOrBuilder extends MessageOrBuilder
  219. final class ReattachOptions extends GeneratedMessage with ReattachOptionsOrBuilder

    Protobuf type spark.connect.ReattachOptions

  220. trait ReattachOptionsOrBuilder extends MessageOrBuilder
  221. final class RecoverPartitions extends GeneratedMessage with RecoverPartitionsOrBuilder

    See `spark.catalog.recoverPartitions`
    

    See `spark.catalog.recoverPartitions`
    

    Protobuf type spark.connect.RecoverPartitions

  222. trait RecoverPartitionsOrBuilder extends MessageOrBuilder
  223. final class RefreshByPath extends GeneratedMessage with RefreshByPathOrBuilder

    See `spark.catalog.refreshByPath`
    

    See `spark.catalog.refreshByPath`
    

    Protobuf type spark.connect.RefreshByPath

  224. trait RefreshByPathOrBuilder extends MessageOrBuilder
  225. final class RefreshTable extends GeneratedMessage with RefreshTableOrBuilder

    See `spark.catalog.refreshTable`
    

    See `spark.catalog.refreshTable`
    

    Protobuf type spark.connect.RefreshTable

  226. trait RefreshTableOrBuilder extends MessageOrBuilder
  227. final class Relation extends GeneratedMessage with RelationOrBuilder

    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.
    

    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.
    

    Protobuf type spark.connect.Relation

  228. final class RelationCommon extends GeneratedMessage with RelationCommonOrBuilder

    Common metadata of all relations.
    

    Common metadata of all relations.
    

    Protobuf type spark.connect.RelationCommon

  229. trait RelationCommonOrBuilder extends MessageOrBuilder
  230. trait RelationOrBuilder extends MessageOrBuilder
  231. final class Relations extends AnyRef
  232. final class ReleaseExecuteRequest extends GeneratedMessage with ReleaseExecuteRequestOrBuilder

    Protobuf type spark.connect.ReleaseExecuteRequest

  233. trait ReleaseExecuteRequestOrBuilder extends MessageOrBuilder
  234. final class ReleaseExecuteResponse extends GeneratedMessage with ReleaseExecuteResponseOrBuilder

    Next ID: 4
    

    Next ID: 4
    

    Protobuf type spark.connect.ReleaseExecuteResponse

  235. trait ReleaseExecuteResponseOrBuilder extends MessageOrBuilder
  236. final class ReleaseSessionRequest extends GeneratedMessage with ReleaseSessionRequestOrBuilder

    Protobuf type spark.connect.ReleaseSessionRequest

  237. trait ReleaseSessionRequestOrBuilder extends MessageOrBuilder
  238. final class ReleaseSessionResponse extends GeneratedMessage with ReleaseSessionResponseOrBuilder

    Next ID: 3
    

    Next ID: 3
    

    Protobuf type spark.connect.ReleaseSessionResponse

  239. trait ReleaseSessionResponseOrBuilder extends MessageOrBuilder
  240. final class RemoveCachedRemoteRelationCommand extends GeneratedMessage with RemoveCachedRemoteRelationCommandOrBuilder

    Command to remove `CashedRemoteRelation`
    

    Command to remove `CashedRemoteRelation`
    

    Protobuf type spark.connect.RemoveCachedRemoteRelationCommand

  241. trait RemoveCachedRemoteRelationCommandOrBuilder extends MessageOrBuilder
  242. final class Repartition extends GeneratedMessage with RepartitionOrBuilder

    Relation repartition.
    

    Relation repartition.
    

    Protobuf type spark.connect.Repartition

  243. final class RepartitionByExpression extends GeneratedMessage with RepartitionByExpressionOrBuilder

    Protobuf type spark.connect.RepartitionByExpression

  244. trait RepartitionByExpressionOrBuilder extends MessageOrBuilder
  245. trait RepartitionOrBuilder extends MessageOrBuilder
  246. final class ResourceInformation extends GeneratedMessage with ResourceInformationOrBuilder

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

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

    Protobuf type spark.connect.ResourceInformation

  247. trait ResourceInformationOrBuilder extends MessageOrBuilder
  248. final class ResourceProfile extends GeneratedMessage with ResourceProfileOrBuilder

    Protobuf type spark.connect.ResourceProfile

  249. trait ResourceProfileOrBuilder extends MessageOrBuilder
  250. final class SQL extends GeneratedMessage with SQLOrBuilder

    Relation that uses a SQL query to generate the output.
    

    Relation that uses a SQL query to generate the output.
    

    Protobuf type spark.connect.SQL

  251. trait SQLOrBuilder extends MessageOrBuilder
  252. final class Sample extends GeneratedMessage with SampleOrBuilder

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

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

    Protobuf type spark.connect.Sample

  253. trait SampleOrBuilder extends MessageOrBuilder
  254. final class ScalarScalaUDF extends GeneratedMessage with ScalarScalaUDFOrBuilder

    Protobuf type spark.connect.ScalarScalaUDF

  255. trait ScalarScalaUDFOrBuilder extends MessageOrBuilder
  256. final class SetCurrentCatalog extends GeneratedMessage with SetCurrentCatalogOrBuilder

    See `spark.catalog.setCurrentCatalog`
    

    See `spark.catalog.setCurrentCatalog`
    

    Protobuf type spark.connect.SetCurrentCatalog

  257. trait SetCurrentCatalogOrBuilder extends MessageOrBuilder
  258. final class SetCurrentDatabase extends GeneratedMessage with SetCurrentDatabaseOrBuilder

    See `spark.catalog.setCurrentDatabase`
    

    See `spark.catalog.setCurrentDatabase`
    

    Protobuf type spark.connect.SetCurrentDatabase

  259. trait SetCurrentDatabaseOrBuilder extends MessageOrBuilder
  260. final class SetOperation extends GeneratedMessage with SetOperationOrBuilder

    Relation of type [[SetOperation]]
    

    Relation of type [[SetOperation]]
    

    Protobuf type spark.connect.SetOperation

  261. trait SetOperationOrBuilder extends MessageOrBuilder
  262. final class ShowString extends GeneratedMessage with ShowStringOrBuilder

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

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

    Protobuf type spark.connect.ShowString

  263. trait ShowStringOrBuilder extends MessageOrBuilder
  264. final class Sort extends GeneratedMessage with SortOrBuilder

    Relation of type [[Sort]].
    

    Relation of type [[Sort]].
    

    Protobuf type spark.connect.Sort

  265. trait SortOrBuilder extends MessageOrBuilder
  266. final class SparkConnectServiceGrpc extends AnyRef

    Main interface for the SparkConnect service.
    

    Main interface for the SparkConnect service.
    

    Annotations
    @Generated() @GrpcGenerated()
  267. final class SqlCommand extends GeneratedMessage with SqlCommandOrBuilder

    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.
    

    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.
    

    Protobuf type spark.connect.SqlCommand

  268. trait SqlCommandOrBuilder extends MessageOrBuilder
  269. final class StackTraceElement extends GeneratedMessage with StackTraceElementOrBuilder

    A message to hold a [[java.lang.StackTraceElement]].
    

    A message to hold a [[java.lang.StackTraceElement]].
    

    Protobuf type spark.connect.StackTraceElement

  270. trait StackTraceElementOrBuilder extends MessageOrBuilder
  271. final class StatApproxQuantile extends GeneratedMessage with StatApproxQuantileOrBuilder

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

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

    Protobuf type spark.connect.StatApproxQuantile

  272. trait StatApproxQuantileOrBuilder extends MessageOrBuilder
  273. final class StatCorr extends GeneratedMessage with StatCorrOrBuilder

    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.
    

    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.
    

    Protobuf type spark.connect.StatCorr

  274. trait StatCorrOrBuilder extends MessageOrBuilder
  275. final class StatCov extends GeneratedMessage with StatCovOrBuilder

    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.
    

    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.
    

    Protobuf type spark.connect.StatCov

  276. trait StatCovOrBuilder extends MessageOrBuilder
  277. final class StatCrosstab extends GeneratedMessage with StatCrosstabOrBuilder

    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.
    

    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.
    

    Protobuf type spark.connect.StatCrosstab

  278. trait StatCrosstabOrBuilder extends MessageOrBuilder
  279. final class StatDescribe extends GeneratedMessage with StatDescribeOrBuilder

    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.
    

    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.
    

    Protobuf type spark.connect.StatDescribe

  280. trait StatDescribeOrBuilder extends MessageOrBuilder
  281. final class StatFreqItems extends GeneratedMessage with StatFreqItemsOrBuilder

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

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

    Protobuf type spark.connect.StatFreqItems

  282. trait StatFreqItemsOrBuilder extends MessageOrBuilder
  283. final class StatSampleBy extends GeneratedMessage with StatSampleByOrBuilder

    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.
    

    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.
    

    Protobuf type spark.connect.StatSampleBy

  284. trait StatSampleByOrBuilder extends MessageOrBuilder
  285. final class StatSummary extends GeneratedMessage with StatSummaryOrBuilder

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

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

    Protobuf type spark.connect.StatSummary

  286. trait StatSummaryOrBuilder extends MessageOrBuilder
  287. final class StorageLevel extends GeneratedMessage with StorageLevelOrBuilder

    StorageLevel for persisting Datasets/Tables.
    

    StorageLevel for persisting Datasets/Tables.
    

    Protobuf type spark.connect.StorageLevel

  288. trait StorageLevelOrBuilder extends MessageOrBuilder
  289. final class StreamingForeachFunction extends GeneratedMessage with StreamingForeachFunctionOrBuilder

    Protobuf type spark.connect.StreamingForeachFunction

  290. trait StreamingForeachFunctionOrBuilder extends MessageOrBuilder
  291. final class StreamingQueryCommand extends GeneratedMessage with StreamingQueryCommandOrBuilder

    Commands for a streaming query.
    

    Commands for a streaming query.
    

    Protobuf type spark.connect.StreamingQueryCommand

  292. trait StreamingQueryCommandOrBuilder extends MessageOrBuilder
  293. final class StreamingQueryCommandResult extends GeneratedMessage with StreamingQueryCommandResultOrBuilder

    Response for commands on a streaming query.
    

    Response for commands on a streaming query.
    

    Protobuf type spark.connect.StreamingQueryCommandResult

  294. trait StreamingQueryCommandResultOrBuilder extends MessageOrBuilder
  295. sealed final class StreamingQueryEventType extends Enum[StreamingQueryEventType] with ProtocolMessageEnum

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

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

    Protobuf enum spark.connect.StreamingQueryEventType

  296. final class StreamingQueryInstanceId extends GeneratedMessage with StreamingQueryInstanceIdOrBuilder

    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.
    

    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.
    

    Protobuf type spark.connect.StreamingQueryInstanceId

  297. trait StreamingQueryInstanceIdOrBuilder extends MessageOrBuilder
  298. final class StreamingQueryListenerBusCommand extends GeneratedMessage with StreamingQueryListenerBusCommandOrBuilder

    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.
    

    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.
    

    Protobuf type spark.connect.StreamingQueryListenerBusCommand

  299. trait StreamingQueryListenerBusCommandOrBuilder extends MessageOrBuilder
  300. final class StreamingQueryListenerEvent extends GeneratedMessage with StreamingQueryListenerEventOrBuilder

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

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

    Protobuf type spark.connect.StreamingQueryListenerEvent

  301. trait StreamingQueryListenerEventOrBuilder extends MessageOrBuilder
  302. final class StreamingQueryListenerEventsResult extends GeneratedMessage with StreamingQueryListenerEventsResultOrBuilder

    Protobuf type spark.connect.StreamingQueryListenerEventsResult

  303. trait StreamingQueryListenerEventsResultOrBuilder extends MessageOrBuilder
  304. final class StreamingQueryManagerCommand extends GeneratedMessage with StreamingQueryManagerCommandOrBuilder

    Commands for the streaming query manager.
    

    Commands for the streaming query manager.
    

    Protobuf type spark.connect.StreamingQueryManagerCommand

  305. trait StreamingQueryManagerCommandOrBuilder extends MessageOrBuilder
  306. final class StreamingQueryManagerCommandResult extends GeneratedMessage with StreamingQueryManagerCommandResultOrBuilder

    Response for commands on the streaming query manager.
    

    Response for commands on the streaming query manager.
    

    Protobuf type spark.connect.StreamingQueryManagerCommandResult

  307. trait StreamingQueryManagerCommandResultOrBuilder extends MessageOrBuilder
  308. final class Strings extends GeneratedMessage with StringsOrBuilder

    Protobuf type spark.connect.Strings

  309. trait StringsOrBuilder extends MessageOrBuilder
  310. final class SubqueryAlias extends GeneratedMessage with SubqueryAliasOrBuilder

    Relation alias.
    

    Relation alias.
    

    Protobuf type spark.connect.SubqueryAlias

  311. trait SubqueryAliasOrBuilder extends MessageOrBuilder
  312. final class SubqueryExpression extends GeneratedMessage with SubqueryExpressionOrBuilder

    Protobuf type spark.connect.SubqueryExpression

  313. trait SubqueryExpressionOrBuilder extends MessageOrBuilder
  314. final class TableExists extends GeneratedMessage with TableExistsOrBuilder

    See `spark.catalog.tableExists`
    

    See `spark.catalog.tableExists`
    

    Protobuf type spark.connect.TableExists

  315. trait TableExistsOrBuilder extends MessageOrBuilder
  316. final class Tail extends GeneratedMessage with TailOrBuilder

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

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

    Protobuf type spark.connect.Tail

  317. trait TailOrBuilder extends MessageOrBuilder
  318. final class TaskResourceRequest extends GeneratedMessage with TaskResourceRequestOrBuilder

    A task resource request.
    

    A task resource request.
    

    Protobuf type spark.connect.TaskResourceRequest

  319. trait TaskResourceRequestOrBuilder extends MessageOrBuilder
  320. final class ToDF extends GeneratedMessage with ToDFOrBuilder

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

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

    Protobuf type spark.connect.ToDF

  321. trait ToDFOrBuilder extends MessageOrBuilder
  322. final class ToSchema extends GeneratedMessage with ToSchemaOrBuilder

    Protobuf type spark.connect.ToSchema

  323. trait ToSchemaOrBuilder extends MessageOrBuilder
  324. final class Transpose extends GeneratedMessage with TransposeOrBuilder

    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.
    

    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.
    

    Protobuf type spark.connect.Transpose

  325. trait TransposeOrBuilder extends MessageOrBuilder
  326. final class TypedAggregateExpression extends GeneratedMessage with TypedAggregateExpressionOrBuilder

    Protobuf type spark.connect.TypedAggregateExpression

  327. trait TypedAggregateExpressionOrBuilder extends MessageOrBuilder
  328. final class Types extends AnyRef
  329. final class UncacheTable extends GeneratedMessage with UncacheTableOrBuilder

    See `spark.catalog.uncacheTable`
    

    See `spark.catalog.uncacheTable`
    

    Protobuf type spark.connect.UncacheTable

  330. trait UncacheTableOrBuilder extends MessageOrBuilder
  331. final class Unknown extends GeneratedMessage with UnknownOrBuilder

    Used for testing purposes only.
    

    Used for testing purposes only.
    

    Protobuf type spark.connect.Unknown

  332. trait UnknownOrBuilder extends MessageOrBuilder
  333. final class Unpivot extends GeneratedMessage with UnpivotOrBuilder

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

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

    Protobuf type spark.connect.Unpivot

  334. trait UnpivotOrBuilder extends MessageOrBuilder
  335. final class UnresolvedTableValuedFunction extends GeneratedMessage with UnresolvedTableValuedFunctionOrBuilder

    Protobuf type spark.connect.UnresolvedTableValuedFunction

  336. trait UnresolvedTableValuedFunctionOrBuilder extends MessageOrBuilder
  337. final class UserContext extends GeneratedMessage with UserContextOrBuilder

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

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

    Protobuf type spark.connect.UserContext

  338. trait UserContextOrBuilder extends MessageOrBuilder
  339. final class WithColumns extends GeneratedMessage with WithColumnsOrBuilder

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

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

    Protobuf type spark.connect.WithColumns

  340. trait WithColumnsOrBuilder extends MessageOrBuilder
  341. final class WithColumnsRenamed extends GeneratedMessage with WithColumnsRenamedOrBuilder

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

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

    Protobuf type spark.connect.WithColumnsRenamed

  342. trait WithColumnsRenamedOrBuilder extends MessageOrBuilder
  343. final class WithRelations extends GeneratedMessage with WithRelationsOrBuilder

    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.
    

    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.
    

    Protobuf type spark.connect.WithRelations

  344. trait WithRelationsOrBuilder extends MessageOrBuilder
  345. final class WithWatermark extends GeneratedMessage with WithWatermarkOrBuilder

    Protobuf type spark.connect.WithWatermark

  346. trait WithWatermarkOrBuilder extends MessageOrBuilder
  347. final class WriteOperation extends GeneratedMessage with WriteOperationOrBuilder

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

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

    Protobuf type spark.connect.WriteOperation

  348. trait WriteOperationOrBuilder extends MessageOrBuilder
  349. final class WriteOperationV2 extends GeneratedMessage with WriteOperationV2OrBuilder

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

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

    Protobuf type spark.connect.WriteOperationV2

  350. trait WriteOperationV2OrBuilder extends MessageOrBuilder
  351. final class WriteStreamOperationStart extends GeneratedMessage with WriteStreamOperationStartOrBuilder

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

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

    Protobuf type spark.connect.WriteStreamOperationStart

  352. trait WriteStreamOperationStartOrBuilder extends MessageOrBuilder
  353. final class WriteStreamOperationStartResult extends GeneratedMessage with WriteStreamOperationStartResultOrBuilder

    Protobuf type spark.connect.WriteStreamOperationStartResult

  354. trait WriteStreamOperationStartResultOrBuilder extends MessageOrBuilder

Ungrouped