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
- Alphabetic
- By Inheritance
- Relation
- RelationOrBuilder
- GeneratedMessage
- Serializable
- AbstractMessage
- Message
- MessageOrBuilder
- AbstractMessageLite
- MessageLite
- MessageLiteOrBuilder
- AnyRef
- Any
- Hide All
- Show All
- Public
- Protected
Value Members
- final def !=(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- final def ##: Int
- Definition Classes
- AnyRef → Any
- final def ==(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- final def asInstanceOf[T0]: T0
- Definition Classes
- Any
- def clone(): AnyRef
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.CloneNotSupportedException]) @IntrinsicCandidate() @native()
- final def eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- def equals(obj: AnyRef): Boolean
- Definition Classes
- Relation → AbstractMessage → Message → AnyRef → Any
- Annotations
- @Override()
- def findInitializationErrors(): List[String]
- Definition Classes
- AbstractMessage → MessageOrBuilder
- def getAggregate(): Aggregate
.spark.connect.Aggregate aggregate = 9;
.spark.connect.Aggregate aggregate = 9;
- returns
The aggregate.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getAggregateOrBuilder(): AggregateOrBuilder
.spark.connect.Aggregate aggregate = 9;
.spark.connect.Aggregate aggregate = 9;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getAllFields(): Map[FieldDescriptor, AnyRef]
- Definition Classes
- GeneratedMessage → MessageOrBuilder
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getApplyInPandasWithStateOrBuilder(): ApplyInPandasWithStateOrBuilder
.spark.connect.ApplyInPandasWithState apply_in_pandas_with_state = 34;
.spark.connect.ApplyInPandasWithState apply_in_pandas_with_state = 34;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getApproxQuantile(): StatApproxQuantile
.spark.connect.StatApproxQuantile approx_quantile = 105;
.spark.connect.StatApproxQuantile approx_quantile = 105;
- returns
The approxQuantile.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getApproxQuantileOrBuilder(): StatApproxQuantileOrBuilder
.spark.connect.StatApproxQuantile approx_quantile = 105;
.spark.connect.StatApproxQuantile approx_quantile = 105;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getAsOfJoin(): AsOfJoin
.spark.connect.AsOfJoin as_of_join = 39;
.spark.connect.AsOfJoin as_of_join = 39;
- returns
The asOfJoin.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getAsOfJoinOrBuilder(): AsOfJoinOrBuilder
.spark.connect.AsOfJoin as_of_join = 39;
.spark.connect.AsOfJoin as_of_join = 39;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getCachedLocalRelation(): CachedLocalRelation
.spark.connect.CachedLocalRelation cached_local_relation = 36;
.spark.connect.CachedLocalRelation cached_local_relation = 36;
- returns
The cachedLocalRelation.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getCachedLocalRelationOrBuilder(): CachedLocalRelationOrBuilder
.spark.connect.CachedLocalRelation cached_local_relation = 36;
.spark.connect.CachedLocalRelation cached_local_relation = 36;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getCachedRemoteRelation(): CachedRemoteRelation
.spark.connect.CachedRemoteRelation cached_remote_relation = 37;
.spark.connect.CachedRemoteRelation cached_remote_relation = 37;
- returns
The cachedRemoteRelation.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getCachedRemoteRelationOrBuilder(): CachedRemoteRelationOrBuilder
.spark.connect.CachedRemoteRelation cached_remote_relation = 37;
.spark.connect.CachedRemoteRelation cached_remote_relation = 37;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getCatalog(): Catalog
Catalog API (experimental / unstable)
Catalog API (experimental / unstable)
.spark.connect.Catalog catalog = 200;
- returns
The catalog.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getCatalogOrBuilder(): CatalogOrBuilder
Catalog API (experimental / unstable)
Catalog API (experimental / unstable)
.spark.connect.Catalog catalog = 200;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- final def getClass(): Class[_ <: AnyRef]
- Definition Classes
- AnyRef → Any
- Annotations
- @IntrinsicCandidate() @native()
- def getCoGroupMap(): CoGroupMap
.spark.connect.CoGroupMap co_group_map = 32;
.spark.connect.CoGroupMap co_group_map = 32;
- returns
The coGroupMap.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getCoGroupMapOrBuilder(): CoGroupMapOrBuilder
.spark.connect.CoGroupMap co_group_map = 32;
.spark.connect.CoGroupMap co_group_map = 32;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getCollectMetrics(): CollectMetrics
.spark.connect.CollectMetrics collect_metrics = 29;
.spark.connect.CollectMetrics collect_metrics = 29;
- returns
The collectMetrics.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getCollectMetricsOrBuilder(): CollectMetricsOrBuilder
.spark.connect.CollectMetrics collect_metrics = 29;
.spark.connect.CollectMetrics collect_metrics = 29;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getCommon(): RelationCommon
.spark.connect.RelationCommon common = 1;
.spark.connect.RelationCommon common = 1;
- returns
The common.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getCommonOrBuilder(): RelationCommonOrBuilder
.spark.connect.RelationCommon common = 1;
.spark.connect.RelationCommon common = 1;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getCorr(): StatCorr
.spark.connect.StatCorr corr = 104;
.spark.connect.StatCorr corr = 104;
- returns
The corr.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getCorrOrBuilder(): StatCorrOrBuilder
.spark.connect.StatCorr corr = 104;
.spark.connect.StatCorr corr = 104;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getCov(): StatCov
.spark.connect.StatCov cov = 103;
.spark.connect.StatCov cov = 103;
- returns
The cov.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getCovOrBuilder(): StatCovOrBuilder
.spark.connect.StatCov cov = 103;
.spark.connect.StatCov cov = 103;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getCrosstab(): StatCrosstab
.spark.connect.StatCrosstab crosstab = 101;
.spark.connect.StatCrosstab crosstab = 101;
- returns
The crosstab.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getCrosstabOrBuilder(): StatCrosstabOrBuilder
.spark.connect.StatCrosstab crosstab = 101;
.spark.connect.StatCrosstab crosstab = 101;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getDeduplicate(): Deduplicate
.spark.connect.Deduplicate deduplicate = 14;
.spark.connect.Deduplicate deduplicate = 14;
- returns
The deduplicate.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getDeduplicateOrBuilder(): DeduplicateOrBuilder
.spark.connect.Deduplicate deduplicate = 14;
.spark.connect.Deduplicate deduplicate = 14;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getDefaultInstanceForType(): Relation
- Definition Classes
- Relation → MessageOrBuilder → MessageLiteOrBuilder
- Annotations
- @Override()
- def getDescribe(): StatDescribe
.spark.connect.StatDescribe describe = 102;
.spark.connect.StatDescribe describe = 102;
- returns
The describe.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getDescribeOrBuilder(): StatDescribeOrBuilder
.spark.connect.StatDescribe describe = 102;
.spark.connect.StatDescribe describe = 102;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getDescriptorForType(): Descriptor
- Definition Classes
- GeneratedMessage → MessageOrBuilder
- def getDrop(): Drop
.spark.connect.Drop drop = 21;
.spark.connect.Drop drop = 21;
- returns
The drop.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getDropNa(): NADrop
.spark.connect.NADrop drop_na = 91;
.spark.connect.NADrop drop_na = 91;
- returns
The dropNa.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getDropNaOrBuilder(): NADropOrBuilder
.spark.connect.NADrop drop_na = 91;
.spark.connect.NADrop drop_na = 91;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getDropOrBuilder(): DropOrBuilder
.spark.connect.Drop drop = 21;
.spark.connect.Drop drop = 21;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getField(field: FieldDescriptor): AnyRef
- Definition Classes
- GeneratedMessage → MessageOrBuilder
- def getFillNa(): NAFill
NA functions
NA functions
.spark.connect.NAFill fill_na = 90;
- returns
The fillNa.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getFillNaOrBuilder(): NAFillOrBuilder
NA functions
NA functions
.spark.connect.NAFill fill_na = 90;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getFilter(): Filter
.spark.connect.Filter filter = 4;
.spark.connect.Filter filter = 4;
- returns
The filter.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getFilterOrBuilder(): FilterOrBuilder
.spark.connect.Filter filter = 4;
.spark.connect.Filter filter = 4;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getFreqItems(): StatFreqItems
.spark.connect.StatFreqItems freq_items = 106;
.spark.connect.StatFreqItems freq_items = 106;
- returns
The freqItems.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getFreqItemsOrBuilder(): StatFreqItemsOrBuilder
.spark.connect.StatFreqItems freq_items = 106;
.spark.connect.StatFreqItems freq_items = 106;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getGroupMap(): GroupMap
.spark.connect.GroupMap group_map = 31;
.spark.connect.GroupMap group_map = 31;
- returns
The groupMap.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getGroupMapOrBuilder(): GroupMapOrBuilder
.spark.connect.GroupMap group_map = 31;
.spark.connect.GroupMap group_map = 31;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getHint(): Hint
.spark.connect.Hint hint = 24;
.spark.connect.Hint hint = 24;
- returns
The hint.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getHintOrBuilder(): HintOrBuilder
.spark.connect.Hint hint = 24;
.spark.connect.Hint hint = 24;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getHtmlString(): HtmlString
.spark.connect.HtmlString html_string = 35;
.spark.connect.HtmlString html_string = 35;
- returns
The htmlString.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getHtmlStringOrBuilder(): HtmlStringOrBuilder
.spark.connect.HtmlString html_string = 35;
.spark.connect.HtmlString html_string = 35;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getInitializationErrorString(): String
- Definition Classes
- AbstractMessage → MessageOrBuilder
- def getJoin(): Join
.spark.connect.Join join = 5;
.spark.connect.Join join = 5;
- returns
The join.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getJoinOrBuilder(): JoinOrBuilder
.spark.connect.Join join = 5;
.spark.connect.Join join = 5;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getLateralJoin(): LateralJoin
.spark.connect.LateralJoin lateral_join = 44;
.spark.connect.LateralJoin lateral_join = 44;
- returns
The lateralJoin.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getLateralJoinOrBuilder(): LateralJoinOrBuilder
.spark.connect.LateralJoin lateral_join = 44;
.spark.connect.LateralJoin lateral_join = 44;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getLimit(): Limit
.spark.connect.Limit limit = 8;
.spark.connect.Limit limit = 8;
- returns
The limit.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getLimitOrBuilder(): LimitOrBuilder
.spark.connect.Limit limit = 8;
.spark.connect.Limit limit = 8;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getLocalRelation(): LocalRelation
.spark.connect.LocalRelation local_relation = 11;
.spark.connect.LocalRelation local_relation = 11;
- returns
The localRelation.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getLocalRelationOrBuilder(): LocalRelationOrBuilder
.spark.connect.LocalRelation local_relation = 11;
.spark.connect.LocalRelation local_relation = 11;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getMapPartitions(): MapPartitions
.spark.connect.MapPartitions map_partitions = 28;
.spark.connect.MapPartitions map_partitions = 28;
- returns
The mapPartitions.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getMapPartitionsOrBuilder(): MapPartitionsOrBuilder
.spark.connect.MapPartitions map_partitions = 28;
.spark.connect.MapPartitions map_partitions = 28;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getMlRelation(): MlRelation
ML relation
ML relation
.spark.connect.MlRelation ml_relation = 300;
- returns
The mlRelation.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getMlRelationOrBuilder(): MlRelationOrBuilder
ML relation
ML relation
.spark.connect.MlRelation ml_relation = 300;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getOffset(): Offset
.spark.connect.Offset offset = 13;
.spark.connect.Offset offset = 13;
- returns
The offset.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getOffsetOrBuilder(): OffsetOrBuilder
.spark.connect.Offset offset = 13;
.spark.connect.Offset offset = 13;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getOneofFieldDescriptor(oneof: OneofDescriptor): FieldDescriptor
- Definition Classes
- GeneratedMessage → AbstractMessage → MessageOrBuilder
- def getParse(): Parse
.spark.connect.Parse parse = 30;
.spark.connect.Parse parse = 30;
- returns
The parse.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getParseOrBuilder(): ParseOrBuilder
.spark.connect.Parse parse = 30;
.spark.connect.Parse parse = 30;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getParserForType(): Parser[Relation]
- Definition Classes
- Relation → GeneratedMessage → Message → MessageLite
- Annotations
- @Override()
- def getProject(): Project
.spark.connect.Project project = 3;
.spark.connect.Project project = 3;
- returns
The project.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getProjectOrBuilder(): ProjectOrBuilder
.spark.connect.Project project = 3;
.spark.connect.Project project = 3;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getRange(): Range
.spark.connect.Range range = 15;
.spark.connect.Range range = 15;
- returns
The range.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getRangeOrBuilder(): RangeOrBuilder
.spark.connect.Range range = 15;
.spark.connect.Range range = 15;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getRead(): Read
.spark.connect.Read read = 2;
.spark.connect.Read read = 2;
- returns
The read.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getReadOrBuilder(): ReadOrBuilder
.spark.connect.Read read = 2;
.spark.connect.Read read = 2;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getRelTypeCase(): RelTypeCase
- Definition Classes
- Relation → RelationOrBuilder
- def getRepartition(): Repartition
.spark.connect.Repartition repartition = 17;
.spark.connect.Repartition repartition = 17;
- returns
The repartition.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getRepartitionByExpression(): RepartitionByExpression
.spark.connect.RepartitionByExpression repartition_by_expression = 27;
.spark.connect.RepartitionByExpression repartition_by_expression = 27;
- returns
The repartitionByExpression.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getRepartitionByExpressionOrBuilder(): RepartitionByExpressionOrBuilder
.spark.connect.RepartitionByExpression repartition_by_expression = 27;
.spark.connect.RepartitionByExpression repartition_by_expression = 27;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getRepartitionOrBuilder(): RepartitionOrBuilder
.spark.connect.Repartition repartition = 17;
.spark.connect.Repartition repartition = 17;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getRepeatedField(field: FieldDescriptor, index: Int): AnyRef
- Definition Classes
- GeneratedMessage → MessageOrBuilder
- def getRepeatedFieldCount(field: FieldDescriptor): Int
- Definition Classes
- GeneratedMessage → MessageOrBuilder
- def getReplace(): NAReplace
.spark.connect.NAReplace replace = 92;
.spark.connect.NAReplace replace = 92;
- returns
The replace.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getReplaceOrBuilder(): NAReplaceOrBuilder
.spark.connect.NAReplace replace = 92;
.spark.connect.NAReplace replace = 92;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getSample(): Sample
.spark.connect.Sample sample = 12;
.spark.connect.Sample sample = 12;
- returns
The sample.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getSampleBy(): StatSampleBy
.spark.connect.StatSampleBy sample_by = 107;
.spark.connect.StatSampleBy sample_by = 107;
- returns
The sampleBy.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getSampleByOrBuilder(): StatSampleByOrBuilder
.spark.connect.StatSampleBy sample_by = 107;
.spark.connect.StatSampleBy sample_by = 107;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getSampleOrBuilder(): SampleOrBuilder
.spark.connect.Sample sample = 12;
.spark.connect.Sample sample = 12;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getSerializedSize(): Int
- Definition Classes
- Relation → GeneratedMessage → AbstractMessage → MessageLite
- Annotations
- @Override()
- def getSetOp(): SetOperation
.spark.connect.SetOperation set_op = 6;
.spark.connect.SetOperation set_op = 6;
- returns
The setOp.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getSetOpOrBuilder(): SetOperationOrBuilder
.spark.connect.SetOperation set_op = 6;
.spark.connect.SetOperation set_op = 6;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getShowString(): ShowString
.spark.connect.ShowString show_string = 20;
.spark.connect.ShowString show_string = 20;
- returns
The showString.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getShowStringOrBuilder(): ShowStringOrBuilder
.spark.connect.ShowString show_string = 20;
.spark.connect.ShowString show_string = 20;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getSort(): Sort
.spark.connect.Sort sort = 7;
.spark.connect.Sort sort = 7;
- returns
The sort.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getSortOrBuilder(): SortOrBuilder
.spark.connect.Sort sort = 7;
.spark.connect.Sort sort = 7;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getSql(): SQL
.spark.connect.SQL sql = 10;
.spark.connect.SQL sql = 10;
- returns
The sql.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getSqlOrBuilder(): SQLOrBuilder
.spark.connect.SQL sql = 10;
.spark.connect.SQL sql = 10;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getSubqueryAlias(): SubqueryAlias
.spark.connect.SubqueryAlias subquery_alias = 16;
.spark.connect.SubqueryAlias subquery_alias = 16;
- returns
The subqueryAlias.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getSubqueryAliasOrBuilder(): SubqueryAliasOrBuilder
.spark.connect.SubqueryAlias subquery_alias = 16;
.spark.connect.SubqueryAlias subquery_alias = 16;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getSummary(): StatSummary
stat functions
stat functions
.spark.connect.StatSummary summary = 100;
- returns
The summary.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getSummaryOrBuilder(): StatSummaryOrBuilder
stat functions
stat functions
.spark.connect.StatSummary summary = 100;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getTail(): Tail
.spark.connect.Tail tail = 22;
.spark.connect.Tail tail = 22;
- returns
The tail.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getTailOrBuilder(): TailOrBuilder
.spark.connect.Tail tail = 22;
.spark.connect.Tail tail = 22;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getToDf(): ToDF
.spark.connect.ToDF to_df = 18;
.spark.connect.ToDF to_df = 18;
- returns
The toDf.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getToDfOrBuilder(): ToDFOrBuilder
.spark.connect.ToDF to_df = 18;
.spark.connect.ToDF to_df = 18;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getToSchema(): ToSchema
.spark.connect.ToSchema to_schema = 26;
.spark.connect.ToSchema to_schema = 26;
- returns
The toSchema.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getToSchemaOrBuilder(): ToSchemaOrBuilder
.spark.connect.ToSchema to_schema = 26;
.spark.connect.ToSchema to_schema = 26;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getTranspose(): Transpose
.spark.connect.Transpose transpose = 42;
.spark.connect.Transpose transpose = 42;
- returns
The transpose.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getTransposeOrBuilder(): TransposeOrBuilder
.spark.connect.Transpose transpose = 42;
.spark.connect.Transpose transpose = 42;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getUnknown(): Unknown
.spark.connect.Unknown unknown = 999;
.spark.connect.Unknown unknown = 999;
- returns
The unknown.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getUnknownFields(): UnknownFieldSet
- Definition Classes
- GeneratedMessage → MessageOrBuilder
- def getUnknownOrBuilder(): UnknownOrBuilder
.spark.connect.Unknown unknown = 999;
.spark.connect.Unknown unknown = 999;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getUnpivot(): Unpivot
.spark.connect.Unpivot unpivot = 25;
.spark.connect.Unpivot unpivot = 25;
- returns
The unpivot.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getUnpivotOrBuilder(): UnpivotOrBuilder
.spark.connect.Unpivot unpivot = 25;
.spark.connect.Unpivot unpivot = 25;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getUnresolvedTableValuedFunction(): UnresolvedTableValuedFunction
.spark.connect.UnresolvedTableValuedFunction unresolved_table_valued_function = 43;
.spark.connect.UnresolvedTableValuedFunction unresolved_table_valued_function = 43;
- returns
The unresolvedTableValuedFunction.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getUnresolvedTableValuedFunctionOrBuilder(): UnresolvedTableValuedFunctionOrBuilder
.spark.connect.UnresolvedTableValuedFunction unresolved_table_valued_function = 43;
.spark.connect.UnresolvedTableValuedFunction unresolved_table_valued_function = 43;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getWithColumns(): WithColumns
.spark.connect.WithColumns with_columns = 23;
.spark.connect.WithColumns with_columns = 23;
- returns
The withColumns.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getWithColumnsOrBuilder(): WithColumnsOrBuilder
.spark.connect.WithColumns with_columns = 23;
.spark.connect.WithColumns with_columns = 23;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getWithColumnsRenamed(): WithColumnsRenamed
.spark.connect.WithColumnsRenamed with_columns_renamed = 19;
.spark.connect.WithColumnsRenamed with_columns_renamed = 19;
- returns
The withColumnsRenamed.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getWithColumnsRenamedOrBuilder(): WithColumnsRenamedOrBuilder
.spark.connect.WithColumnsRenamed with_columns_renamed = 19;
.spark.connect.WithColumnsRenamed with_columns_renamed = 19;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getWithRelations(): WithRelations
.spark.connect.WithRelations with_relations = 41;
.spark.connect.WithRelations with_relations = 41;
- returns
The withRelations.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getWithRelationsOrBuilder(): WithRelationsOrBuilder
.spark.connect.WithRelations with_relations = 41;
.spark.connect.WithRelations with_relations = 41;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getWithWatermark(): WithWatermark
.spark.connect.WithWatermark with_watermark = 33;
.spark.connect.WithWatermark with_watermark = 33;
- returns
The withWatermark.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def getWithWatermarkOrBuilder(): WithWatermarkOrBuilder
.spark.connect.WithWatermark with_watermark = 33;
.spark.connect.WithWatermark with_watermark = 33;
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasAggregate(): Boolean
.spark.connect.Aggregate aggregate = 9;
.spark.connect.Aggregate aggregate = 9;
- returns
Whether the aggregate field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasApproxQuantile(): Boolean
.spark.connect.StatApproxQuantile approx_quantile = 105;
.spark.connect.StatApproxQuantile approx_quantile = 105;
- returns
Whether the approxQuantile field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasCollectMetrics(): Boolean
.spark.connect.CollectMetrics collect_metrics = 29;
.spark.connect.CollectMetrics collect_metrics = 29;
- returns
Whether the collectMetrics field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasCommon(): Boolean
.spark.connect.RelationCommon common = 1;
.spark.connect.RelationCommon common = 1;
- returns
Whether the common field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasCorr(): Boolean
.spark.connect.StatCorr corr = 104;
.spark.connect.StatCorr corr = 104;
- returns
Whether the corr field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasCov(): Boolean
.spark.connect.StatCov cov = 103;
.spark.connect.StatCov cov = 103;
- returns
Whether the cov field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasCrosstab(): Boolean
.spark.connect.StatCrosstab crosstab = 101;
.spark.connect.StatCrosstab crosstab = 101;
- returns
Whether the crosstab field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasDeduplicate(): Boolean
.spark.connect.Deduplicate deduplicate = 14;
.spark.connect.Deduplicate deduplicate = 14;
- returns
Whether the deduplicate field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasDescribe(): Boolean
.spark.connect.StatDescribe describe = 102;
.spark.connect.StatDescribe describe = 102;
- returns
Whether the describe field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasDrop(): Boolean
.spark.connect.Drop drop = 21;
.spark.connect.Drop drop = 21;
- returns
Whether the drop field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasDropNa(): Boolean
.spark.connect.NADrop drop_na = 91;
.spark.connect.NADrop drop_na = 91;
- returns
Whether the dropNa field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasField(field: FieldDescriptor): Boolean
- Definition Classes
- GeneratedMessage → MessageOrBuilder
- def hasFillNa(): Boolean
NA functions
NA functions
.spark.connect.NAFill fill_na = 90;
- returns
Whether the fillNa field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasFilter(): Boolean
.spark.connect.Filter filter = 4;
.spark.connect.Filter filter = 4;
- returns
Whether the filter field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasFreqItems(): Boolean
.spark.connect.StatFreqItems freq_items = 106;
.spark.connect.StatFreqItems freq_items = 106;
- returns
Whether the freqItems field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasGroupMap(): Boolean
.spark.connect.GroupMap group_map = 31;
.spark.connect.GroupMap group_map = 31;
- returns
Whether the groupMap field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasHint(): Boolean
.spark.connect.Hint hint = 24;
.spark.connect.Hint hint = 24;
- returns
Whether the hint field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasHtmlString(): Boolean
.spark.connect.HtmlString html_string = 35;
.spark.connect.HtmlString html_string = 35;
- returns
Whether the htmlString field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasJoin(): Boolean
.spark.connect.Join join = 5;
.spark.connect.Join join = 5;
- returns
Whether the join field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasLateralJoin(): Boolean
.spark.connect.LateralJoin lateral_join = 44;
.spark.connect.LateralJoin lateral_join = 44;
- returns
Whether the lateralJoin field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasLimit(): Boolean
.spark.connect.Limit limit = 8;
.spark.connect.Limit limit = 8;
- returns
Whether the limit field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasLocalRelation(): Boolean
.spark.connect.LocalRelation local_relation = 11;
.spark.connect.LocalRelation local_relation = 11;
- returns
Whether the localRelation field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasMapPartitions(): Boolean
.spark.connect.MapPartitions map_partitions = 28;
.spark.connect.MapPartitions map_partitions = 28;
- returns
Whether the mapPartitions field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasMlRelation(): Boolean
ML relation
ML relation
.spark.connect.MlRelation ml_relation = 300;
- returns
Whether the mlRelation field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasOffset(): Boolean
.spark.connect.Offset offset = 13;
.spark.connect.Offset offset = 13;
- returns
Whether the offset field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasOneof(oneof: OneofDescriptor): Boolean
- Definition Classes
- GeneratedMessage → AbstractMessage → MessageOrBuilder
- def hasParse(): Boolean
.spark.connect.Parse parse = 30;
.spark.connect.Parse parse = 30;
- returns
Whether the parse field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasProject(): Boolean
.spark.connect.Project project = 3;
.spark.connect.Project project = 3;
- returns
Whether the project field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasRange(): Boolean
.spark.connect.Range range = 15;
.spark.connect.Range range = 15;
- returns
Whether the range field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasRead(): Boolean
.spark.connect.Read read = 2;
.spark.connect.Read read = 2;
- returns
Whether the read field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasRepartition(): Boolean
.spark.connect.Repartition repartition = 17;
.spark.connect.Repartition repartition = 17;
- returns
Whether the repartition field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasReplace(): Boolean
.spark.connect.NAReplace replace = 92;
.spark.connect.NAReplace replace = 92;
- returns
Whether the replace field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasSample(): Boolean
.spark.connect.Sample sample = 12;
.spark.connect.Sample sample = 12;
- returns
Whether the sample field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasSampleBy(): Boolean
.spark.connect.StatSampleBy sample_by = 107;
.spark.connect.StatSampleBy sample_by = 107;
- returns
Whether the sampleBy field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasSetOp(): Boolean
.spark.connect.SetOperation set_op = 6;
.spark.connect.SetOperation set_op = 6;
- returns
Whether the setOp field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasShowString(): Boolean
.spark.connect.ShowString show_string = 20;
.spark.connect.ShowString show_string = 20;
- returns
Whether the showString field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasSort(): Boolean
.spark.connect.Sort sort = 7;
.spark.connect.Sort sort = 7;
- returns
Whether the sort field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasSql(): Boolean
.spark.connect.SQL sql = 10;
.spark.connect.SQL sql = 10;
- returns
Whether the sql field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasSubqueryAlias(): Boolean
.spark.connect.SubqueryAlias subquery_alias = 16;
.spark.connect.SubqueryAlias subquery_alias = 16;
- returns
Whether the subqueryAlias field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasSummary(): Boolean
stat functions
stat functions
.spark.connect.StatSummary summary = 100;
- returns
Whether the summary field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasTail(): Boolean
.spark.connect.Tail tail = 22;
.spark.connect.Tail tail = 22;
- returns
Whether the tail field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasToDf(): Boolean
.spark.connect.ToDF to_df = 18;
.spark.connect.ToDF to_df = 18;
- returns
Whether the toDf field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasToSchema(): Boolean
.spark.connect.ToSchema to_schema = 26;
.spark.connect.ToSchema to_schema = 26;
- returns
Whether the toSchema field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasTranspose(): Boolean
.spark.connect.Transpose transpose = 42;
.spark.connect.Transpose transpose = 42;
- returns
Whether the transpose field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasUnknown(): Boolean
.spark.connect.Unknown unknown = 999;
.spark.connect.Unknown unknown = 999;
- returns
Whether the unknown field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasUnpivot(): Boolean
.spark.connect.Unpivot unpivot = 25;
.spark.connect.Unpivot unpivot = 25;
- returns
Whether the unpivot field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasWithColumns(): Boolean
.spark.connect.WithColumns with_columns = 23;
.spark.connect.WithColumns with_columns = 23;
- returns
Whether the withColumns field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- 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
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasWithRelations(): Boolean
.spark.connect.WithRelations with_relations = 41;
.spark.connect.WithRelations with_relations = 41;
- returns
Whether the withRelations field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hasWithWatermark(): Boolean
.spark.connect.WithWatermark with_watermark = 33;
.spark.connect.WithWatermark with_watermark = 33;
- returns
Whether the withWatermark field is set.
- Definition Classes
- Relation → RelationOrBuilder
- Annotations
- @Override()
- def hashCode(): Int
- Definition Classes
- Relation → AbstractMessage → Message → AnyRef → Any
- Annotations
- @Override()
- def internalGetFieldAccessorTable(): FieldAccessorTable
- def internalGetMapFieldReflection(fieldNumber: Int): MapFieldReflectionAccessor
- Attributes
- protected[protobuf]
- Definition Classes
- GeneratedMessage
- final def isInitialized(): Boolean
- Definition Classes
- Relation → GeneratedMessage → AbstractMessage → MessageLiteOrBuilder
- Annotations
- @Override()
- final def isInstanceOf[T0]: Boolean
- Definition Classes
- Any
- final def ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- def newBuilderForType(parent: BuilderParent): Builder
- def newBuilderForType(): Builder
- Definition Classes
- Relation → Message → MessageLite
- Annotations
- @Override()
- def newInstance(unused: UnusedPrivateParameter): AnyRef
- Attributes
- protected[protobuf]
- Definition Classes
- GeneratedMessage
- final def notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
- final def notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
- def parseUnknownField(input: CodedInputStream, unknownFields: Builder, extensionRegistry: ExtensionRegistryLite, tag: Int): Boolean
- Attributes
- protected[protobuf]
- Definition Classes
- GeneratedMessage
- Annotations
- @throws(classOf[java.io.IOException])
- def parseUnknownFieldProto3(input: CodedInputStream, unknownFields: Builder, extensionRegistry: ExtensionRegistryLite, tag: Int): Boolean
- Attributes
- protected[protobuf]
- Definition Classes
- GeneratedMessage
- Annotations
- @throws(classOf[java.io.IOException])
- final def synchronized[T0](arg0: => T0): T0
- Definition Classes
- AnyRef
- def toBuilder(): Builder
- Definition Classes
- Relation → Message → MessageLite
- Annotations
- @Override()
- def toByteArray(): Array[Byte]
- Definition Classes
- AbstractMessageLite → MessageLite
- def toByteString(): ByteString
- Definition Classes
- AbstractMessageLite → MessageLite
- final def toString(): String
- Definition Classes
- AbstractMessage → Message → AnyRef → Any
- final def wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- final def wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException]) @native()
- final def wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- def writeDelimitedTo(output: OutputStream): Unit
- Definition Classes
- AbstractMessageLite → MessageLite
- Annotations
- @throws(classOf[java.io.IOException])
- def writeReplace(): AnyRef
- Attributes
- protected[protobuf]
- Definition Classes
- GeneratedMessage
- Annotations
- @throws(classOf[java.io.ObjectStreamException])
- def writeTo(output: CodedOutputStream): Unit
- Definition Classes
- Relation → GeneratedMessage → AbstractMessage → MessageLite
- Annotations
- @Override()
- def writeTo(output: OutputStream): Unit
- Definition Classes
- AbstractMessageLite → MessageLite
- Annotations
- @throws(classOf[java.io.IOException])
Deprecated Value Members
- def finalize(): Unit
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.Throwable]) @Deprecated
- Deprecated
(Since version 9)
- def internalGetMapField(fieldNumber: Int): MapField[_ <: AnyRef, _ <: AnyRef]
- Attributes
- protected[protobuf]
- Definition Classes
- GeneratedMessage
- Annotations
- @Deprecated
- Deprecated
- def mergeFromAndMakeImmutableInternal(input: CodedInputStream, extensionRegistry: ExtensionRegistryLite): Unit
- Attributes
- protected[protobuf]
- Definition Classes
- GeneratedMessage
- Annotations
- @throws(classOf[com.google.protobuf.InvalidProtocolBufferException]) @Deprecated
- Deprecated