Packages

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.

Protobuf type spark.connect.Relation

Linear Supertypes
RelationOrBuilder, GeneratedMessage, Serializable, AbstractMessage, Message, MessageOrBuilder, AbstractMessageLite[MessageType, BuilderType], MessageLite, MessageLiteOrBuilder, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. Relation
  2. RelationOrBuilder
  3. GeneratedMessage
  4. Serializable
  5. AbstractMessage
  6. Message
  7. MessageOrBuilder
  8. AbstractMessageLite
  9. MessageLite
  10. MessageLiteOrBuilder
  11. AnyRef
  12. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

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(obj: AnyRef): Boolean
    Definition Classes
    Relation → AbstractMessage → Message → AnyRef → Any
    Annotations
    @Override()
  8. def findInitializationErrors(): List[String]
    Definition Classes
    AbstractMessage → MessageOrBuilder
  9. def getAggregate(): Aggregate

    .spark.connect.Aggregate aggregate = 9;

    .spark.connect.Aggregate aggregate = 9;

    returns

    The aggregate.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  10. def getAggregateOrBuilder(): AggregateOrBuilder

    .spark.connect.Aggregate aggregate = 9;

    .spark.connect.Aggregate aggregate = 9;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  11. def getAllFields(): Map[FieldDescriptor, AnyRef]
    Definition Classes
    GeneratedMessage → MessageOrBuilder
  12. def getApplyInPandasWithState(): ApplyInPandasWithState

    .spark.connect.ApplyInPandasWithState apply_in_pandas_with_state = 34;

    .spark.connect.ApplyInPandasWithState apply_in_pandas_with_state = 34;

    returns

    The applyInPandasWithState.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  13. def getApplyInPandasWithStateOrBuilder(): ApplyInPandasWithStateOrBuilder

    .spark.connect.ApplyInPandasWithState apply_in_pandas_with_state = 34;

    .spark.connect.ApplyInPandasWithState apply_in_pandas_with_state = 34;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  14. def getApproxQuantile(): StatApproxQuantile

    .spark.connect.StatApproxQuantile approx_quantile = 105;

    .spark.connect.StatApproxQuantile approx_quantile = 105;

    returns

    The approxQuantile.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  15. def getApproxQuantileOrBuilder(): StatApproxQuantileOrBuilder

    .spark.connect.StatApproxQuantile approx_quantile = 105;

    .spark.connect.StatApproxQuantile approx_quantile = 105;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  16. def getAsOfJoin(): AsOfJoin

    .spark.connect.AsOfJoin as_of_join = 39;

    .spark.connect.AsOfJoin as_of_join = 39;

    returns

    The asOfJoin.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  17. def getAsOfJoinOrBuilder(): AsOfJoinOrBuilder

    .spark.connect.AsOfJoin as_of_join = 39;

    .spark.connect.AsOfJoin as_of_join = 39;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  18. def getCachedLocalRelation(): CachedLocalRelation

    .spark.connect.CachedLocalRelation cached_local_relation = 36;

    .spark.connect.CachedLocalRelation cached_local_relation = 36;

    returns

    The cachedLocalRelation.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  19. def getCachedLocalRelationOrBuilder(): CachedLocalRelationOrBuilder

    .spark.connect.CachedLocalRelation cached_local_relation = 36;

    .spark.connect.CachedLocalRelation cached_local_relation = 36;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  20. def getCachedRemoteRelation(): CachedRemoteRelation

    .spark.connect.CachedRemoteRelation cached_remote_relation = 37;

    .spark.connect.CachedRemoteRelation cached_remote_relation = 37;

    returns

    The cachedRemoteRelation.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  21. def getCachedRemoteRelationOrBuilder(): CachedRemoteRelationOrBuilder

    .spark.connect.CachedRemoteRelation cached_remote_relation = 37;

    .spark.connect.CachedRemoteRelation cached_remote_relation = 37;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  22. def getCatalog(): Catalog

    Catalog API (experimental / unstable)
    

    Catalog API (experimental / unstable)
    

    .spark.connect.Catalog catalog = 200;

    returns

    The catalog.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  23. def getCatalogOrBuilder(): CatalogOrBuilder

    Catalog API (experimental / unstable)
    

    Catalog API (experimental / unstable)
    

    .spark.connect.Catalog catalog = 200;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  24. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @IntrinsicCandidate() @native()
  25. def getCoGroupMap(): CoGroupMap

    .spark.connect.CoGroupMap co_group_map = 32;

    .spark.connect.CoGroupMap co_group_map = 32;

    returns

    The coGroupMap.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  26. def getCoGroupMapOrBuilder(): CoGroupMapOrBuilder

    .spark.connect.CoGroupMap co_group_map = 32;

    .spark.connect.CoGroupMap co_group_map = 32;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  27. def getCollectMetrics(): CollectMetrics

    .spark.connect.CollectMetrics collect_metrics = 29;

    .spark.connect.CollectMetrics collect_metrics = 29;

    returns

    The collectMetrics.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  28. def getCollectMetricsOrBuilder(): CollectMetricsOrBuilder

    .spark.connect.CollectMetrics collect_metrics = 29;

    .spark.connect.CollectMetrics collect_metrics = 29;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  29. def getCommon(): RelationCommon

    .spark.connect.RelationCommon common = 1;

    .spark.connect.RelationCommon common = 1;

    returns

    The common.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  30. 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.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  31. def getCommonInlineUserDefinedDataSourceOrBuilder(): CommonInlineUserDefinedDataSourceOrBuilder

    .spark.connect.CommonInlineUserDefinedDataSource common_inline_user_defined_data_source = 40;

    .spark.connect.CommonInlineUserDefinedDataSource common_inline_user_defined_data_source = 40;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  32. 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.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  33. def getCommonInlineUserDefinedTableFunctionOrBuilder(): CommonInlineUserDefinedTableFunctionOrBuilder

    .spark.connect.CommonInlineUserDefinedTableFunction common_inline_user_defined_table_function = 38;

    .spark.connect.CommonInlineUserDefinedTableFunction common_inline_user_defined_table_function = 38;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  34. def getCommonOrBuilder(): RelationCommonOrBuilder

    .spark.connect.RelationCommon common = 1;

    .spark.connect.RelationCommon common = 1;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  35. def getCorr(): StatCorr

    .spark.connect.StatCorr corr = 104;

    .spark.connect.StatCorr corr = 104;

    returns

    The corr.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  36. def getCorrOrBuilder(): StatCorrOrBuilder

    .spark.connect.StatCorr corr = 104;

    .spark.connect.StatCorr corr = 104;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  37. def getCov(): StatCov

    .spark.connect.StatCov cov = 103;

    .spark.connect.StatCov cov = 103;

    returns

    The cov.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  38. def getCovOrBuilder(): StatCovOrBuilder

    .spark.connect.StatCov cov = 103;

    .spark.connect.StatCov cov = 103;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  39. def getCrosstab(): StatCrosstab

    .spark.connect.StatCrosstab crosstab = 101;

    .spark.connect.StatCrosstab crosstab = 101;

    returns

    The crosstab.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  40. def getCrosstabOrBuilder(): StatCrosstabOrBuilder

    .spark.connect.StatCrosstab crosstab = 101;

    .spark.connect.StatCrosstab crosstab = 101;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  41. def getDeduplicate(): Deduplicate

    .spark.connect.Deduplicate deduplicate = 14;

    .spark.connect.Deduplicate deduplicate = 14;

    returns

    The deduplicate.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  42. def getDeduplicateOrBuilder(): DeduplicateOrBuilder

    .spark.connect.Deduplicate deduplicate = 14;

    .spark.connect.Deduplicate deduplicate = 14;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  43. def getDefaultInstanceForType(): Relation
    Definition Classes
    Relation → MessageOrBuilder → MessageLiteOrBuilder
    Annotations
    @Override()
  44. def getDescribe(): StatDescribe

    .spark.connect.StatDescribe describe = 102;

    .spark.connect.StatDescribe describe = 102;

    returns

    The describe.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  45. def getDescribeOrBuilder(): StatDescribeOrBuilder

    .spark.connect.StatDescribe describe = 102;

    .spark.connect.StatDescribe describe = 102;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  46. def getDescriptorForType(): Descriptor
    Definition Classes
    GeneratedMessage → MessageOrBuilder
  47. def getDrop(): Drop

    .spark.connect.Drop drop = 21;

    .spark.connect.Drop drop = 21;

    returns

    The drop.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  48. def getDropNa(): NADrop

    .spark.connect.NADrop drop_na = 91;

    .spark.connect.NADrop drop_na = 91;

    returns

    The dropNa.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  49. def getDropNaOrBuilder(): NADropOrBuilder

    .spark.connect.NADrop drop_na = 91;

    .spark.connect.NADrop drop_na = 91;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  50. def getDropOrBuilder(): DropOrBuilder

    .spark.connect.Drop drop = 21;

    .spark.connect.Drop drop = 21;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  51. 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.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  52. 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;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  53. def getField(field: FieldDescriptor): AnyRef
    Definition Classes
    GeneratedMessage → MessageOrBuilder
  54. def getFillNa(): NAFill

    NA functions
    

    NA functions
    

    .spark.connect.NAFill fill_na = 90;

    returns

    The fillNa.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  55. def getFillNaOrBuilder(): NAFillOrBuilder

    NA functions
    

    NA functions
    

    .spark.connect.NAFill fill_na = 90;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  56. def getFilter(): Filter

    .spark.connect.Filter filter = 4;

    .spark.connect.Filter filter = 4;

    returns

    The filter.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  57. def getFilterOrBuilder(): FilterOrBuilder

    .spark.connect.Filter filter = 4;

    .spark.connect.Filter filter = 4;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  58. def getFreqItems(): StatFreqItems

    .spark.connect.StatFreqItems freq_items = 106;

    .spark.connect.StatFreqItems freq_items = 106;

    returns

    The freqItems.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  59. def getFreqItemsOrBuilder(): StatFreqItemsOrBuilder

    .spark.connect.StatFreqItems freq_items = 106;

    .spark.connect.StatFreqItems freq_items = 106;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  60. def getGroupMap(): GroupMap

    .spark.connect.GroupMap group_map = 31;

    .spark.connect.GroupMap group_map = 31;

    returns

    The groupMap.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  61. def getGroupMapOrBuilder(): GroupMapOrBuilder

    .spark.connect.GroupMap group_map = 31;

    .spark.connect.GroupMap group_map = 31;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  62. def getHint(): Hint

    .spark.connect.Hint hint = 24;

    .spark.connect.Hint hint = 24;

    returns

    The hint.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  63. def getHintOrBuilder(): HintOrBuilder

    .spark.connect.Hint hint = 24;

    .spark.connect.Hint hint = 24;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  64. def getHtmlString(): HtmlString

    .spark.connect.HtmlString html_string = 35;

    .spark.connect.HtmlString html_string = 35;

    returns

    The htmlString.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  65. def getHtmlStringOrBuilder(): HtmlStringOrBuilder

    .spark.connect.HtmlString html_string = 35;

    .spark.connect.HtmlString html_string = 35;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  66. def getInitializationErrorString(): String
    Definition Classes
    AbstractMessage → MessageOrBuilder
  67. def getJoin(): Join

    .spark.connect.Join join = 5;

    .spark.connect.Join join = 5;

    returns

    The join.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  68. def getJoinOrBuilder(): JoinOrBuilder

    .spark.connect.Join join = 5;

    .spark.connect.Join join = 5;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  69. def getLateralJoin(): LateralJoin

    .spark.connect.LateralJoin lateral_join = 44;

    .spark.connect.LateralJoin lateral_join = 44;

    returns

    The lateralJoin.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  70. def getLateralJoinOrBuilder(): LateralJoinOrBuilder

    .spark.connect.LateralJoin lateral_join = 44;

    .spark.connect.LateralJoin lateral_join = 44;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  71. def getLimit(): Limit

    .spark.connect.Limit limit = 8;

    .spark.connect.Limit limit = 8;

    returns

    The limit.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  72. def getLimitOrBuilder(): LimitOrBuilder

    .spark.connect.Limit limit = 8;

    .spark.connect.Limit limit = 8;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  73. def getLocalRelation(): LocalRelation

    .spark.connect.LocalRelation local_relation = 11;

    .spark.connect.LocalRelation local_relation = 11;

    returns

    The localRelation.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  74. def getLocalRelationOrBuilder(): LocalRelationOrBuilder

    .spark.connect.LocalRelation local_relation = 11;

    .spark.connect.LocalRelation local_relation = 11;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  75. def getMapPartitions(): MapPartitions

    .spark.connect.MapPartitions map_partitions = 28;

    .spark.connect.MapPartitions map_partitions = 28;

    returns

    The mapPartitions.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  76. def getMapPartitionsOrBuilder(): MapPartitionsOrBuilder

    .spark.connect.MapPartitions map_partitions = 28;

    .spark.connect.MapPartitions map_partitions = 28;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  77. def getMlRelation(): MlRelation

    ML relation
    

    ML relation
    

    .spark.connect.MlRelation ml_relation = 300;

    returns

    The mlRelation.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  78. def getMlRelationOrBuilder(): MlRelationOrBuilder

    ML relation
    

    ML relation
    

    .spark.connect.MlRelation ml_relation = 300;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  79. def getOffset(): Offset

    .spark.connect.Offset offset = 13;

    .spark.connect.Offset offset = 13;

    returns

    The offset.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  80. def getOffsetOrBuilder(): OffsetOrBuilder

    .spark.connect.Offset offset = 13;

    .spark.connect.Offset offset = 13;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  81. def getOneofFieldDescriptor(oneof: OneofDescriptor): FieldDescriptor
    Definition Classes
    GeneratedMessage → AbstractMessage → MessageOrBuilder
  82. def getParse(): Parse

    .spark.connect.Parse parse = 30;

    .spark.connect.Parse parse = 30;

    returns

    The parse.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  83. def getParseOrBuilder(): ParseOrBuilder

    .spark.connect.Parse parse = 30;

    .spark.connect.Parse parse = 30;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  84. def getParserForType(): Parser[Relation]
    Definition Classes
    Relation → GeneratedMessage → Message → MessageLite
    Annotations
    @Override()
  85. def getProject(): Project

    .spark.connect.Project project = 3;

    .spark.connect.Project project = 3;

    returns

    The project.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  86. def getProjectOrBuilder(): ProjectOrBuilder

    .spark.connect.Project project = 3;

    .spark.connect.Project project = 3;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  87. def getRange(): Range

    .spark.connect.Range range = 15;

    .spark.connect.Range range = 15;

    returns

    The range.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  88. def getRangeOrBuilder(): RangeOrBuilder

    .spark.connect.Range range = 15;

    .spark.connect.Range range = 15;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  89. def getRead(): Read

    .spark.connect.Read read = 2;

    .spark.connect.Read read = 2;

    returns

    The read.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  90. def getReadOrBuilder(): ReadOrBuilder

    .spark.connect.Read read = 2;

    .spark.connect.Read read = 2;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  91. def getRelTypeCase(): RelTypeCase
    Definition Classes
    RelationRelationOrBuilder
  92. def getRepartition(): Repartition

    .spark.connect.Repartition repartition = 17;

    .spark.connect.Repartition repartition = 17;

    returns

    The repartition.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  93. def getRepartitionByExpression(): RepartitionByExpression

    .spark.connect.RepartitionByExpression repartition_by_expression = 27;

    .spark.connect.RepartitionByExpression repartition_by_expression = 27;

    returns

    The repartitionByExpression.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  94. def getRepartitionByExpressionOrBuilder(): RepartitionByExpressionOrBuilder

    .spark.connect.RepartitionByExpression repartition_by_expression = 27;

    .spark.connect.RepartitionByExpression repartition_by_expression = 27;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  95. def getRepartitionOrBuilder(): RepartitionOrBuilder

    .spark.connect.Repartition repartition = 17;

    .spark.connect.Repartition repartition = 17;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  96. def getRepeatedField(field: FieldDescriptor, index: Int): AnyRef
    Definition Classes
    GeneratedMessage → MessageOrBuilder
  97. def getRepeatedFieldCount(field: FieldDescriptor): Int
    Definition Classes
    GeneratedMessage → MessageOrBuilder
  98. def getReplace(): NAReplace

    .spark.connect.NAReplace replace = 92;

    .spark.connect.NAReplace replace = 92;

    returns

    The replace.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  99. def getReplaceOrBuilder(): NAReplaceOrBuilder

    .spark.connect.NAReplace replace = 92;

    .spark.connect.NAReplace replace = 92;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  100. def getSample(): Sample

    .spark.connect.Sample sample = 12;

    .spark.connect.Sample sample = 12;

    returns

    The sample.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  101. def getSampleBy(): StatSampleBy

    .spark.connect.StatSampleBy sample_by = 107;

    .spark.connect.StatSampleBy sample_by = 107;

    returns

    The sampleBy.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  102. def getSampleByOrBuilder(): StatSampleByOrBuilder

    .spark.connect.StatSampleBy sample_by = 107;

    .spark.connect.StatSampleBy sample_by = 107;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  103. def getSampleOrBuilder(): SampleOrBuilder

    .spark.connect.Sample sample = 12;

    .spark.connect.Sample sample = 12;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  104. def getSerializedSize(): Int
    Definition Classes
    Relation → GeneratedMessage → AbstractMessage → MessageLite
    Annotations
    @Override()
  105. def getSetOp(): SetOperation

    .spark.connect.SetOperation set_op = 6;

    .spark.connect.SetOperation set_op = 6;

    returns

    The setOp.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  106. def getSetOpOrBuilder(): SetOperationOrBuilder

    .spark.connect.SetOperation set_op = 6;

    .spark.connect.SetOperation set_op = 6;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  107. def getShowString(): ShowString

    .spark.connect.ShowString show_string = 20;

    .spark.connect.ShowString show_string = 20;

    returns

    The showString.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  108. def getShowStringOrBuilder(): ShowStringOrBuilder

    .spark.connect.ShowString show_string = 20;

    .spark.connect.ShowString show_string = 20;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  109. def getSort(): Sort

    .spark.connect.Sort sort = 7;

    .spark.connect.Sort sort = 7;

    returns

    The sort.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  110. def getSortOrBuilder(): SortOrBuilder

    .spark.connect.Sort sort = 7;

    .spark.connect.Sort sort = 7;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  111. def getSql(): SQL

    .spark.connect.SQL sql = 10;

    .spark.connect.SQL sql = 10;

    returns

    The sql.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  112. def getSqlOrBuilder(): SQLOrBuilder

    .spark.connect.SQL sql = 10;

    .spark.connect.SQL sql = 10;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  113. def getSubqueryAlias(): SubqueryAlias

    .spark.connect.SubqueryAlias subquery_alias = 16;

    .spark.connect.SubqueryAlias subquery_alias = 16;

    returns

    The subqueryAlias.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  114. def getSubqueryAliasOrBuilder(): SubqueryAliasOrBuilder

    .spark.connect.SubqueryAlias subquery_alias = 16;

    .spark.connect.SubqueryAlias subquery_alias = 16;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  115. def getSummary(): StatSummary

    stat functions
    

    stat functions
    

    .spark.connect.StatSummary summary = 100;

    returns

    The summary.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  116. def getSummaryOrBuilder(): StatSummaryOrBuilder

    stat functions
    

    stat functions
    

    .spark.connect.StatSummary summary = 100;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  117. def getTail(): Tail

    .spark.connect.Tail tail = 22;

    .spark.connect.Tail tail = 22;

    returns

    The tail.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  118. def getTailOrBuilder(): TailOrBuilder

    .spark.connect.Tail tail = 22;

    .spark.connect.Tail tail = 22;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  119. def getToDf(): ToDF

    .spark.connect.ToDF to_df = 18;

    .spark.connect.ToDF to_df = 18;

    returns

    The toDf.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  120. def getToDfOrBuilder(): ToDFOrBuilder

    .spark.connect.ToDF to_df = 18;

    .spark.connect.ToDF to_df = 18;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  121. def getToSchema(): ToSchema

    .spark.connect.ToSchema to_schema = 26;

    .spark.connect.ToSchema to_schema = 26;

    returns

    The toSchema.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  122. def getToSchemaOrBuilder(): ToSchemaOrBuilder

    .spark.connect.ToSchema to_schema = 26;

    .spark.connect.ToSchema to_schema = 26;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  123. def getTranspose(): Transpose

    .spark.connect.Transpose transpose = 42;

    .spark.connect.Transpose transpose = 42;

    returns

    The transpose.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  124. def getTransposeOrBuilder(): TransposeOrBuilder

    .spark.connect.Transpose transpose = 42;

    .spark.connect.Transpose transpose = 42;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  125. def getUnknown(): Unknown

    .spark.connect.Unknown unknown = 999;

    .spark.connect.Unknown unknown = 999;

    returns

    The unknown.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  126. def getUnknownFields(): UnknownFieldSet
    Definition Classes
    GeneratedMessage → MessageOrBuilder
  127. def getUnknownOrBuilder(): UnknownOrBuilder

    .spark.connect.Unknown unknown = 999;

    .spark.connect.Unknown unknown = 999;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  128. def getUnpivot(): Unpivot

    .spark.connect.Unpivot unpivot = 25;

    .spark.connect.Unpivot unpivot = 25;

    returns

    The unpivot.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  129. def getUnpivotOrBuilder(): UnpivotOrBuilder

    .spark.connect.Unpivot unpivot = 25;

    .spark.connect.Unpivot unpivot = 25;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  130. def getUnresolvedTableValuedFunction(): UnresolvedTableValuedFunction

    .spark.connect.UnresolvedTableValuedFunction unresolved_table_valued_function = 43;

    .spark.connect.UnresolvedTableValuedFunction unresolved_table_valued_function = 43;

    returns

    The unresolvedTableValuedFunction.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  131. def getUnresolvedTableValuedFunctionOrBuilder(): UnresolvedTableValuedFunctionOrBuilder

    .spark.connect.UnresolvedTableValuedFunction unresolved_table_valued_function = 43;

    .spark.connect.UnresolvedTableValuedFunction unresolved_table_valued_function = 43;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  132. def getWithColumns(): WithColumns

    .spark.connect.WithColumns with_columns = 23;

    .spark.connect.WithColumns with_columns = 23;

    returns

    The withColumns.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  133. def getWithColumnsOrBuilder(): WithColumnsOrBuilder

    .spark.connect.WithColumns with_columns = 23;

    .spark.connect.WithColumns with_columns = 23;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  134. def getWithColumnsRenamed(): WithColumnsRenamed

    .spark.connect.WithColumnsRenamed with_columns_renamed = 19;

    .spark.connect.WithColumnsRenamed with_columns_renamed = 19;

    returns

    The withColumnsRenamed.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  135. def getWithColumnsRenamedOrBuilder(): WithColumnsRenamedOrBuilder

    .spark.connect.WithColumnsRenamed with_columns_renamed = 19;

    .spark.connect.WithColumnsRenamed with_columns_renamed = 19;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  136. def getWithRelations(): WithRelations

    .spark.connect.WithRelations with_relations = 41;

    .spark.connect.WithRelations with_relations = 41;

    returns

    The withRelations.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  137. def getWithRelationsOrBuilder(): WithRelationsOrBuilder

    .spark.connect.WithRelations with_relations = 41;

    .spark.connect.WithRelations with_relations = 41;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  138. def getWithWatermark(): WithWatermark

    .spark.connect.WithWatermark with_watermark = 33;

    .spark.connect.WithWatermark with_watermark = 33;

    returns

    The withWatermark.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  139. def getWithWatermarkOrBuilder(): WithWatermarkOrBuilder

    .spark.connect.WithWatermark with_watermark = 33;

    .spark.connect.WithWatermark with_watermark = 33;

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  140. def hasAggregate(): Boolean

    .spark.connect.Aggregate aggregate = 9;

    .spark.connect.Aggregate aggregate = 9;

    returns

    Whether the aggregate field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  141. 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.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  142. def hasApproxQuantile(): Boolean

    .spark.connect.StatApproxQuantile approx_quantile = 105;

    .spark.connect.StatApproxQuantile approx_quantile = 105;

    returns

    Whether the approxQuantile field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  143. def hasAsOfJoin(): Boolean

    .spark.connect.AsOfJoin as_of_join = 39;

    .spark.connect.AsOfJoin as_of_join = 39;

    returns

    Whether the asOfJoin field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  144. def hasCachedLocalRelation(): Boolean

    .spark.connect.CachedLocalRelation cached_local_relation = 36;

    .spark.connect.CachedLocalRelation cached_local_relation = 36;

    returns

    Whether the cachedLocalRelation field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  145. def hasCachedRemoteRelation(): Boolean

    .spark.connect.CachedRemoteRelation cached_remote_relation = 37;

    .spark.connect.CachedRemoteRelation cached_remote_relation = 37;

    returns

    Whether the cachedRemoteRelation field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  146. def hasCatalog(): Boolean

    Catalog API (experimental / unstable)
    

    Catalog API (experimental / unstable)
    

    .spark.connect.Catalog catalog = 200;

    returns

    Whether the catalog field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  147. def hasCoGroupMap(): Boolean

    .spark.connect.CoGroupMap co_group_map = 32;

    .spark.connect.CoGroupMap co_group_map = 32;

    returns

    Whether the coGroupMap field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  148. def hasCollectMetrics(): Boolean

    .spark.connect.CollectMetrics collect_metrics = 29;

    .spark.connect.CollectMetrics collect_metrics = 29;

    returns

    Whether the collectMetrics field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  149. def hasCommon(): Boolean

    .spark.connect.RelationCommon common = 1;

    .spark.connect.RelationCommon common = 1;

    returns

    Whether the common field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  150. 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.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  151. 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.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  152. def hasCorr(): Boolean

    .spark.connect.StatCorr corr = 104;

    .spark.connect.StatCorr corr = 104;

    returns

    Whether the corr field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  153. def hasCov(): Boolean

    .spark.connect.StatCov cov = 103;

    .spark.connect.StatCov cov = 103;

    returns

    Whether the cov field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  154. def hasCrosstab(): Boolean

    .spark.connect.StatCrosstab crosstab = 101;

    .spark.connect.StatCrosstab crosstab = 101;

    returns

    Whether the crosstab field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  155. def hasDeduplicate(): Boolean

    .spark.connect.Deduplicate deduplicate = 14;

    .spark.connect.Deduplicate deduplicate = 14;

    returns

    Whether the deduplicate field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  156. def hasDescribe(): Boolean

    .spark.connect.StatDescribe describe = 102;

    .spark.connect.StatDescribe describe = 102;

    returns

    Whether the describe field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  157. def hasDrop(): Boolean

    .spark.connect.Drop drop = 21;

    .spark.connect.Drop drop = 21;

    returns

    Whether the drop field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  158. def hasDropNa(): Boolean

    .spark.connect.NADrop drop_na = 91;

    .spark.connect.NADrop drop_na = 91;

    returns

    Whether the dropNa field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  159. 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.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  160. def hasField(field: FieldDescriptor): Boolean
    Definition Classes
    GeneratedMessage → MessageOrBuilder
  161. def hasFillNa(): Boolean

    NA functions
    

    NA functions
    

    .spark.connect.NAFill fill_na = 90;

    returns

    Whether the fillNa field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  162. def hasFilter(): Boolean

    .spark.connect.Filter filter = 4;

    .spark.connect.Filter filter = 4;

    returns

    Whether the filter field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  163. def hasFreqItems(): Boolean

    .spark.connect.StatFreqItems freq_items = 106;

    .spark.connect.StatFreqItems freq_items = 106;

    returns

    Whether the freqItems field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  164. def hasGroupMap(): Boolean

    .spark.connect.GroupMap group_map = 31;

    .spark.connect.GroupMap group_map = 31;

    returns

    Whether the groupMap field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  165. def hasHint(): Boolean

    .spark.connect.Hint hint = 24;

    .spark.connect.Hint hint = 24;

    returns

    Whether the hint field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  166. def hasHtmlString(): Boolean

    .spark.connect.HtmlString html_string = 35;

    .spark.connect.HtmlString html_string = 35;

    returns

    Whether the htmlString field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  167. def hasJoin(): Boolean

    .spark.connect.Join join = 5;

    .spark.connect.Join join = 5;

    returns

    Whether the join field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  168. def hasLateralJoin(): Boolean

    .spark.connect.LateralJoin lateral_join = 44;

    .spark.connect.LateralJoin lateral_join = 44;

    returns

    Whether the lateralJoin field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  169. def hasLimit(): Boolean

    .spark.connect.Limit limit = 8;

    .spark.connect.Limit limit = 8;

    returns

    Whether the limit field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  170. def hasLocalRelation(): Boolean

    .spark.connect.LocalRelation local_relation = 11;

    .spark.connect.LocalRelation local_relation = 11;

    returns

    Whether the localRelation field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  171. def hasMapPartitions(): Boolean

    .spark.connect.MapPartitions map_partitions = 28;

    .spark.connect.MapPartitions map_partitions = 28;

    returns

    Whether the mapPartitions field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  172. def hasMlRelation(): Boolean

    ML relation
    

    ML relation
    

    .spark.connect.MlRelation ml_relation = 300;

    returns

    Whether the mlRelation field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  173. def hasOffset(): Boolean

    .spark.connect.Offset offset = 13;

    .spark.connect.Offset offset = 13;

    returns

    Whether the offset field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  174. def hasOneof(oneof: OneofDescriptor): Boolean
    Definition Classes
    GeneratedMessage → AbstractMessage → MessageOrBuilder
  175. def hasParse(): Boolean

    .spark.connect.Parse parse = 30;

    .spark.connect.Parse parse = 30;

    returns

    Whether the parse field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  176. def hasProject(): Boolean

    .spark.connect.Project project = 3;

    .spark.connect.Project project = 3;

    returns

    Whether the project field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  177. def hasRange(): Boolean

    .spark.connect.Range range = 15;

    .spark.connect.Range range = 15;

    returns

    Whether the range field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  178. def hasRead(): Boolean

    .spark.connect.Read read = 2;

    .spark.connect.Read read = 2;

    returns

    Whether the read field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  179. def hasRepartition(): Boolean

    .spark.connect.Repartition repartition = 17;

    .spark.connect.Repartition repartition = 17;

    returns

    Whether the repartition field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  180. def hasRepartitionByExpression(): Boolean

    .spark.connect.RepartitionByExpression repartition_by_expression = 27;

    .spark.connect.RepartitionByExpression repartition_by_expression = 27;

    returns

    Whether the repartitionByExpression field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  181. def hasReplace(): Boolean

    .spark.connect.NAReplace replace = 92;

    .spark.connect.NAReplace replace = 92;

    returns

    Whether the replace field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  182. def hasSample(): Boolean

    .spark.connect.Sample sample = 12;

    .spark.connect.Sample sample = 12;

    returns

    Whether the sample field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  183. def hasSampleBy(): Boolean

    .spark.connect.StatSampleBy sample_by = 107;

    .spark.connect.StatSampleBy sample_by = 107;

    returns

    Whether the sampleBy field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  184. def hasSetOp(): Boolean

    .spark.connect.SetOperation set_op = 6;

    .spark.connect.SetOperation set_op = 6;

    returns

    Whether the setOp field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  185. def hasShowString(): Boolean

    .spark.connect.ShowString show_string = 20;

    .spark.connect.ShowString show_string = 20;

    returns

    Whether the showString field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  186. def hasSort(): Boolean

    .spark.connect.Sort sort = 7;

    .spark.connect.Sort sort = 7;

    returns

    Whether the sort field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  187. def hasSql(): Boolean

    .spark.connect.SQL sql = 10;

    .spark.connect.SQL sql = 10;

    returns

    Whether the sql field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  188. def hasSubqueryAlias(): Boolean

    .spark.connect.SubqueryAlias subquery_alias = 16;

    .spark.connect.SubqueryAlias subquery_alias = 16;

    returns

    Whether the subqueryAlias field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  189. def hasSummary(): Boolean

    stat functions
    

    stat functions
    

    .spark.connect.StatSummary summary = 100;

    returns

    Whether the summary field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  190. def hasTail(): Boolean

    .spark.connect.Tail tail = 22;

    .spark.connect.Tail tail = 22;

    returns

    Whether the tail field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  191. def hasToDf(): Boolean

    .spark.connect.ToDF to_df = 18;

    .spark.connect.ToDF to_df = 18;

    returns

    Whether the toDf field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  192. def hasToSchema(): Boolean

    .spark.connect.ToSchema to_schema = 26;

    .spark.connect.ToSchema to_schema = 26;

    returns

    Whether the toSchema field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  193. def hasTranspose(): Boolean

    .spark.connect.Transpose transpose = 42;

    .spark.connect.Transpose transpose = 42;

    returns

    Whether the transpose field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  194. def hasUnknown(): Boolean

    .spark.connect.Unknown unknown = 999;

    .spark.connect.Unknown unknown = 999;

    returns

    Whether the unknown field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  195. def hasUnpivot(): Boolean

    .spark.connect.Unpivot unpivot = 25;

    .spark.connect.Unpivot unpivot = 25;

    returns

    Whether the unpivot field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  196. 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.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  197. def hasWithColumns(): Boolean

    .spark.connect.WithColumns with_columns = 23;

    .spark.connect.WithColumns with_columns = 23;

    returns

    Whether the withColumns field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  198. def hasWithColumnsRenamed(): Boolean

    .spark.connect.WithColumnsRenamed with_columns_renamed = 19;

    .spark.connect.WithColumnsRenamed with_columns_renamed = 19;

    returns

    Whether the withColumnsRenamed field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  199. def hasWithRelations(): Boolean

    .spark.connect.WithRelations with_relations = 41;

    .spark.connect.WithRelations with_relations = 41;

    returns

    Whether the withRelations field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  200. def hasWithWatermark(): Boolean

    .spark.connect.WithWatermark with_watermark = 33;

    .spark.connect.WithWatermark with_watermark = 33;

    returns

    Whether the withWatermark field is set.

    Definition Classes
    RelationRelationOrBuilder
    Annotations
    @Override()
  201. def hashCode(): Int
    Definition Classes
    Relation → AbstractMessage → Message → AnyRef → Any
    Annotations
    @Override()
  202. def internalGetFieldAccessorTable(): FieldAccessorTable
    Attributes
    protected[proto]
    Definition Classes
    Relation → GeneratedMessage
    Annotations
    @Override()
  203. def internalGetMapFieldReflection(fieldNumber: Int): MapFieldReflectionAccessor
    Attributes
    protected[protobuf]
    Definition Classes
    GeneratedMessage
  204. final def isInitialized(): Boolean
    Definition Classes
    Relation → GeneratedMessage → AbstractMessage → MessageLiteOrBuilder
    Annotations
    @Override()
  205. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  206. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  207. def newBuilderForType(parent: BuilderParent): Builder
    Attributes
    protected[proto]
    Definition Classes
    Relation → AbstractMessage
    Annotations
    @Override()
  208. def newBuilderForType(): Builder
    Definition Classes
    Relation → Message → MessageLite
    Annotations
    @Override()
  209. def newInstance(unused: UnusedPrivateParameter): AnyRef
    Attributes
    protected[protobuf]
    Definition Classes
    GeneratedMessage
  210. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @IntrinsicCandidate() @native()
  211. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @IntrinsicCandidate() @native()
  212. def parseUnknownField(input: CodedInputStream, unknownFields: Builder, extensionRegistry: ExtensionRegistryLite, tag: Int): Boolean
    Attributes
    protected[protobuf]
    Definition Classes
    GeneratedMessage
    Annotations
    @throws(classOf[java.io.IOException])
  213. def parseUnknownFieldProto3(input: CodedInputStream, unknownFields: Builder, extensionRegistry: ExtensionRegistryLite, tag: Int): Boolean
    Attributes
    protected[protobuf]
    Definition Classes
    GeneratedMessage
    Annotations
    @throws(classOf[java.io.IOException])
  214. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  215. def toBuilder(): Builder
    Definition Classes
    Relation → Message → MessageLite
    Annotations
    @Override()
  216. def toByteArray(): Array[Byte]
    Definition Classes
    AbstractMessageLite → MessageLite
  217. def toByteString(): ByteString
    Definition Classes
    AbstractMessageLite → MessageLite
  218. final def toString(): String
    Definition Classes
    AbstractMessage → Message → AnyRef → Any
  219. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  220. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  221. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  222. def writeDelimitedTo(output: OutputStream): Unit
    Definition Classes
    AbstractMessageLite → MessageLite
    Annotations
    @throws(classOf[java.io.IOException])
  223. def writeReplace(): AnyRef
    Attributes
    protected[protobuf]
    Definition Classes
    GeneratedMessage
    Annotations
    @throws(classOf[java.io.ObjectStreamException])
  224. def writeTo(output: CodedOutputStream): Unit
    Definition Classes
    Relation → GeneratedMessage → AbstractMessage → MessageLite
    Annotations
    @Override()
  225. def writeTo(output: OutputStream): Unit
    Definition Classes
    AbstractMessageLite → MessageLite
    Annotations
    @throws(classOf[java.io.IOException])

Deprecated Value Members

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

    (Since version 9)

  2. def internalGetMapField(fieldNumber: Int): MapField[_ <: AnyRef, _ <: AnyRef]
    Attributes
    protected[protobuf]
    Definition Classes
    GeneratedMessage
    Annotations
    @Deprecated
    Deprecated
  3. def mergeFromAndMakeImmutableInternal(input: CodedInputStream, extensionRegistry: ExtensionRegistryLite): Unit
    Attributes
    protected[protobuf]
    Definition Classes
    GeneratedMessage
    Annotations
    @throws(classOf[com.google.protobuf.InvalidProtocolBufferException]) @Deprecated
    Deprecated

Inherited from RelationOrBuilder

Inherited from GeneratedMessage

Inherited from Serializable

Inherited from AbstractMessage

Inherited from Message

Inherited from MessageOrBuilder

Inherited from AbstractMessageLite[MessageType, BuilderType]

Inherited from MessageLite

Inherited from MessageLiteOrBuilder

Inherited from AnyRef

Inherited from Any

Ungrouped