Packages

t

org.apache.spark.connect.proto

RelationOrBuilder

trait RelationOrBuilder extends MessageOrBuilder

Linear Supertypes
MessageOrBuilder, MessageLiteOrBuilder, AnyRef, Any
Known Subclasses
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. RelationOrBuilder
  2. MessageOrBuilder
  3. MessageLiteOrBuilder
  4. AnyRef
  5. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Abstract Value Members

  1. abstract def findInitializationErrors(): List[String]
    Definition Classes
    MessageOrBuilder
  2. abstract def getAggregate(): Aggregate

    .spark.connect.Aggregate aggregate = 9;

    .spark.connect.Aggregate aggregate = 9;

    returns

    The aggregate.

  3. abstract def getAggregateOrBuilder(): AggregateOrBuilder

    .spark.connect.Aggregate aggregate = 9;

  4. abstract def getAllFields(): Map[FieldDescriptor, AnyRef]
    Definition Classes
    MessageOrBuilder
  5. abstract def getApplyInPandasWithState(): ApplyInPandasWithState

    .spark.connect.ApplyInPandasWithState apply_in_pandas_with_state = 34;

    .spark.connect.ApplyInPandasWithState apply_in_pandas_with_state = 34;

    returns

    The applyInPandasWithState.

  6. abstract def getApplyInPandasWithStateOrBuilder(): ApplyInPandasWithStateOrBuilder

    .spark.connect.ApplyInPandasWithState apply_in_pandas_with_state = 34;

  7. abstract def getApproxQuantile(): StatApproxQuantile

    .spark.connect.StatApproxQuantile approx_quantile = 105;

    .spark.connect.StatApproxQuantile approx_quantile = 105;

    returns

    The approxQuantile.

  8. abstract def getApproxQuantileOrBuilder(): StatApproxQuantileOrBuilder

    .spark.connect.StatApproxQuantile approx_quantile = 105;

  9. abstract def getAsOfJoin(): AsOfJoin

    .spark.connect.AsOfJoin as_of_join = 39;

    .spark.connect.AsOfJoin as_of_join = 39;

    returns

    The asOfJoin.

  10. abstract def getAsOfJoinOrBuilder(): AsOfJoinOrBuilder

    .spark.connect.AsOfJoin as_of_join = 39;

  11. abstract def getCachedLocalRelation(): CachedLocalRelation

    .spark.connect.CachedLocalRelation cached_local_relation = 36;

    .spark.connect.CachedLocalRelation cached_local_relation = 36;

    returns

    The cachedLocalRelation.

  12. abstract def getCachedLocalRelationOrBuilder(): CachedLocalRelationOrBuilder

    .spark.connect.CachedLocalRelation cached_local_relation = 36;

  13. abstract def getCachedRemoteRelation(): CachedRemoteRelation

    .spark.connect.CachedRemoteRelation cached_remote_relation = 37;

    .spark.connect.CachedRemoteRelation cached_remote_relation = 37;

    returns

    The cachedRemoteRelation.

  14. abstract def getCachedRemoteRelationOrBuilder(): CachedRemoteRelationOrBuilder

    .spark.connect.CachedRemoteRelation cached_remote_relation = 37;

  15. abstract def getCatalog(): Catalog

    Catalog API (experimental / unstable)
    

    Catalog API (experimental / unstable)
    

    .spark.connect.Catalog catalog = 200;

    returns

    The catalog.

  16. abstract def getCatalogOrBuilder(): CatalogOrBuilder

    Catalog API (experimental / unstable)
    

    Catalog API (experimental / unstable)
    

    .spark.connect.Catalog catalog = 200;

  17. abstract def getCoGroupMap(): CoGroupMap

    .spark.connect.CoGroupMap co_group_map = 32;

    .spark.connect.CoGroupMap co_group_map = 32;

    returns

    The coGroupMap.

  18. abstract def getCoGroupMapOrBuilder(): CoGroupMapOrBuilder

    .spark.connect.CoGroupMap co_group_map = 32;

  19. abstract def getCollectMetrics(): CollectMetrics

    .spark.connect.CollectMetrics collect_metrics = 29;

    .spark.connect.CollectMetrics collect_metrics = 29;

    returns

    The collectMetrics.

  20. abstract def getCollectMetricsOrBuilder(): CollectMetricsOrBuilder

    .spark.connect.CollectMetrics collect_metrics = 29;

  21. abstract def getCommon(): RelationCommon

    .spark.connect.RelationCommon common = 1;

    .spark.connect.RelationCommon common = 1;

    returns

    The common.

  22. abstract def getCommonInlineUserDefinedDataSource(): CommonInlineUserDefinedDataSource

    .spark.connect.CommonInlineUserDefinedDataSource common_inline_user_defined_data_source = 40;

    .spark.connect.CommonInlineUserDefinedDataSource common_inline_user_defined_data_source = 40;

    returns

    The commonInlineUserDefinedDataSource.

  23. abstract def getCommonInlineUserDefinedDataSourceOrBuilder(): CommonInlineUserDefinedDataSourceOrBuilder

    .spark.connect.CommonInlineUserDefinedDataSource common_inline_user_defined_data_source = 40;

  24. abstract def getCommonInlineUserDefinedTableFunction(): CommonInlineUserDefinedTableFunction

    .spark.connect.CommonInlineUserDefinedTableFunction common_inline_user_defined_table_function = 38;

    .spark.connect.CommonInlineUserDefinedTableFunction common_inline_user_defined_table_function = 38;

    returns

    The commonInlineUserDefinedTableFunction.

  25. abstract def getCommonInlineUserDefinedTableFunctionOrBuilder(): CommonInlineUserDefinedTableFunctionOrBuilder

    .spark.connect.CommonInlineUserDefinedTableFunction common_inline_user_defined_table_function = 38;

  26. abstract def getCommonOrBuilder(): RelationCommonOrBuilder

    .spark.connect.RelationCommon common = 1;

  27. abstract def getCorr(): StatCorr

    .spark.connect.StatCorr corr = 104;

    .spark.connect.StatCorr corr = 104;

    returns

    The corr.

  28. abstract def getCorrOrBuilder(): StatCorrOrBuilder

    .spark.connect.StatCorr corr = 104;

  29. abstract def getCov(): StatCov

    .spark.connect.StatCov cov = 103;

    .spark.connect.StatCov cov = 103;

    returns

    The cov.

  30. abstract def getCovOrBuilder(): StatCovOrBuilder

    .spark.connect.StatCov cov = 103;

  31. abstract def getCrosstab(): StatCrosstab

    .spark.connect.StatCrosstab crosstab = 101;

    .spark.connect.StatCrosstab crosstab = 101;

    returns

    The crosstab.

  32. abstract def getCrosstabOrBuilder(): StatCrosstabOrBuilder

    .spark.connect.StatCrosstab crosstab = 101;

  33. abstract def getDeduplicate(): Deduplicate

    .spark.connect.Deduplicate deduplicate = 14;

    .spark.connect.Deduplicate deduplicate = 14;

    returns

    The deduplicate.

  34. abstract def getDeduplicateOrBuilder(): DeduplicateOrBuilder

    .spark.connect.Deduplicate deduplicate = 14;

  35. abstract def getDefaultInstanceForType(): Message
    Definition Classes
    MessageOrBuilder → MessageLiteOrBuilder
  36. abstract def getDescribe(): StatDescribe

    .spark.connect.StatDescribe describe = 102;

    .spark.connect.StatDescribe describe = 102;

    returns

    The describe.

  37. abstract def getDescribeOrBuilder(): StatDescribeOrBuilder

    .spark.connect.StatDescribe describe = 102;

  38. abstract def getDescriptorForType(): Descriptor
    Definition Classes
    MessageOrBuilder
  39. abstract def getDrop(): Drop

    .spark.connect.Drop drop = 21;

    .spark.connect.Drop drop = 21;

    returns

    The drop.

  40. abstract def getDropNa(): NADrop

    .spark.connect.NADrop drop_na = 91;

    .spark.connect.NADrop drop_na = 91;

    returns

    The dropNa.

  41. abstract def getDropNaOrBuilder(): NADropOrBuilder

    .spark.connect.NADrop drop_na = 91;

  42. abstract def getDropOrBuilder(): DropOrBuilder

    .spark.connect.Drop drop = 21;

  43. abstract def getExtension(): Any

    This field is used to mark extensions to the protocol. When plugins generate arbitrary
    relations they can add them here. During the planning the correct resolution is done.
    

    This field is used to mark extensions to the protocol. When plugins generate arbitrary
    relations they can add them here. During the planning the correct resolution is done.
    

    .google.protobuf.Any extension = 998;

    returns

    The extension.

  44. abstract def getExtensionOrBuilder(): AnyOrBuilder

    This field is used to mark extensions to the protocol. When plugins generate arbitrary
    relations they can add them here. During the planning the correct resolution is done.
    

    This field is used to mark extensions to the protocol. When plugins generate arbitrary
    relations they can add them here. During the planning the correct resolution is done.
    

    .google.protobuf.Any extension = 998;

  45. abstract def getField(field: FieldDescriptor): AnyRef
    Definition Classes
    MessageOrBuilder
  46. abstract def getFillNa(): NAFill

    NA functions
    

    NA functions
    

    .spark.connect.NAFill fill_na = 90;

    returns

    The fillNa.

  47. abstract def getFillNaOrBuilder(): NAFillOrBuilder

    NA functions
    

    NA functions
    

    .spark.connect.NAFill fill_na = 90;

  48. abstract def getFilter(): Filter

    .spark.connect.Filter filter = 4;

    .spark.connect.Filter filter = 4;

    returns

    The filter.

  49. abstract def getFilterOrBuilder(): FilterOrBuilder

    .spark.connect.Filter filter = 4;

  50. abstract def getFreqItems(): StatFreqItems

    .spark.connect.StatFreqItems freq_items = 106;

    .spark.connect.StatFreqItems freq_items = 106;

    returns

    The freqItems.

  51. abstract def getFreqItemsOrBuilder(): StatFreqItemsOrBuilder

    .spark.connect.StatFreqItems freq_items = 106;

  52. abstract def getGroupMap(): GroupMap

    .spark.connect.GroupMap group_map = 31;

    .spark.connect.GroupMap group_map = 31;

    returns

    The groupMap.

  53. abstract def getGroupMapOrBuilder(): GroupMapOrBuilder

    .spark.connect.GroupMap group_map = 31;

  54. abstract def getHint(): Hint

    .spark.connect.Hint hint = 24;

    .spark.connect.Hint hint = 24;

    returns

    The hint.

  55. abstract def getHintOrBuilder(): HintOrBuilder

    .spark.connect.Hint hint = 24;

  56. abstract def getHtmlString(): HtmlString

    .spark.connect.HtmlString html_string = 35;

    .spark.connect.HtmlString html_string = 35;

    returns

    The htmlString.

  57. abstract def getHtmlStringOrBuilder(): HtmlStringOrBuilder

    .spark.connect.HtmlString html_string = 35;

  58. abstract def getInitializationErrorString(): String
    Definition Classes
    MessageOrBuilder
  59. abstract def getJoin(): Join

    .spark.connect.Join join = 5;

    .spark.connect.Join join = 5;

    returns

    The join.

  60. abstract def getJoinOrBuilder(): JoinOrBuilder

    .spark.connect.Join join = 5;

  61. abstract def getLateralJoin(): LateralJoin

    .spark.connect.LateralJoin lateral_join = 44;

    .spark.connect.LateralJoin lateral_join = 44;

    returns

    The lateralJoin.

  62. abstract def getLateralJoinOrBuilder(): LateralJoinOrBuilder

    .spark.connect.LateralJoin lateral_join = 44;

  63. abstract def getLimit(): Limit

    .spark.connect.Limit limit = 8;

    .spark.connect.Limit limit = 8;

    returns

    The limit.

  64. abstract def getLimitOrBuilder(): LimitOrBuilder

    .spark.connect.Limit limit = 8;

  65. abstract def getLocalRelation(): LocalRelation

    .spark.connect.LocalRelation local_relation = 11;

    .spark.connect.LocalRelation local_relation = 11;

    returns

    The localRelation.

  66. abstract def getLocalRelationOrBuilder(): LocalRelationOrBuilder

    .spark.connect.LocalRelation local_relation = 11;

  67. abstract def getMapPartitions(): MapPartitions

    .spark.connect.MapPartitions map_partitions = 28;

    .spark.connect.MapPartitions map_partitions = 28;

    returns

    The mapPartitions.

  68. abstract def getMapPartitionsOrBuilder(): MapPartitionsOrBuilder

    .spark.connect.MapPartitions map_partitions = 28;

  69. abstract def getMlRelation(): MlRelation

    ML relation
    

    ML relation
    

    .spark.connect.MlRelation ml_relation = 300;

    returns

    The mlRelation.

  70. abstract def getMlRelationOrBuilder(): MlRelationOrBuilder

    ML relation
    

    ML relation
    

    .spark.connect.MlRelation ml_relation = 300;

  71. abstract def getOffset(): Offset

    .spark.connect.Offset offset = 13;

    .spark.connect.Offset offset = 13;

    returns

    The offset.

  72. abstract def getOffsetOrBuilder(): OffsetOrBuilder

    .spark.connect.Offset offset = 13;

  73. abstract def getOneofFieldDescriptor(oneof: OneofDescriptor): FieldDescriptor
    Definition Classes
    MessageOrBuilder
  74. abstract def getParse(): Parse

    .spark.connect.Parse parse = 30;

    .spark.connect.Parse parse = 30;

    returns

    The parse.

  75. abstract def getParseOrBuilder(): ParseOrBuilder

    .spark.connect.Parse parse = 30;

  76. abstract def getProject(): Project

    .spark.connect.Project project = 3;

    .spark.connect.Project project = 3;

    returns

    The project.

  77. abstract def getProjectOrBuilder(): ProjectOrBuilder

    .spark.connect.Project project = 3;

  78. abstract def getRange(): Range

    .spark.connect.Range range = 15;

    .spark.connect.Range range = 15;

    returns

    The range.

  79. abstract def getRangeOrBuilder(): RangeOrBuilder

    .spark.connect.Range range = 15;

  80. abstract def getRead(): Read

    .spark.connect.Read read = 2;

    .spark.connect.Read read = 2;

    returns

    The read.

  81. abstract def getReadOrBuilder(): ReadOrBuilder

    .spark.connect.Read read = 2;

  82. abstract def getRelTypeCase(): RelTypeCase
  83. abstract def getRepartition(): Repartition

    .spark.connect.Repartition repartition = 17;

    .spark.connect.Repartition repartition = 17;

    returns

    The repartition.

  84. abstract def getRepartitionByExpression(): RepartitionByExpression

    .spark.connect.RepartitionByExpression repartition_by_expression = 27;

    .spark.connect.RepartitionByExpression repartition_by_expression = 27;

    returns

    The repartitionByExpression.

  85. abstract def getRepartitionByExpressionOrBuilder(): RepartitionByExpressionOrBuilder

    .spark.connect.RepartitionByExpression repartition_by_expression = 27;

  86. abstract def getRepartitionOrBuilder(): RepartitionOrBuilder

    .spark.connect.Repartition repartition = 17;

  87. abstract def getRepeatedField(field: FieldDescriptor, index: Int): AnyRef
    Definition Classes
    MessageOrBuilder
  88. abstract def getRepeatedFieldCount(field: FieldDescriptor): Int
    Definition Classes
    MessageOrBuilder
  89. abstract def getReplace(): NAReplace

    .spark.connect.NAReplace replace = 92;

    .spark.connect.NAReplace replace = 92;

    returns

    The replace.

  90. abstract def getReplaceOrBuilder(): NAReplaceOrBuilder

    .spark.connect.NAReplace replace = 92;

  91. abstract def getSample(): Sample

    .spark.connect.Sample sample = 12;

    .spark.connect.Sample sample = 12;

    returns

    The sample.

  92. abstract def getSampleBy(): StatSampleBy

    .spark.connect.StatSampleBy sample_by = 107;

    .spark.connect.StatSampleBy sample_by = 107;

    returns

    The sampleBy.

  93. abstract def getSampleByOrBuilder(): StatSampleByOrBuilder

    .spark.connect.StatSampleBy sample_by = 107;

  94. abstract def getSampleOrBuilder(): SampleOrBuilder

    .spark.connect.Sample sample = 12;

  95. abstract def getSetOp(): SetOperation

    .spark.connect.SetOperation set_op = 6;

    .spark.connect.SetOperation set_op = 6;

    returns

    The setOp.

  96. abstract def getSetOpOrBuilder(): SetOperationOrBuilder

    .spark.connect.SetOperation set_op = 6;

  97. abstract def getShowString(): ShowString

    .spark.connect.ShowString show_string = 20;

    .spark.connect.ShowString show_string = 20;

    returns

    The showString.

  98. abstract def getShowStringOrBuilder(): ShowStringOrBuilder

    .spark.connect.ShowString show_string = 20;

  99. abstract def getSort(): Sort

    .spark.connect.Sort sort = 7;

    .spark.connect.Sort sort = 7;

    returns

    The sort.

  100. abstract def getSortOrBuilder(): SortOrBuilder

    .spark.connect.Sort sort = 7;

  101. abstract def getSql(): SQL

    .spark.connect.SQL sql = 10;

    .spark.connect.SQL sql = 10;

    returns

    The sql.

  102. abstract def getSqlOrBuilder(): SQLOrBuilder

    .spark.connect.SQL sql = 10;

  103. abstract def getSubqueryAlias(): SubqueryAlias

    .spark.connect.SubqueryAlias subquery_alias = 16;

    .spark.connect.SubqueryAlias subquery_alias = 16;

    returns

    The subqueryAlias.

  104. abstract def getSubqueryAliasOrBuilder(): SubqueryAliasOrBuilder

    .spark.connect.SubqueryAlias subquery_alias = 16;

  105. abstract def getSummary(): StatSummary

    stat functions
    

    stat functions
    

    .spark.connect.StatSummary summary = 100;

    returns

    The summary.

  106. abstract def getSummaryOrBuilder(): StatSummaryOrBuilder

    stat functions
    

    stat functions
    

    .spark.connect.StatSummary summary = 100;

  107. abstract def getTail(): Tail

    .spark.connect.Tail tail = 22;

    .spark.connect.Tail tail = 22;

    returns

    The tail.

  108. abstract def getTailOrBuilder(): TailOrBuilder

    .spark.connect.Tail tail = 22;

  109. abstract def getToDf(): ToDF

    .spark.connect.ToDF to_df = 18;

    .spark.connect.ToDF to_df = 18;

    returns

    The toDf.

  110. abstract def getToDfOrBuilder(): ToDFOrBuilder

    .spark.connect.ToDF to_df = 18;

  111. abstract def getToSchema(): ToSchema

    .spark.connect.ToSchema to_schema = 26;

    .spark.connect.ToSchema to_schema = 26;

    returns

    The toSchema.

  112. abstract def getToSchemaOrBuilder(): ToSchemaOrBuilder

    .spark.connect.ToSchema to_schema = 26;

  113. abstract def getTranspose(): Transpose

    .spark.connect.Transpose transpose = 42;

    .spark.connect.Transpose transpose = 42;

    returns

    The transpose.

  114. abstract def getTransposeOrBuilder(): TransposeOrBuilder

    .spark.connect.Transpose transpose = 42;

  115. abstract def getUnknown(): Unknown

    .spark.connect.Unknown unknown = 999;

    .spark.connect.Unknown unknown = 999;

    returns

    The unknown.

  116. abstract def getUnknownFields(): UnknownFieldSet
    Definition Classes
    MessageOrBuilder
  117. abstract def getUnknownOrBuilder(): UnknownOrBuilder

    .spark.connect.Unknown unknown = 999;

  118. abstract def getUnpivot(): Unpivot

    .spark.connect.Unpivot unpivot = 25;

    .spark.connect.Unpivot unpivot = 25;

    returns

    The unpivot.

  119. abstract def getUnpivotOrBuilder(): UnpivotOrBuilder

    .spark.connect.Unpivot unpivot = 25;

  120. abstract def getUnresolvedTableValuedFunction(): UnresolvedTableValuedFunction

    .spark.connect.UnresolvedTableValuedFunction unresolved_table_valued_function = 43;

    .spark.connect.UnresolvedTableValuedFunction unresolved_table_valued_function = 43;

    returns

    The unresolvedTableValuedFunction.

  121. abstract def getUnresolvedTableValuedFunctionOrBuilder(): UnresolvedTableValuedFunctionOrBuilder

    .spark.connect.UnresolvedTableValuedFunction unresolved_table_valued_function = 43;

  122. abstract def getWithColumns(): WithColumns

    .spark.connect.WithColumns with_columns = 23;

    .spark.connect.WithColumns with_columns = 23;

    returns

    The withColumns.

  123. abstract def getWithColumnsOrBuilder(): WithColumnsOrBuilder

    .spark.connect.WithColumns with_columns = 23;

  124. abstract def getWithColumnsRenamed(): WithColumnsRenamed

    .spark.connect.WithColumnsRenamed with_columns_renamed = 19;

    .spark.connect.WithColumnsRenamed with_columns_renamed = 19;

    returns

    The withColumnsRenamed.

  125. abstract def getWithColumnsRenamedOrBuilder(): WithColumnsRenamedOrBuilder

    .spark.connect.WithColumnsRenamed with_columns_renamed = 19;

  126. abstract def getWithRelations(): WithRelations

    .spark.connect.WithRelations with_relations = 41;

    .spark.connect.WithRelations with_relations = 41;

    returns

    The withRelations.

  127. abstract def getWithRelationsOrBuilder(): WithRelationsOrBuilder

    .spark.connect.WithRelations with_relations = 41;

  128. abstract def getWithWatermark(): WithWatermark

    .spark.connect.WithWatermark with_watermark = 33;

    .spark.connect.WithWatermark with_watermark = 33;

    returns

    The withWatermark.

  129. abstract def getWithWatermarkOrBuilder(): WithWatermarkOrBuilder

    .spark.connect.WithWatermark with_watermark = 33;

  130. abstract def hasAggregate(): Boolean

    .spark.connect.Aggregate aggregate = 9;

    .spark.connect.Aggregate aggregate = 9;

    returns

    Whether the aggregate field is set.

  131. abstract def hasApplyInPandasWithState(): Boolean

    .spark.connect.ApplyInPandasWithState apply_in_pandas_with_state = 34;

    .spark.connect.ApplyInPandasWithState apply_in_pandas_with_state = 34;

    returns

    Whether the applyInPandasWithState field is set.

  132. abstract def hasApproxQuantile(): Boolean

    .spark.connect.StatApproxQuantile approx_quantile = 105;

    .spark.connect.StatApproxQuantile approx_quantile = 105;

    returns

    Whether the approxQuantile field is set.

  133. abstract def hasAsOfJoin(): Boolean

    .spark.connect.AsOfJoin as_of_join = 39;

    .spark.connect.AsOfJoin as_of_join = 39;

    returns

    Whether the asOfJoin field is set.

  134. abstract def hasCachedLocalRelation(): Boolean

    .spark.connect.CachedLocalRelation cached_local_relation = 36;

    .spark.connect.CachedLocalRelation cached_local_relation = 36;

    returns

    Whether the cachedLocalRelation field is set.

  135. abstract def hasCachedRemoteRelation(): Boolean

    .spark.connect.CachedRemoteRelation cached_remote_relation = 37;

    .spark.connect.CachedRemoteRelation cached_remote_relation = 37;

    returns

    Whether the cachedRemoteRelation field is set.

  136. abstract def hasCatalog(): Boolean

    Catalog API (experimental / unstable)
    

    Catalog API (experimental / unstable)
    

    .spark.connect.Catalog catalog = 200;

    returns

    Whether the catalog field is set.

  137. abstract def hasCoGroupMap(): Boolean

    .spark.connect.CoGroupMap co_group_map = 32;

    .spark.connect.CoGroupMap co_group_map = 32;

    returns

    Whether the coGroupMap field is set.

  138. abstract def hasCollectMetrics(): Boolean

    .spark.connect.CollectMetrics collect_metrics = 29;

    .spark.connect.CollectMetrics collect_metrics = 29;

    returns

    Whether the collectMetrics field is set.

  139. abstract def hasCommon(): Boolean

    .spark.connect.RelationCommon common = 1;

    .spark.connect.RelationCommon common = 1;

    returns

    Whether the common field is set.

  140. abstract def hasCommonInlineUserDefinedDataSource(): Boolean

    .spark.connect.CommonInlineUserDefinedDataSource common_inline_user_defined_data_source = 40;

    .spark.connect.CommonInlineUserDefinedDataSource common_inline_user_defined_data_source = 40;

    returns

    Whether the commonInlineUserDefinedDataSource field is set.

  141. abstract def hasCommonInlineUserDefinedTableFunction(): Boolean

    .spark.connect.CommonInlineUserDefinedTableFunction common_inline_user_defined_table_function = 38;

    .spark.connect.CommonInlineUserDefinedTableFunction common_inline_user_defined_table_function = 38;

    returns

    Whether the commonInlineUserDefinedTableFunction field is set.

  142. abstract def hasCorr(): Boolean

    .spark.connect.StatCorr corr = 104;

    .spark.connect.StatCorr corr = 104;

    returns

    Whether the corr field is set.

  143. abstract def hasCov(): Boolean

    .spark.connect.StatCov cov = 103;

    .spark.connect.StatCov cov = 103;

    returns

    Whether the cov field is set.

  144. abstract def hasCrosstab(): Boolean

    .spark.connect.StatCrosstab crosstab = 101;

    .spark.connect.StatCrosstab crosstab = 101;

    returns

    Whether the crosstab field is set.

  145. abstract def hasDeduplicate(): Boolean

    .spark.connect.Deduplicate deduplicate = 14;

    .spark.connect.Deduplicate deduplicate = 14;

    returns

    Whether the deduplicate field is set.

  146. abstract def hasDescribe(): Boolean

    .spark.connect.StatDescribe describe = 102;

    .spark.connect.StatDescribe describe = 102;

    returns

    Whether the describe field is set.

  147. abstract def hasDrop(): Boolean

    .spark.connect.Drop drop = 21;

    .spark.connect.Drop drop = 21;

    returns

    Whether the drop field is set.

  148. abstract def hasDropNa(): Boolean

    .spark.connect.NADrop drop_na = 91;

    .spark.connect.NADrop drop_na = 91;

    returns

    Whether the dropNa field is set.

  149. abstract def hasExtension(): Boolean

    This field is used to mark extensions to the protocol. When plugins generate arbitrary
    relations they can add them here. During the planning the correct resolution is done.
    

    This field is used to mark extensions to the protocol. When plugins generate arbitrary
    relations they can add them here. During the planning the correct resolution is done.
    

    .google.protobuf.Any extension = 998;

    returns

    Whether the extension field is set.

  150. abstract def hasField(field: FieldDescriptor): Boolean
    Definition Classes
    MessageOrBuilder
  151. abstract def hasFillNa(): Boolean

    NA functions
    

    NA functions
    

    .spark.connect.NAFill fill_na = 90;

    returns

    Whether the fillNa field is set.

  152. abstract def hasFilter(): Boolean

    .spark.connect.Filter filter = 4;

    .spark.connect.Filter filter = 4;

    returns

    Whether the filter field is set.

  153. abstract def hasFreqItems(): Boolean

    .spark.connect.StatFreqItems freq_items = 106;

    .spark.connect.StatFreqItems freq_items = 106;

    returns

    Whether the freqItems field is set.

  154. abstract def hasGroupMap(): Boolean

    .spark.connect.GroupMap group_map = 31;

    .spark.connect.GroupMap group_map = 31;

    returns

    Whether the groupMap field is set.

  155. abstract def hasHint(): Boolean

    .spark.connect.Hint hint = 24;

    .spark.connect.Hint hint = 24;

    returns

    Whether the hint field is set.

  156. abstract def hasHtmlString(): Boolean

    .spark.connect.HtmlString html_string = 35;

    .spark.connect.HtmlString html_string = 35;

    returns

    Whether the htmlString field is set.

  157. abstract def hasJoin(): Boolean

    .spark.connect.Join join = 5;

    .spark.connect.Join join = 5;

    returns

    Whether the join field is set.

  158. abstract def hasLateralJoin(): Boolean

    .spark.connect.LateralJoin lateral_join = 44;

    .spark.connect.LateralJoin lateral_join = 44;

    returns

    Whether the lateralJoin field is set.

  159. abstract def hasLimit(): Boolean

    .spark.connect.Limit limit = 8;

    .spark.connect.Limit limit = 8;

    returns

    Whether the limit field is set.

  160. abstract def hasLocalRelation(): Boolean

    .spark.connect.LocalRelation local_relation = 11;

    .spark.connect.LocalRelation local_relation = 11;

    returns

    Whether the localRelation field is set.

  161. abstract def hasMapPartitions(): Boolean

    .spark.connect.MapPartitions map_partitions = 28;

    .spark.connect.MapPartitions map_partitions = 28;

    returns

    Whether the mapPartitions field is set.

  162. abstract def hasMlRelation(): Boolean

    ML relation
    

    ML relation
    

    .spark.connect.MlRelation ml_relation = 300;

    returns

    Whether the mlRelation field is set.

  163. abstract def hasOffset(): Boolean

    .spark.connect.Offset offset = 13;

    .spark.connect.Offset offset = 13;

    returns

    Whether the offset field is set.

  164. abstract def hasOneof(oneof: OneofDescriptor): Boolean
    Definition Classes
    MessageOrBuilder
  165. abstract def hasParse(): Boolean

    .spark.connect.Parse parse = 30;

    .spark.connect.Parse parse = 30;

    returns

    Whether the parse field is set.

  166. abstract def hasProject(): Boolean

    .spark.connect.Project project = 3;

    .spark.connect.Project project = 3;

    returns

    Whether the project field is set.

  167. abstract def hasRange(): Boolean

    .spark.connect.Range range = 15;

    .spark.connect.Range range = 15;

    returns

    Whether the range field is set.

  168. abstract def hasRead(): Boolean

    .spark.connect.Read read = 2;

    .spark.connect.Read read = 2;

    returns

    Whether the read field is set.

  169. abstract def hasRepartition(): Boolean

    .spark.connect.Repartition repartition = 17;

    .spark.connect.Repartition repartition = 17;

    returns

    Whether the repartition field is set.

  170. abstract def hasRepartitionByExpression(): Boolean

    .spark.connect.RepartitionByExpression repartition_by_expression = 27;

    .spark.connect.RepartitionByExpression repartition_by_expression = 27;

    returns

    Whether the repartitionByExpression field is set.

  171. abstract def hasReplace(): Boolean

    .spark.connect.NAReplace replace = 92;

    .spark.connect.NAReplace replace = 92;

    returns

    Whether the replace field is set.

  172. abstract def hasSample(): Boolean

    .spark.connect.Sample sample = 12;

    .spark.connect.Sample sample = 12;

    returns

    Whether the sample field is set.

  173. abstract def hasSampleBy(): Boolean

    .spark.connect.StatSampleBy sample_by = 107;

    .spark.connect.StatSampleBy sample_by = 107;

    returns

    Whether the sampleBy field is set.

  174. abstract def hasSetOp(): Boolean

    .spark.connect.SetOperation set_op = 6;

    .spark.connect.SetOperation set_op = 6;

    returns

    Whether the setOp field is set.

  175. abstract def hasShowString(): Boolean

    .spark.connect.ShowString show_string = 20;

    .spark.connect.ShowString show_string = 20;

    returns

    Whether the showString field is set.

  176. abstract def hasSort(): Boolean

    .spark.connect.Sort sort = 7;

    .spark.connect.Sort sort = 7;

    returns

    Whether the sort field is set.

  177. abstract def hasSql(): Boolean

    .spark.connect.SQL sql = 10;

    .spark.connect.SQL sql = 10;

    returns

    Whether the sql field is set.

  178. abstract def hasSubqueryAlias(): Boolean

    .spark.connect.SubqueryAlias subquery_alias = 16;

    .spark.connect.SubqueryAlias subquery_alias = 16;

    returns

    Whether the subqueryAlias field is set.

  179. abstract def hasSummary(): Boolean

    stat functions
    

    stat functions
    

    .spark.connect.StatSummary summary = 100;

    returns

    Whether the summary field is set.

  180. abstract def hasTail(): Boolean

    .spark.connect.Tail tail = 22;

    .spark.connect.Tail tail = 22;

    returns

    Whether the tail field is set.

  181. abstract def hasToDf(): Boolean

    .spark.connect.ToDF to_df = 18;

    .spark.connect.ToDF to_df = 18;

    returns

    Whether the toDf field is set.

  182. abstract def hasToSchema(): Boolean

    .spark.connect.ToSchema to_schema = 26;

    .spark.connect.ToSchema to_schema = 26;

    returns

    Whether the toSchema field is set.

  183. abstract def hasTranspose(): Boolean

    .spark.connect.Transpose transpose = 42;

    .spark.connect.Transpose transpose = 42;

    returns

    Whether the transpose field is set.

  184. abstract def hasUnknown(): Boolean

    .spark.connect.Unknown unknown = 999;

    .spark.connect.Unknown unknown = 999;

    returns

    Whether the unknown field is set.

  185. abstract def hasUnpivot(): Boolean

    .spark.connect.Unpivot unpivot = 25;

    .spark.connect.Unpivot unpivot = 25;

    returns

    Whether the unpivot field is set.

  186. abstract def hasUnresolvedTableValuedFunction(): Boolean

    .spark.connect.UnresolvedTableValuedFunction unresolved_table_valued_function = 43;

    .spark.connect.UnresolvedTableValuedFunction unresolved_table_valued_function = 43;

    returns

    Whether the unresolvedTableValuedFunction field is set.

  187. abstract def hasWithColumns(): Boolean

    .spark.connect.WithColumns with_columns = 23;

    .spark.connect.WithColumns with_columns = 23;

    returns

    Whether the withColumns field is set.

  188. abstract def hasWithColumnsRenamed(): Boolean

    .spark.connect.WithColumnsRenamed with_columns_renamed = 19;

    .spark.connect.WithColumnsRenamed with_columns_renamed = 19;

    returns

    Whether the withColumnsRenamed field is set.

  189. abstract def hasWithRelations(): Boolean

    .spark.connect.WithRelations with_relations = 41;

    .spark.connect.WithRelations with_relations = 41;

    returns

    Whether the withRelations field is set.

  190. abstract def hasWithWatermark(): Boolean

    .spark.connect.WithWatermark with_watermark = 33;

    .spark.connect.WithWatermark with_watermark = 33;

    returns

    Whether the withWatermark field is set.

  191. abstract def isInitialized(): Boolean
    Definition Classes
    MessageLiteOrBuilder

Concrete Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##: Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  5. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @IntrinsicCandidate() @native()
  6. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  7. def equals(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef → Any
  8. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @IntrinsicCandidate() @native()
  9. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @IntrinsicCandidate() @native()
  10. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  11. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  12. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @IntrinsicCandidate() @native()
  13. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @IntrinsicCandidate() @native()
  14. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  15. def toString(): String
    Definition Classes
    AnyRef → Any
  16. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  17. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  18. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])

Deprecated Value Members

  1. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.Throwable]) @Deprecated
    Deprecated

    (Since version 9)

Inherited from MessageOrBuilder

Inherited from MessageLiteOrBuilder

Inherited from AnyRef

Inherited from Any

Ungrouped