generated

package
v34.0.0-...-f7ad518 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Apr 11, 2024 License: Apache-2.0 Imports: 9 Imported by: 0

Documentation

Index

Constants

View Source
const (
	SparkConnectService_ExecutePlan_FullMethodName    = "/spark.connect.SparkConnectService/ExecutePlan"
	SparkConnectService_AnalyzePlan_FullMethodName    = "/spark.connect.SparkConnectService/AnalyzePlan"
	SparkConnectService_Config_FullMethodName         = "/spark.connect.SparkConnectService/Config"
	SparkConnectService_AddArtifacts_FullMethodName   = "/spark.connect.SparkConnectService/AddArtifacts"
	SparkConnectService_ArtifactStatus_FullMethodName = "/spark.connect.SparkConnectService/ArtifactStatus"
	SparkConnectService_Interrupt_FullMethodName      = "/spark.connect.SparkConnectService/Interrupt"
)

Variables

View Source
var (
	AnalyzePlanRequest_Explain_ExplainMode_name = map[int32]string{
		0: "EXPLAIN_MODE_UNSPECIFIED",
		1: "EXPLAIN_MODE_SIMPLE",
		2: "EXPLAIN_MODE_EXTENDED",
		3: "EXPLAIN_MODE_CODEGEN",
		4: "EXPLAIN_MODE_COST",
		5: "EXPLAIN_MODE_FORMATTED",
	}
	AnalyzePlanRequest_Explain_ExplainMode_value = map[string]int32{
		"EXPLAIN_MODE_UNSPECIFIED": 0,
		"EXPLAIN_MODE_SIMPLE":      1,
		"EXPLAIN_MODE_EXTENDED":    2,
		"EXPLAIN_MODE_CODEGEN":     3,
		"EXPLAIN_MODE_COST":        4,
		"EXPLAIN_MODE_FORMATTED":   5,
	}
)

Enum value maps for AnalyzePlanRequest_Explain_ExplainMode.

View Source
var (
	InterruptRequest_InterruptType_name = map[int32]string{
		0: "INTERRUPT_TYPE_UNSPECIFIED",
		1: "INTERRUPT_TYPE_ALL",
	}
	InterruptRequest_InterruptType_value = map[string]int32{
		"INTERRUPT_TYPE_UNSPECIFIED": 0,
		"INTERRUPT_TYPE_ALL":         1,
	}
)

Enum value maps for InterruptRequest_InterruptType.

View Source
var (
	WriteOperation_SaveMode_name = map[int32]string{
		0: "SAVE_MODE_UNSPECIFIED",
		1: "SAVE_MODE_APPEND",
		2: "SAVE_MODE_OVERWRITE",
		3: "SAVE_MODE_ERROR_IF_EXISTS",
		4: "SAVE_MODE_IGNORE",
	}
	WriteOperation_SaveMode_value = map[string]int32{
		"SAVE_MODE_UNSPECIFIED":     0,
		"SAVE_MODE_APPEND":          1,
		"SAVE_MODE_OVERWRITE":       2,
		"SAVE_MODE_ERROR_IF_EXISTS": 3,
		"SAVE_MODE_IGNORE":          4,
	}
)

Enum value maps for WriteOperation_SaveMode.

View Source
var (
	WriteOperation_SaveTable_TableSaveMethod_name = map[int32]string{
		0: "TABLE_SAVE_METHOD_UNSPECIFIED",
		1: "TABLE_SAVE_METHOD_SAVE_AS_TABLE",
		2: "TABLE_SAVE_METHOD_INSERT_INTO",
	}
	WriteOperation_SaveTable_TableSaveMethod_value = map[string]int32{
		"TABLE_SAVE_METHOD_UNSPECIFIED":   0,
		"TABLE_SAVE_METHOD_SAVE_AS_TABLE": 1,
		"TABLE_SAVE_METHOD_INSERT_INTO":   2,
	}
)

Enum value maps for WriteOperation_SaveTable_TableSaveMethod.

View Source
var (
	WriteOperationV2_Mode_name = map[int32]string{
		0: "MODE_UNSPECIFIED",
		1: "MODE_CREATE",
		2: "MODE_OVERWRITE",
		3: "MODE_OVERWRITE_PARTITIONS",
		4: "MODE_APPEND",
		5: "MODE_REPLACE",
		6: "MODE_CREATE_OR_REPLACE",
	}
	WriteOperationV2_Mode_value = map[string]int32{
		"MODE_UNSPECIFIED":          0,
		"MODE_CREATE":               1,
		"MODE_OVERWRITE":            2,
		"MODE_OVERWRITE_PARTITIONS": 3,
		"MODE_APPEND":               4,
		"MODE_REPLACE":              5,
		"MODE_CREATE_OR_REPLACE":    6,
	}
)

Enum value maps for WriteOperationV2_Mode.

View Source
var (
	Expression_Window_WindowFrame_FrameType_name = map[int32]string{
		0: "FRAME_TYPE_UNDEFINED",
		1: "FRAME_TYPE_ROW",
		2: "FRAME_TYPE_RANGE",
	}
	Expression_Window_WindowFrame_FrameType_value = map[string]int32{
		"FRAME_TYPE_UNDEFINED": 0,
		"FRAME_TYPE_ROW":       1,
		"FRAME_TYPE_RANGE":     2,
	}
)

Enum value maps for Expression_Window_WindowFrame_FrameType.

View Source
var (
	Expression_SortOrder_SortDirection_name = map[int32]string{
		0: "SORT_DIRECTION_UNSPECIFIED",
		1: "SORT_DIRECTION_ASCENDING",
		2: "SORT_DIRECTION_DESCENDING",
	}
	Expression_SortOrder_SortDirection_value = map[string]int32{
		"SORT_DIRECTION_UNSPECIFIED": 0,
		"SORT_DIRECTION_ASCENDING":   1,
		"SORT_DIRECTION_DESCENDING":  2,
	}
)

Enum value maps for Expression_SortOrder_SortDirection.

View Source
var (
	Expression_SortOrder_NullOrdering_name = map[int32]string{
		0: "SORT_NULLS_UNSPECIFIED",
		1: "SORT_NULLS_FIRST",
		2: "SORT_NULLS_LAST",
	}
	Expression_SortOrder_NullOrdering_value = map[string]int32{
		"SORT_NULLS_UNSPECIFIED": 0,
		"SORT_NULLS_FIRST":       1,
		"SORT_NULLS_LAST":        2,
	}
)

Enum value maps for Expression_SortOrder_NullOrdering.

View Source
var (
	Join_JoinType_name = map[int32]string{
		0: "JOIN_TYPE_UNSPECIFIED",
		1: "JOIN_TYPE_INNER",
		2: "JOIN_TYPE_FULL_OUTER",
		3: "JOIN_TYPE_LEFT_OUTER",
		4: "JOIN_TYPE_RIGHT_OUTER",
		5: "JOIN_TYPE_LEFT_ANTI",
		6: "JOIN_TYPE_LEFT_SEMI",
		7: "JOIN_TYPE_CROSS",
	}
	Join_JoinType_value = map[string]int32{
		"JOIN_TYPE_UNSPECIFIED": 0,
		"JOIN_TYPE_INNER":       1,
		"JOIN_TYPE_FULL_OUTER":  2,
		"JOIN_TYPE_LEFT_OUTER":  3,
		"JOIN_TYPE_RIGHT_OUTER": 4,
		"JOIN_TYPE_LEFT_ANTI":   5,
		"JOIN_TYPE_LEFT_SEMI":   6,
		"JOIN_TYPE_CROSS":       7,
	}
)

Enum value maps for Join_JoinType.

View Source
var (
	SetOperation_SetOpType_name = map[int32]string{
		0: "SET_OP_TYPE_UNSPECIFIED",
		1: "SET_OP_TYPE_INTERSECT",
		2: "SET_OP_TYPE_UNION",
		3: "SET_OP_TYPE_EXCEPT",
	}
	SetOperation_SetOpType_value = map[string]int32{
		"SET_OP_TYPE_UNSPECIFIED": 0,
		"SET_OP_TYPE_INTERSECT":   1,
		"SET_OP_TYPE_UNION":       2,
		"SET_OP_TYPE_EXCEPT":      3,
	}
)

Enum value maps for SetOperation_SetOpType.

View Source
var (
	Aggregate_GroupType_name = map[int32]string{
		0: "GROUP_TYPE_UNSPECIFIED",
		1: "GROUP_TYPE_GROUPBY",
		2: "GROUP_TYPE_ROLLUP",
		3: "GROUP_TYPE_CUBE",
		4: "GROUP_TYPE_PIVOT",
	}
	Aggregate_GroupType_value = map[string]int32{
		"GROUP_TYPE_UNSPECIFIED": 0,
		"GROUP_TYPE_GROUPBY":     1,
		"GROUP_TYPE_ROLLUP":      2,
		"GROUP_TYPE_CUBE":        3,
		"GROUP_TYPE_PIVOT":       4,
	}
)

Enum value maps for Aggregate_GroupType.

View Source
var (
	Parse_ParseFormat_name = map[int32]string{
		0: "PARSE_FORMAT_UNSPECIFIED",
		1: "PARSE_FORMAT_CSV",
		2: "PARSE_FORMAT_JSON",
	}
	Parse_ParseFormat_value = map[string]int32{
		"PARSE_FORMAT_UNSPECIFIED": 0,
		"PARSE_FORMAT_CSV":         1,
		"PARSE_FORMAT_JSON":        2,
	}
)

Enum value maps for Parse_ParseFormat.

View Source
var File_spark_connect_base_proto protoreflect.FileDescriptor
View Source
var File_spark_connect_catalog_proto protoreflect.FileDescriptor
View Source
var File_spark_connect_commands_proto protoreflect.FileDescriptor
View Source
var File_spark_connect_common_proto protoreflect.FileDescriptor
View Source
var File_spark_connect_example_plugins_proto protoreflect.FileDescriptor
View Source
var File_spark_connect_expressions_proto protoreflect.FileDescriptor
View Source
var File_spark_connect_relations_proto protoreflect.FileDescriptor
View Source
var File_spark_connect_types_proto protoreflect.FileDescriptor
View Source
var SparkConnectService_ServiceDesc = grpc.ServiceDesc{
	ServiceName: "spark.connect.SparkConnectService",
	HandlerType: (*SparkConnectServiceServer)(nil),
	Methods: []grpc.MethodDesc{
		{
			MethodName: "AnalyzePlan",
			Handler:    _SparkConnectService_AnalyzePlan_Handler,
		},
		{
			MethodName: "Config",
			Handler:    _SparkConnectService_Config_Handler,
		},
		{
			MethodName: "ArtifactStatus",
			Handler:    _SparkConnectService_ArtifactStatus_Handler,
		},
		{
			MethodName: "Interrupt",
			Handler:    _SparkConnectService_Interrupt_Handler,
		},
	},
	Streams: []grpc.StreamDesc{
		{
			StreamName:    "ExecutePlan",
			Handler:       _SparkConnectService_ExecutePlan_Handler,
			ServerStreams: true,
		},
		{
			StreamName:    "AddArtifacts",
			Handler:       _SparkConnectService_AddArtifacts_Handler,
			ClientStreams: true,
		},
	},
	Metadata: "spark/connect/base.proto",
}

SparkConnectService_ServiceDesc is the grpc.ServiceDesc for SparkConnectService service. It's only intended for direct use with grpc.RegisterService, and not to be introspected or modified (even as a copy)

Functions

func RegisterSparkConnectServiceServer

func RegisterSparkConnectServiceServer(s grpc.ServiceRegistrar, srv SparkConnectServiceServer)

Types

type AddArtifactsRequest

type AddArtifactsRequest struct {

	// (Required)
	//
	// The session_id specifies a spark session for a user id (which is specified
	// by user_context.user_id). The session_id is set by the client to be able to
	// collate streaming responses from different queries within the dedicated session.
	SessionId string `protobuf:"bytes,1,opt,name=session_id,json=sessionId,proto3" json:"session_id,omitempty"`
	// User context
	UserContext *UserContext `protobuf:"bytes,2,opt,name=user_context,json=userContext,proto3" json:"user_context,omitempty"`
	// Provides optional information about the client sending the request. This field
	// can be used for language or version specific information and is only intended for
	// logging purposes and will not be interpreted by the server.
	ClientType *string `protobuf:"bytes,6,opt,name=client_type,json=clientType,proto3,oneof" json:"client_type,omitempty"`
	// The payload is either a batch of artifacts or a partial chunk of a large artifact.
	//
	// Types that are assignable to Payload:
	//
	//	*AddArtifactsRequest_Batch_
	//	*AddArtifactsRequest_BeginChunk
	//	*AddArtifactsRequest_Chunk
	Payload isAddArtifactsRequest_Payload `protobuf_oneof:"payload"`
	// contains filtered or unexported fields
}

Request to transfer client-local artifacts.

func (*AddArtifactsRequest) Descriptor deprecated

func (*AddArtifactsRequest) Descriptor() ([]byte, []int)

Deprecated: Use AddArtifactsRequest.ProtoReflect.Descriptor instead.

func (*AddArtifactsRequest) GetBatch

func (*AddArtifactsRequest) GetBeginChunk

func (*AddArtifactsRequest) GetChunk

func (*AddArtifactsRequest) GetClientType

func (x *AddArtifactsRequest) GetClientType() string

func (*AddArtifactsRequest) GetPayload

func (m *AddArtifactsRequest) GetPayload() isAddArtifactsRequest_Payload

func (*AddArtifactsRequest) GetSessionId

func (x *AddArtifactsRequest) GetSessionId() string

func (*AddArtifactsRequest) GetUserContext

func (x *AddArtifactsRequest) GetUserContext() *UserContext

func (*AddArtifactsRequest) ProtoMessage

func (*AddArtifactsRequest) ProtoMessage()

func (*AddArtifactsRequest) ProtoReflect

func (x *AddArtifactsRequest) ProtoReflect() protoreflect.Message

func (*AddArtifactsRequest) Reset

func (x *AddArtifactsRequest) Reset()

func (*AddArtifactsRequest) String

func (x *AddArtifactsRequest) String() string

type AddArtifactsRequest_ArtifactChunk

type AddArtifactsRequest_ArtifactChunk struct {

	// Data chunk.
	Data []byte `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty"`
	// CRC to allow server to verify integrity of the chunk.
	Crc int64 `protobuf:"varint,2,opt,name=crc,proto3" json:"crc,omitempty"`
	// contains filtered or unexported fields
}

A chunk of an Artifact.

func (*AddArtifactsRequest_ArtifactChunk) Descriptor deprecated

func (*AddArtifactsRequest_ArtifactChunk) Descriptor() ([]byte, []int)

Deprecated: Use AddArtifactsRequest_ArtifactChunk.ProtoReflect.Descriptor instead.

func (*AddArtifactsRequest_ArtifactChunk) GetCrc

func (*AddArtifactsRequest_ArtifactChunk) GetData

func (x *AddArtifactsRequest_ArtifactChunk) GetData() []byte

func (*AddArtifactsRequest_ArtifactChunk) ProtoMessage

func (*AddArtifactsRequest_ArtifactChunk) ProtoMessage()

func (*AddArtifactsRequest_ArtifactChunk) ProtoReflect

func (*AddArtifactsRequest_ArtifactChunk) Reset

func (*AddArtifactsRequest_ArtifactChunk) String

type AddArtifactsRequest_Batch

type AddArtifactsRequest_Batch struct {
	Artifacts []*AddArtifactsRequest_SingleChunkArtifact `protobuf:"bytes,1,rep,name=artifacts,proto3" json:"artifacts,omitempty"`
	// contains filtered or unexported fields
}

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

func (*AddArtifactsRequest_Batch) Descriptor deprecated

func (*AddArtifactsRequest_Batch) Descriptor() ([]byte, []int)

Deprecated: Use AddArtifactsRequest_Batch.ProtoReflect.Descriptor instead.

func (*AddArtifactsRequest_Batch) GetArtifacts

func (*AddArtifactsRequest_Batch) ProtoMessage

func (*AddArtifactsRequest_Batch) ProtoMessage()

func (*AddArtifactsRequest_Batch) ProtoReflect

func (*AddArtifactsRequest_Batch) Reset

func (x *AddArtifactsRequest_Batch) Reset()

func (*AddArtifactsRequest_Batch) String

func (x *AddArtifactsRequest_Batch) String() string

type AddArtifactsRequest_Batch_

type AddArtifactsRequest_Batch_ struct {
	Batch *AddArtifactsRequest_Batch `protobuf:"bytes,3,opt,name=batch,proto3,oneof"`
}

type AddArtifactsRequest_BeginChunk

type AddArtifactsRequest_BeginChunk struct {
	// The metadata and the initial chunk of a large artifact chunked into multiple requests.
	// The server side is notified about the total size of the large artifact as well as the
	// number of chunks to expect.
	BeginChunk *AddArtifactsRequest_BeginChunkedArtifact `protobuf:"bytes,4,opt,name=begin_chunk,json=beginChunk,proto3,oneof"`
}

type AddArtifactsRequest_BeginChunkedArtifact

type AddArtifactsRequest_BeginChunkedArtifact struct {

	// Name of the artifact undergoing chunking. Follows the same conventions as the `name` in
	// the `Artifact` message.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// Total size of the artifact in bytes.
	TotalBytes int64 `protobuf:"varint,2,opt,name=total_bytes,json=totalBytes,proto3" json:"total_bytes,omitempty"`
	// Number of chunks the artifact is split into.
	// This includes the `initial_chunk`.
	NumChunks int64 `protobuf:"varint,3,opt,name=num_chunks,json=numChunks,proto3" json:"num_chunks,omitempty"`
	// The first/initial chunk.
	InitialChunk *AddArtifactsRequest_ArtifactChunk `protobuf:"bytes,4,opt,name=initial_chunk,json=initialChunk,proto3" json:"initial_chunk,omitempty"`
	// contains filtered or unexported fields
}

Signals the beginning/start of a chunked artifact. A large artifact is transferred through a payload of `BeginChunkedArtifact` followed by a sequence of `ArtifactChunk`s.

func (*AddArtifactsRequest_BeginChunkedArtifact) Descriptor deprecated

func (*AddArtifactsRequest_BeginChunkedArtifact) Descriptor() ([]byte, []int)

Deprecated: Use AddArtifactsRequest_BeginChunkedArtifact.ProtoReflect.Descriptor instead.

func (*AddArtifactsRequest_BeginChunkedArtifact) GetInitialChunk

func (*AddArtifactsRequest_BeginChunkedArtifact) GetName

func (*AddArtifactsRequest_BeginChunkedArtifact) GetNumChunks

func (*AddArtifactsRequest_BeginChunkedArtifact) GetTotalBytes

func (*AddArtifactsRequest_BeginChunkedArtifact) ProtoMessage

func (*AddArtifactsRequest_BeginChunkedArtifact) ProtoReflect

func (*AddArtifactsRequest_BeginChunkedArtifact) Reset

func (*AddArtifactsRequest_BeginChunkedArtifact) String

type AddArtifactsRequest_Chunk

type AddArtifactsRequest_Chunk struct {
	// A chunk of an artifact excluding metadata. This can be any chunk of a large artifact
	// excluding the first chunk (which is included in `BeginChunkedArtifact`).
	Chunk *AddArtifactsRequest_ArtifactChunk `protobuf:"bytes,5,opt,name=chunk,proto3,oneof"`
}

type AddArtifactsRequest_SingleChunkArtifact

type AddArtifactsRequest_SingleChunkArtifact struct {

	// The name of the artifact is expected in the form of a "Relative Path" that is made up of a
	// sequence of directories and the final file element.
	// Examples of "Relative Path"s: "jars/test.jar", "classes/xyz.class", "abc.xyz", "a/b/X.jar".
	// The server is expected to maintain the hierarchy of files as defined by their name. (i.e
	// The relative path of the file on the server's filesystem will be the same as the name of
	// the provided artifact)
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// A single data chunk.
	Data *AddArtifactsRequest_ArtifactChunk `protobuf:"bytes,2,opt,name=data,proto3" json:"data,omitempty"`
	// contains filtered or unexported fields
}

An artifact that is contained in a single `ArtifactChunk`. Generally, this message represents tiny artifacts such as REPL-generated class files.

func (*AddArtifactsRequest_SingleChunkArtifact) Descriptor deprecated

func (*AddArtifactsRequest_SingleChunkArtifact) Descriptor() ([]byte, []int)

Deprecated: Use AddArtifactsRequest_SingleChunkArtifact.ProtoReflect.Descriptor instead.

func (*AddArtifactsRequest_SingleChunkArtifact) GetData

func (*AddArtifactsRequest_SingleChunkArtifact) GetName

func (*AddArtifactsRequest_SingleChunkArtifact) ProtoMessage

func (*AddArtifactsRequest_SingleChunkArtifact) ProtoReflect

func (*AddArtifactsRequest_SingleChunkArtifact) Reset

func (*AddArtifactsRequest_SingleChunkArtifact) String

type AddArtifactsResponse

type AddArtifactsResponse struct {

	// The list of artifact(s) seen by the server.
	Artifacts []*AddArtifactsResponse_ArtifactSummary `protobuf:"bytes,1,rep,name=artifacts,proto3" json:"artifacts,omitempty"`
	// contains filtered or unexported fields
}

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

func (*AddArtifactsResponse) Descriptor deprecated

func (*AddArtifactsResponse) Descriptor() ([]byte, []int)

Deprecated: Use AddArtifactsResponse.ProtoReflect.Descriptor instead.

func (*AddArtifactsResponse) GetArtifacts

func (*AddArtifactsResponse) ProtoMessage

func (*AddArtifactsResponse) ProtoMessage()

func (*AddArtifactsResponse) ProtoReflect

func (x *AddArtifactsResponse) ProtoReflect() protoreflect.Message

func (*AddArtifactsResponse) Reset

func (x *AddArtifactsResponse) Reset()

func (*AddArtifactsResponse) String

func (x *AddArtifactsResponse) String() string

type AddArtifactsResponse_ArtifactSummary

type AddArtifactsResponse_ArtifactSummary struct {
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// Whether the CRC (Cyclic Redundancy Check) is successful on server verification.
	// The server discards any artifact that fails the CRC.
	// If false, the client may choose to resend the artifact specified by `name`.
	IsCrcSuccessful bool `protobuf:"varint,2,opt,name=is_crc_successful,json=isCrcSuccessful,proto3" json:"is_crc_successful,omitempty"`
	// contains filtered or unexported fields
}

Metadata of an artifact.

func (*AddArtifactsResponse_ArtifactSummary) Descriptor deprecated

func (*AddArtifactsResponse_ArtifactSummary) Descriptor() ([]byte, []int)

Deprecated: Use AddArtifactsResponse_ArtifactSummary.ProtoReflect.Descriptor instead.

func (*AddArtifactsResponse_ArtifactSummary) GetIsCrcSuccessful

func (x *AddArtifactsResponse_ArtifactSummary) GetIsCrcSuccessful() bool

func (*AddArtifactsResponse_ArtifactSummary) GetName

func (*AddArtifactsResponse_ArtifactSummary) ProtoMessage

func (*AddArtifactsResponse_ArtifactSummary) ProtoMessage()

func (*AddArtifactsResponse_ArtifactSummary) ProtoReflect

func (*AddArtifactsResponse_ArtifactSummary) Reset

func (*AddArtifactsResponse_ArtifactSummary) String

type Aggregate

type Aggregate struct {

	// (Required) Input relation for a RelationalGroupedDataset.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) How the RelationalGroupedDataset was built.
	GroupType Aggregate_GroupType `` /* 128-byte string literal not displayed */
	// (Required) Expressions for grouping keys
	GroupingExpressions []*Expression `protobuf:"bytes,3,rep,name=grouping_expressions,json=groupingExpressions,proto3" json:"grouping_expressions,omitempty"`
	// (Required) List of values that will be translated to columns in the output DataFrame.
	AggregateExpressions []*Expression `protobuf:"bytes,4,rep,name=aggregate_expressions,json=aggregateExpressions,proto3" json:"aggregate_expressions,omitempty"`
	// (Optional) Pivots a column of the current `DataFrame` and performs the specified aggregation.
	Pivot *Aggregate_Pivot `protobuf:"bytes,5,opt,name=pivot,proto3" json:"pivot,omitempty"`
	// contains filtered or unexported fields
}

Relation of type [Aggregate].

func (*Aggregate) Descriptor deprecated

func (*Aggregate) Descriptor() ([]byte, []int)

Deprecated: Use Aggregate.ProtoReflect.Descriptor instead.

func (*Aggregate) GetAggregateExpressions

func (x *Aggregate) GetAggregateExpressions() []*Expression

func (*Aggregate) GetGroupType

func (x *Aggregate) GetGroupType() Aggregate_GroupType

func (*Aggregate) GetGroupingExpressions

func (x *Aggregate) GetGroupingExpressions() []*Expression

func (*Aggregate) GetInput

func (x *Aggregate) GetInput() *Relation

func (*Aggregate) GetPivot

func (x *Aggregate) GetPivot() *Aggregate_Pivot

func (*Aggregate) ProtoMessage

func (*Aggregate) ProtoMessage()

func (*Aggregate) ProtoReflect

func (x *Aggregate) ProtoReflect() protoreflect.Message

func (*Aggregate) Reset

func (x *Aggregate) Reset()

func (*Aggregate) String

func (x *Aggregate) String() string

type Aggregate_GroupType

type Aggregate_GroupType int32
const (
	Aggregate_GROUP_TYPE_UNSPECIFIED Aggregate_GroupType = 0
	Aggregate_GROUP_TYPE_GROUPBY     Aggregate_GroupType = 1
	Aggregate_GROUP_TYPE_ROLLUP      Aggregate_GroupType = 2
	Aggregate_GROUP_TYPE_CUBE        Aggregate_GroupType = 3
	Aggregate_GROUP_TYPE_PIVOT       Aggregate_GroupType = 4
)

func (Aggregate_GroupType) Descriptor

func (Aggregate_GroupType) Enum

func (Aggregate_GroupType) EnumDescriptor deprecated

func (Aggregate_GroupType) EnumDescriptor() ([]byte, []int)

Deprecated: Use Aggregate_GroupType.Descriptor instead.

func (Aggregate_GroupType) Number

func (Aggregate_GroupType) String

func (x Aggregate_GroupType) String() string

func (Aggregate_GroupType) Type

type Aggregate_Pivot

type Aggregate_Pivot struct {

	// (Required) The column to pivot
	Col *Expression `protobuf:"bytes,1,opt,name=col,proto3" json:"col,omitempty"`
	// (Optional) List of values that will be translated to columns in the output DataFrame.
	//
	// Note that if it is empty, the server side will immediately trigger a job to collect
	// the distinct values of the column.
	Values []*Expression_Literal `protobuf:"bytes,2,rep,name=values,proto3" json:"values,omitempty"`
	// contains filtered or unexported fields
}

func (*Aggregate_Pivot) Descriptor deprecated

func (*Aggregate_Pivot) Descriptor() ([]byte, []int)

Deprecated: Use Aggregate_Pivot.ProtoReflect.Descriptor instead.

func (*Aggregate_Pivot) GetCol

func (x *Aggregate_Pivot) GetCol() *Expression

func (*Aggregate_Pivot) GetValues

func (x *Aggregate_Pivot) GetValues() []*Expression_Literal

func (*Aggregate_Pivot) ProtoMessage

func (*Aggregate_Pivot) ProtoMessage()

func (*Aggregate_Pivot) ProtoReflect

func (x *Aggregate_Pivot) ProtoReflect() protoreflect.Message

func (*Aggregate_Pivot) Reset

func (x *Aggregate_Pivot) Reset()

func (*Aggregate_Pivot) String

func (x *Aggregate_Pivot) String() string

type AnalyzePlanRequest

type AnalyzePlanRequest struct {

	// (Required)
	//
	// The session_id specifies a spark session for a user id (which is specified
	// by user_context.user_id). The session_id is set by the client to be able to
	// collate streaming responses from different queries within the dedicated session.
	SessionId string `protobuf:"bytes,1,opt,name=session_id,json=sessionId,proto3" json:"session_id,omitempty"`
	// (Required) User context
	UserContext *UserContext `protobuf:"bytes,2,opt,name=user_context,json=userContext,proto3" json:"user_context,omitempty"`
	// Provides optional information about the client sending the request. This field
	// can be used for language or version specific information and is only intended for
	// logging purposes and will not be interpreted by the server.
	ClientType *string `protobuf:"bytes,3,opt,name=client_type,json=clientType,proto3,oneof" json:"client_type,omitempty"`
	// Types that are assignable to Analyze:
	//
	//	*AnalyzePlanRequest_Schema_
	//	*AnalyzePlanRequest_Explain_
	//	*AnalyzePlanRequest_TreeString_
	//	*AnalyzePlanRequest_IsLocal_
	//	*AnalyzePlanRequest_IsStreaming_
	//	*AnalyzePlanRequest_InputFiles_
	//	*AnalyzePlanRequest_SparkVersion_
	//	*AnalyzePlanRequest_DdlParse
	//	*AnalyzePlanRequest_SameSemantics_
	//	*AnalyzePlanRequest_SemanticHash_
	//	*AnalyzePlanRequest_Persist_
	//	*AnalyzePlanRequest_Unpersist_
	//	*AnalyzePlanRequest_GetStorageLevel_
	Analyze isAnalyzePlanRequest_Analyze `protobuf_oneof:"analyze"`
	// contains filtered or unexported fields
}

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

func (*AnalyzePlanRequest) Descriptor deprecated

func (*AnalyzePlanRequest) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanRequest.ProtoReflect.Descriptor instead.

func (*AnalyzePlanRequest) GetAnalyze

func (m *AnalyzePlanRequest) GetAnalyze() isAnalyzePlanRequest_Analyze

func (*AnalyzePlanRequest) GetClientType

func (x *AnalyzePlanRequest) GetClientType() string

func (*AnalyzePlanRequest) GetDdlParse

func (*AnalyzePlanRequest) GetExplain

func (*AnalyzePlanRequest) GetGetStorageLevel

func (x *AnalyzePlanRequest) GetGetStorageLevel() *AnalyzePlanRequest_GetStorageLevel

func (*AnalyzePlanRequest) GetInputFiles

func (*AnalyzePlanRequest) GetIsLocal

func (*AnalyzePlanRequest) GetIsStreaming

func (*AnalyzePlanRequest) GetPersist

func (*AnalyzePlanRequest) GetSameSemantics

func (*AnalyzePlanRequest) GetSchema

func (*AnalyzePlanRequest) GetSemanticHash

func (*AnalyzePlanRequest) GetSessionId

func (x *AnalyzePlanRequest) GetSessionId() string

func (*AnalyzePlanRequest) GetSparkVersion

func (*AnalyzePlanRequest) GetTreeString

func (*AnalyzePlanRequest) GetUnpersist

func (*AnalyzePlanRequest) GetUserContext

func (x *AnalyzePlanRequest) GetUserContext() *UserContext

func (*AnalyzePlanRequest) ProtoMessage

func (*AnalyzePlanRequest) ProtoMessage()

func (*AnalyzePlanRequest) ProtoReflect

func (x *AnalyzePlanRequest) ProtoReflect() protoreflect.Message

func (*AnalyzePlanRequest) Reset

func (x *AnalyzePlanRequest) Reset()

func (*AnalyzePlanRequest) String

func (x *AnalyzePlanRequest) String() string

type AnalyzePlanRequest_DDLParse

type AnalyzePlanRequest_DDLParse struct {

	// (Required) The DDL formatted string to be parsed.
	DdlString string `protobuf:"bytes,1,opt,name=ddl_string,json=ddlString,proto3" json:"ddl_string,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanRequest_DDLParse) Descriptor deprecated

func (*AnalyzePlanRequest_DDLParse) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanRequest_DDLParse.ProtoReflect.Descriptor instead.

func (*AnalyzePlanRequest_DDLParse) GetDdlString

func (x *AnalyzePlanRequest_DDLParse) GetDdlString() string

func (*AnalyzePlanRequest_DDLParse) ProtoMessage

func (*AnalyzePlanRequest_DDLParse) ProtoMessage()

func (*AnalyzePlanRequest_DDLParse) ProtoReflect

func (*AnalyzePlanRequest_DDLParse) Reset

func (x *AnalyzePlanRequest_DDLParse) Reset()

func (*AnalyzePlanRequest_DDLParse) String

func (x *AnalyzePlanRequest_DDLParse) String() string

type AnalyzePlanRequest_DdlParse

type AnalyzePlanRequest_DdlParse struct {
	DdlParse *AnalyzePlanRequest_DDLParse `protobuf:"bytes,11,opt,name=ddl_parse,json=ddlParse,proto3,oneof"`
}

type AnalyzePlanRequest_Explain

type AnalyzePlanRequest_Explain struct {

	// (Required) The logical plan to be analyzed.
	Plan *Plan `protobuf:"bytes,1,opt,name=plan,proto3" json:"plan,omitempty"`
	// (Required) For analyzePlan rpc calls, configure the mode to explain plan in strings.
	ExplainMode AnalyzePlanRequest_Explain_ExplainMode `` /* 153-byte string literal not displayed */
	// contains filtered or unexported fields
}

Explains the input plan based on a configurable mode.

func (*AnalyzePlanRequest_Explain) Descriptor deprecated

func (*AnalyzePlanRequest_Explain) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanRequest_Explain.ProtoReflect.Descriptor instead.

func (*AnalyzePlanRequest_Explain) GetExplainMode

func (*AnalyzePlanRequest_Explain) GetPlan

func (x *AnalyzePlanRequest_Explain) GetPlan() *Plan

func (*AnalyzePlanRequest_Explain) ProtoMessage

func (*AnalyzePlanRequest_Explain) ProtoMessage()

func (*AnalyzePlanRequest_Explain) ProtoReflect

func (*AnalyzePlanRequest_Explain) Reset

func (x *AnalyzePlanRequest_Explain) Reset()

func (*AnalyzePlanRequest_Explain) String

func (x *AnalyzePlanRequest_Explain) String() string

type AnalyzePlanRequest_Explain_

type AnalyzePlanRequest_Explain_ struct {
	Explain *AnalyzePlanRequest_Explain `protobuf:"bytes,5,opt,name=explain,proto3,oneof"`
}

type AnalyzePlanRequest_Explain_ExplainMode

type AnalyzePlanRequest_Explain_ExplainMode int32

Plan explanation mode.

const (
	AnalyzePlanRequest_Explain_EXPLAIN_MODE_UNSPECIFIED AnalyzePlanRequest_Explain_ExplainMode = 0
	// Generates only physical plan.
	AnalyzePlanRequest_Explain_EXPLAIN_MODE_SIMPLE AnalyzePlanRequest_Explain_ExplainMode = 1
	// Generates parsed logical plan, analyzed logical plan, optimized logical plan and physical plan.
	// Parsed Logical plan is a unresolved plan that extracted from the query. Analyzed logical plans
	// transforms which translates unresolvedAttribute and unresolvedRelation into fully typed objects.
	// The optimized logical plan transforms through a set of optimization rules, resulting in the
	// physical plan.
	AnalyzePlanRequest_Explain_EXPLAIN_MODE_EXTENDED AnalyzePlanRequest_Explain_ExplainMode = 2
	// Generates code for the statement, if any and a physical plan.
	AnalyzePlanRequest_Explain_EXPLAIN_MODE_CODEGEN AnalyzePlanRequest_Explain_ExplainMode = 3
	// If plan node statistics are available, generates a logical plan and also the statistics.
	AnalyzePlanRequest_Explain_EXPLAIN_MODE_COST AnalyzePlanRequest_Explain_ExplainMode = 4
	// Generates a physical plan outline and also node details.
	AnalyzePlanRequest_Explain_EXPLAIN_MODE_FORMATTED AnalyzePlanRequest_Explain_ExplainMode = 5
)

func (AnalyzePlanRequest_Explain_ExplainMode) Descriptor

func (AnalyzePlanRequest_Explain_ExplainMode) Enum

func (AnalyzePlanRequest_Explain_ExplainMode) EnumDescriptor deprecated

func (AnalyzePlanRequest_Explain_ExplainMode) EnumDescriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanRequest_Explain_ExplainMode.Descriptor instead.

func (AnalyzePlanRequest_Explain_ExplainMode) Number

func (AnalyzePlanRequest_Explain_ExplainMode) String

func (AnalyzePlanRequest_Explain_ExplainMode) Type

type AnalyzePlanRequest_GetStorageLevel

type AnalyzePlanRequest_GetStorageLevel struct {

	// (Required) The logical plan to get the storage level.
	Relation *Relation `protobuf:"bytes,1,opt,name=relation,proto3" json:"relation,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanRequest_GetStorageLevel) Descriptor deprecated

func (*AnalyzePlanRequest_GetStorageLevel) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanRequest_GetStorageLevel.ProtoReflect.Descriptor instead.

func (*AnalyzePlanRequest_GetStorageLevel) GetRelation

func (x *AnalyzePlanRequest_GetStorageLevel) GetRelation() *Relation

func (*AnalyzePlanRequest_GetStorageLevel) ProtoMessage

func (*AnalyzePlanRequest_GetStorageLevel) ProtoMessage()

func (*AnalyzePlanRequest_GetStorageLevel) ProtoReflect

func (*AnalyzePlanRequest_GetStorageLevel) Reset

func (*AnalyzePlanRequest_GetStorageLevel) String

type AnalyzePlanRequest_GetStorageLevel_

type AnalyzePlanRequest_GetStorageLevel_ struct {
	GetStorageLevel *AnalyzePlanRequest_GetStorageLevel `protobuf:"bytes,16,opt,name=get_storage_level,json=getStorageLevel,proto3,oneof"`
}

type AnalyzePlanRequest_InputFiles

type AnalyzePlanRequest_InputFiles struct {

	// (Required) The logical plan to be analyzed.
	Plan *Plan `protobuf:"bytes,1,opt,name=plan,proto3" json:"plan,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanRequest_InputFiles) Descriptor deprecated

func (*AnalyzePlanRequest_InputFiles) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanRequest_InputFiles.ProtoReflect.Descriptor instead.

func (*AnalyzePlanRequest_InputFiles) GetPlan

func (x *AnalyzePlanRequest_InputFiles) GetPlan() *Plan

func (*AnalyzePlanRequest_InputFiles) ProtoMessage

func (*AnalyzePlanRequest_InputFiles) ProtoMessage()

func (*AnalyzePlanRequest_InputFiles) ProtoReflect

func (*AnalyzePlanRequest_InputFiles) Reset

func (x *AnalyzePlanRequest_InputFiles) Reset()

func (*AnalyzePlanRequest_InputFiles) String

type AnalyzePlanRequest_InputFiles_

type AnalyzePlanRequest_InputFiles_ struct {
	InputFiles *AnalyzePlanRequest_InputFiles `protobuf:"bytes,9,opt,name=input_files,json=inputFiles,proto3,oneof"`
}

type AnalyzePlanRequest_IsLocal

type AnalyzePlanRequest_IsLocal struct {

	// (Required) The logical plan to be analyzed.
	Plan *Plan `protobuf:"bytes,1,opt,name=plan,proto3" json:"plan,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanRequest_IsLocal) Descriptor deprecated

func (*AnalyzePlanRequest_IsLocal) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanRequest_IsLocal.ProtoReflect.Descriptor instead.

func (*AnalyzePlanRequest_IsLocal) GetPlan

func (x *AnalyzePlanRequest_IsLocal) GetPlan() *Plan

func (*AnalyzePlanRequest_IsLocal) ProtoMessage

func (*AnalyzePlanRequest_IsLocal) ProtoMessage()

func (*AnalyzePlanRequest_IsLocal) ProtoReflect

func (*AnalyzePlanRequest_IsLocal) Reset

func (x *AnalyzePlanRequest_IsLocal) Reset()

func (*AnalyzePlanRequest_IsLocal) String

func (x *AnalyzePlanRequest_IsLocal) String() string

type AnalyzePlanRequest_IsLocal_

type AnalyzePlanRequest_IsLocal_ struct {
	IsLocal *AnalyzePlanRequest_IsLocal `protobuf:"bytes,7,opt,name=is_local,json=isLocal,proto3,oneof"`
}

type AnalyzePlanRequest_IsStreaming

type AnalyzePlanRequest_IsStreaming struct {

	// (Required) The logical plan to be analyzed.
	Plan *Plan `protobuf:"bytes,1,opt,name=plan,proto3" json:"plan,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanRequest_IsStreaming) Descriptor deprecated

func (*AnalyzePlanRequest_IsStreaming) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanRequest_IsStreaming.ProtoReflect.Descriptor instead.

func (*AnalyzePlanRequest_IsStreaming) GetPlan

func (x *AnalyzePlanRequest_IsStreaming) GetPlan() *Plan

func (*AnalyzePlanRequest_IsStreaming) ProtoMessage

func (*AnalyzePlanRequest_IsStreaming) ProtoMessage()

func (*AnalyzePlanRequest_IsStreaming) ProtoReflect

func (*AnalyzePlanRequest_IsStreaming) Reset

func (x *AnalyzePlanRequest_IsStreaming) Reset()

func (*AnalyzePlanRequest_IsStreaming) String

type AnalyzePlanRequest_IsStreaming_

type AnalyzePlanRequest_IsStreaming_ struct {
	IsStreaming *AnalyzePlanRequest_IsStreaming `protobuf:"bytes,8,opt,name=is_streaming,json=isStreaming,proto3,oneof"`
}

type AnalyzePlanRequest_Persist

type AnalyzePlanRequest_Persist struct {

	// (Required) The logical plan to persist.
	Relation *Relation `protobuf:"bytes,1,opt,name=relation,proto3" json:"relation,omitempty"`
	// (Optional) The storage level.
	StorageLevel *StorageLevel `protobuf:"bytes,2,opt,name=storage_level,json=storageLevel,proto3,oneof" json:"storage_level,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanRequest_Persist) Descriptor deprecated

func (*AnalyzePlanRequest_Persist) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanRequest_Persist.ProtoReflect.Descriptor instead.

func (*AnalyzePlanRequest_Persist) GetRelation

func (x *AnalyzePlanRequest_Persist) GetRelation() *Relation

func (*AnalyzePlanRequest_Persist) GetStorageLevel

func (x *AnalyzePlanRequest_Persist) GetStorageLevel() *StorageLevel

func (*AnalyzePlanRequest_Persist) ProtoMessage

func (*AnalyzePlanRequest_Persist) ProtoMessage()

func (*AnalyzePlanRequest_Persist) ProtoReflect

func (*AnalyzePlanRequest_Persist) Reset

func (x *AnalyzePlanRequest_Persist) Reset()

func (*AnalyzePlanRequest_Persist) String

func (x *AnalyzePlanRequest_Persist) String() string

type AnalyzePlanRequest_Persist_

type AnalyzePlanRequest_Persist_ struct {
	Persist *AnalyzePlanRequest_Persist `protobuf:"bytes,14,opt,name=persist,proto3,oneof"`
}

type AnalyzePlanRequest_SameSemantics

type AnalyzePlanRequest_SameSemantics struct {

	// (Required) The plan to be compared.
	TargetPlan *Plan `protobuf:"bytes,1,opt,name=target_plan,json=targetPlan,proto3" json:"target_plan,omitempty"`
	// (Required) The other plan to be compared.
	OtherPlan *Plan `protobuf:"bytes,2,opt,name=other_plan,json=otherPlan,proto3" json:"other_plan,omitempty"`
	// contains filtered or unexported fields
}

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

func (*AnalyzePlanRequest_SameSemantics) Descriptor deprecated

func (*AnalyzePlanRequest_SameSemantics) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanRequest_SameSemantics.ProtoReflect.Descriptor instead.

func (*AnalyzePlanRequest_SameSemantics) GetOtherPlan

func (x *AnalyzePlanRequest_SameSemantics) GetOtherPlan() *Plan

func (*AnalyzePlanRequest_SameSemantics) GetTargetPlan

func (x *AnalyzePlanRequest_SameSemantics) GetTargetPlan() *Plan

func (*AnalyzePlanRequest_SameSemantics) ProtoMessage

func (*AnalyzePlanRequest_SameSemantics) ProtoMessage()

func (*AnalyzePlanRequest_SameSemantics) ProtoReflect

func (*AnalyzePlanRequest_SameSemantics) Reset

func (*AnalyzePlanRequest_SameSemantics) String

type AnalyzePlanRequest_SameSemantics_

type AnalyzePlanRequest_SameSemantics_ struct {
	SameSemantics *AnalyzePlanRequest_SameSemantics `protobuf:"bytes,12,opt,name=same_semantics,json=sameSemantics,proto3,oneof"`
}

type AnalyzePlanRequest_Schema

type AnalyzePlanRequest_Schema struct {

	// (Required) The logical plan to be analyzed.
	Plan *Plan `protobuf:"bytes,1,opt,name=plan,proto3" json:"plan,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanRequest_Schema) Descriptor deprecated

func (*AnalyzePlanRequest_Schema) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanRequest_Schema.ProtoReflect.Descriptor instead.

func (*AnalyzePlanRequest_Schema) GetPlan

func (x *AnalyzePlanRequest_Schema) GetPlan() *Plan

func (*AnalyzePlanRequest_Schema) ProtoMessage

func (*AnalyzePlanRequest_Schema) ProtoMessage()

func (*AnalyzePlanRequest_Schema) ProtoReflect

func (*AnalyzePlanRequest_Schema) Reset

func (x *AnalyzePlanRequest_Schema) Reset()

func (*AnalyzePlanRequest_Schema) String

func (x *AnalyzePlanRequest_Schema) String() string

type AnalyzePlanRequest_Schema_

type AnalyzePlanRequest_Schema_ struct {
	Schema *AnalyzePlanRequest_Schema `protobuf:"bytes,4,opt,name=schema,proto3,oneof"`
}

type AnalyzePlanRequest_SemanticHash

type AnalyzePlanRequest_SemanticHash struct {

	// (Required) The logical plan to get a hashCode.
	Plan *Plan `protobuf:"bytes,1,opt,name=plan,proto3" json:"plan,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanRequest_SemanticHash) Descriptor deprecated

func (*AnalyzePlanRequest_SemanticHash) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanRequest_SemanticHash.ProtoReflect.Descriptor instead.

func (*AnalyzePlanRequest_SemanticHash) GetPlan

func (x *AnalyzePlanRequest_SemanticHash) GetPlan() *Plan

func (*AnalyzePlanRequest_SemanticHash) ProtoMessage

func (*AnalyzePlanRequest_SemanticHash) ProtoMessage()

func (*AnalyzePlanRequest_SemanticHash) ProtoReflect

func (*AnalyzePlanRequest_SemanticHash) Reset

func (*AnalyzePlanRequest_SemanticHash) String

type AnalyzePlanRequest_SemanticHash_

type AnalyzePlanRequest_SemanticHash_ struct {
	SemanticHash *AnalyzePlanRequest_SemanticHash `protobuf:"bytes,13,opt,name=semantic_hash,json=semanticHash,proto3,oneof"`
}

type AnalyzePlanRequest_SparkVersion

type AnalyzePlanRequest_SparkVersion struct {
	// contains filtered or unexported fields
}

func (*AnalyzePlanRequest_SparkVersion) Descriptor deprecated

func (*AnalyzePlanRequest_SparkVersion) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanRequest_SparkVersion.ProtoReflect.Descriptor instead.

func (*AnalyzePlanRequest_SparkVersion) ProtoMessage

func (*AnalyzePlanRequest_SparkVersion) ProtoMessage()

func (*AnalyzePlanRequest_SparkVersion) ProtoReflect

func (*AnalyzePlanRequest_SparkVersion) Reset

func (*AnalyzePlanRequest_SparkVersion) String

type AnalyzePlanRequest_SparkVersion_

type AnalyzePlanRequest_SparkVersion_ struct {
	SparkVersion *AnalyzePlanRequest_SparkVersion `protobuf:"bytes,10,opt,name=spark_version,json=sparkVersion,proto3,oneof"`
}

type AnalyzePlanRequest_TreeString

type AnalyzePlanRequest_TreeString struct {

	// (Required) The logical plan to be analyzed.
	Plan *Plan `protobuf:"bytes,1,opt,name=plan,proto3" json:"plan,omitempty"`
	// (Optional) Max level of the schema.
	Level *int32 `protobuf:"varint,2,opt,name=level,proto3,oneof" json:"level,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanRequest_TreeString) Descriptor deprecated

func (*AnalyzePlanRequest_TreeString) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanRequest_TreeString.ProtoReflect.Descriptor instead.

func (*AnalyzePlanRequest_TreeString) GetLevel

func (x *AnalyzePlanRequest_TreeString) GetLevel() int32

func (*AnalyzePlanRequest_TreeString) GetPlan

func (x *AnalyzePlanRequest_TreeString) GetPlan() *Plan

func (*AnalyzePlanRequest_TreeString) ProtoMessage

func (*AnalyzePlanRequest_TreeString) ProtoMessage()

func (*AnalyzePlanRequest_TreeString) ProtoReflect

func (*AnalyzePlanRequest_TreeString) Reset

func (x *AnalyzePlanRequest_TreeString) Reset()

func (*AnalyzePlanRequest_TreeString) String

type AnalyzePlanRequest_TreeString_

type AnalyzePlanRequest_TreeString_ struct {
	TreeString *AnalyzePlanRequest_TreeString `protobuf:"bytes,6,opt,name=tree_string,json=treeString,proto3,oneof"`
}

type AnalyzePlanRequest_Unpersist

type AnalyzePlanRequest_Unpersist struct {

	// (Required) The logical plan to unpersist.
	Relation *Relation `protobuf:"bytes,1,opt,name=relation,proto3" json:"relation,omitempty"`
	// (Optional) Whether to block until all blocks are deleted.
	Blocking *bool `protobuf:"varint,2,opt,name=blocking,proto3,oneof" json:"blocking,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanRequest_Unpersist) Descriptor deprecated

func (*AnalyzePlanRequest_Unpersist) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanRequest_Unpersist.ProtoReflect.Descriptor instead.

func (*AnalyzePlanRequest_Unpersist) GetBlocking

func (x *AnalyzePlanRequest_Unpersist) GetBlocking() bool

func (*AnalyzePlanRequest_Unpersist) GetRelation

func (x *AnalyzePlanRequest_Unpersist) GetRelation() *Relation

func (*AnalyzePlanRequest_Unpersist) ProtoMessage

func (*AnalyzePlanRequest_Unpersist) ProtoMessage()

func (*AnalyzePlanRequest_Unpersist) ProtoReflect

func (*AnalyzePlanRequest_Unpersist) Reset

func (x *AnalyzePlanRequest_Unpersist) Reset()

func (*AnalyzePlanRequest_Unpersist) String

type AnalyzePlanRequest_Unpersist_

type AnalyzePlanRequest_Unpersist_ struct {
	Unpersist *AnalyzePlanRequest_Unpersist `protobuf:"bytes,15,opt,name=unpersist,proto3,oneof"`
}

type AnalyzePlanResponse

type AnalyzePlanResponse struct {
	SessionId string `protobuf:"bytes,1,opt,name=session_id,json=sessionId,proto3" json:"session_id,omitempty"`
	// Types that are assignable to Result:
	//
	//	*AnalyzePlanResponse_Schema_
	//	*AnalyzePlanResponse_Explain_
	//	*AnalyzePlanResponse_TreeString_
	//	*AnalyzePlanResponse_IsLocal_
	//	*AnalyzePlanResponse_IsStreaming_
	//	*AnalyzePlanResponse_InputFiles_
	//	*AnalyzePlanResponse_SparkVersion_
	//	*AnalyzePlanResponse_DdlParse
	//	*AnalyzePlanResponse_SameSemantics_
	//	*AnalyzePlanResponse_SemanticHash_
	//	*AnalyzePlanResponse_Persist_
	//	*AnalyzePlanResponse_Unpersist_
	//	*AnalyzePlanResponse_GetStorageLevel_
	Result isAnalyzePlanResponse_Result `protobuf_oneof:"result"`
	// contains filtered or unexported fields
}

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

func (*AnalyzePlanResponse) Descriptor deprecated

func (*AnalyzePlanResponse) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanResponse.ProtoReflect.Descriptor instead.

func (*AnalyzePlanResponse) GetDdlParse

func (*AnalyzePlanResponse) GetExplain

func (*AnalyzePlanResponse) GetGetStorageLevel

func (*AnalyzePlanResponse) GetInputFiles

func (*AnalyzePlanResponse) GetIsLocal

func (*AnalyzePlanResponse) GetIsStreaming

func (*AnalyzePlanResponse) GetPersist

func (*AnalyzePlanResponse) GetResult

func (m *AnalyzePlanResponse) GetResult() isAnalyzePlanResponse_Result

func (*AnalyzePlanResponse) GetSameSemantics

func (*AnalyzePlanResponse) GetSchema

func (*AnalyzePlanResponse) GetSemanticHash

func (*AnalyzePlanResponse) GetSessionId

func (x *AnalyzePlanResponse) GetSessionId() string

func (*AnalyzePlanResponse) GetSparkVersion

func (*AnalyzePlanResponse) GetTreeString

func (*AnalyzePlanResponse) GetUnpersist

func (*AnalyzePlanResponse) ProtoMessage

func (*AnalyzePlanResponse) ProtoMessage()

func (*AnalyzePlanResponse) ProtoReflect

func (x *AnalyzePlanResponse) ProtoReflect() protoreflect.Message

func (*AnalyzePlanResponse) Reset

func (x *AnalyzePlanResponse) Reset()

func (*AnalyzePlanResponse) String

func (x *AnalyzePlanResponse) String() string

type AnalyzePlanResponse_DDLParse

type AnalyzePlanResponse_DDLParse struct {
	Parsed *DataType `protobuf:"bytes,1,opt,name=parsed,proto3" json:"parsed,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanResponse_DDLParse) Descriptor deprecated

func (*AnalyzePlanResponse_DDLParse) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanResponse_DDLParse.ProtoReflect.Descriptor instead.

func (*AnalyzePlanResponse_DDLParse) GetParsed

func (x *AnalyzePlanResponse_DDLParse) GetParsed() *DataType

func (*AnalyzePlanResponse_DDLParse) ProtoMessage

func (*AnalyzePlanResponse_DDLParse) ProtoMessage()

func (*AnalyzePlanResponse_DDLParse) ProtoReflect

func (*AnalyzePlanResponse_DDLParse) Reset

func (x *AnalyzePlanResponse_DDLParse) Reset()

func (*AnalyzePlanResponse_DDLParse) String

type AnalyzePlanResponse_DdlParse

type AnalyzePlanResponse_DdlParse struct {
	DdlParse *AnalyzePlanResponse_DDLParse `protobuf:"bytes,9,opt,name=ddl_parse,json=ddlParse,proto3,oneof"`
}

type AnalyzePlanResponse_Explain

type AnalyzePlanResponse_Explain struct {
	ExplainString string `protobuf:"bytes,1,opt,name=explain_string,json=explainString,proto3" json:"explain_string,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanResponse_Explain) Descriptor deprecated

func (*AnalyzePlanResponse_Explain) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanResponse_Explain.ProtoReflect.Descriptor instead.

func (*AnalyzePlanResponse_Explain) GetExplainString

func (x *AnalyzePlanResponse_Explain) GetExplainString() string

func (*AnalyzePlanResponse_Explain) ProtoMessage

func (*AnalyzePlanResponse_Explain) ProtoMessage()

func (*AnalyzePlanResponse_Explain) ProtoReflect

func (*AnalyzePlanResponse_Explain) Reset

func (x *AnalyzePlanResponse_Explain) Reset()

func (*AnalyzePlanResponse_Explain) String

func (x *AnalyzePlanResponse_Explain) String() string

type AnalyzePlanResponse_Explain_

type AnalyzePlanResponse_Explain_ struct {
	Explain *AnalyzePlanResponse_Explain `protobuf:"bytes,3,opt,name=explain,proto3,oneof"`
}

type AnalyzePlanResponse_GetStorageLevel

type AnalyzePlanResponse_GetStorageLevel struct {

	// (Required) The StorageLevel as a result of get_storage_level request.
	StorageLevel *StorageLevel `protobuf:"bytes,1,opt,name=storage_level,json=storageLevel,proto3" json:"storage_level,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanResponse_GetStorageLevel) Descriptor deprecated

func (*AnalyzePlanResponse_GetStorageLevel) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanResponse_GetStorageLevel.ProtoReflect.Descriptor instead.

func (*AnalyzePlanResponse_GetStorageLevel) GetStorageLevel

func (x *AnalyzePlanResponse_GetStorageLevel) GetStorageLevel() *StorageLevel

func (*AnalyzePlanResponse_GetStorageLevel) ProtoMessage

func (*AnalyzePlanResponse_GetStorageLevel) ProtoMessage()

func (*AnalyzePlanResponse_GetStorageLevel) ProtoReflect

func (*AnalyzePlanResponse_GetStorageLevel) Reset

func (*AnalyzePlanResponse_GetStorageLevel) String

type AnalyzePlanResponse_GetStorageLevel_

type AnalyzePlanResponse_GetStorageLevel_ struct {
	GetStorageLevel *AnalyzePlanResponse_GetStorageLevel `protobuf:"bytes,14,opt,name=get_storage_level,json=getStorageLevel,proto3,oneof"`
}

type AnalyzePlanResponse_InputFiles

type AnalyzePlanResponse_InputFiles struct {

	// A best-effort snapshot of the files that compose this Dataset
	Files []string `protobuf:"bytes,1,rep,name=files,proto3" json:"files,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanResponse_InputFiles) Descriptor deprecated

func (*AnalyzePlanResponse_InputFiles) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanResponse_InputFiles.ProtoReflect.Descriptor instead.

func (*AnalyzePlanResponse_InputFiles) GetFiles

func (x *AnalyzePlanResponse_InputFiles) GetFiles() []string

func (*AnalyzePlanResponse_InputFiles) ProtoMessage

func (*AnalyzePlanResponse_InputFiles) ProtoMessage()

func (*AnalyzePlanResponse_InputFiles) ProtoReflect

func (*AnalyzePlanResponse_InputFiles) Reset

func (x *AnalyzePlanResponse_InputFiles) Reset()

func (*AnalyzePlanResponse_InputFiles) String

type AnalyzePlanResponse_InputFiles_

type AnalyzePlanResponse_InputFiles_ struct {
	InputFiles *AnalyzePlanResponse_InputFiles `protobuf:"bytes,7,opt,name=input_files,json=inputFiles,proto3,oneof"`
}

type AnalyzePlanResponse_IsLocal

type AnalyzePlanResponse_IsLocal struct {
	IsLocal bool `protobuf:"varint,1,opt,name=is_local,json=isLocal,proto3" json:"is_local,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanResponse_IsLocal) Descriptor deprecated

func (*AnalyzePlanResponse_IsLocal) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanResponse_IsLocal.ProtoReflect.Descriptor instead.

func (*AnalyzePlanResponse_IsLocal) GetIsLocal

func (x *AnalyzePlanResponse_IsLocal) GetIsLocal() bool

func (*AnalyzePlanResponse_IsLocal) ProtoMessage

func (*AnalyzePlanResponse_IsLocal) ProtoMessage()

func (*AnalyzePlanResponse_IsLocal) ProtoReflect

func (*AnalyzePlanResponse_IsLocal) Reset

func (x *AnalyzePlanResponse_IsLocal) Reset()

func (*AnalyzePlanResponse_IsLocal) String

func (x *AnalyzePlanResponse_IsLocal) String() string

type AnalyzePlanResponse_IsLocal_

type AnalyzePlanResponse_IsLocal_ struct {
	IsLocal *AnalyzePlanResponse_IsLocal `protobuf:"bytes,5,opt,name=is_local,json=isLocal,proto3,oneof"`
}

type AnalyzePlanResponse_IsStreaming

type AnalyzePlanResponse_IsStreaming struct {
	IsStreaming bool `protobuf:"varint,1,opt,name=is_streaming,json=isStreaming,proto3" json:"is_streaming,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanResponse_IsStreaming) Descriptor deprecated

func (*AnalyzePlanResponse_IsStreaming) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanResponse_IsStreaming.ProtoReflect.Descriptor instead.

func (*AnalyzePlanResponse_IsStreaming) GetIsStreaming

func (x *AnalyzePlanResponse_IsStreaming) GetIsStreaming() bool

func (*AnalyzePlanResponse_IsStreaming) ProtoMessage

func (*AnalyzePlanResponse_IsStreaming) ProtoMessage()

func (*AnalyzePlanResponse_IsStreaming) ProtoReflect

func (*AnalyzePlanResponse_IsStreaming) Reset

func (*AnalyzePlanResponse_IsStreaming) String

type AnalyzePlanResponse_IsStreaming_

type AnalyzePlanResponse_IsStreaming_ struct {
	IsStreaming *AnalyzePlanResponse_IsStreaming `protobuf:"bytes,6,opt,name=is_streaming,json=isStreaming,proto3,oneof"`
}

type AnalyzePlanResponse_Persist

type AnalyzePlanResponse_Persist struct {
	// contains filtered or unexported fields
}

func (*AnalyzePlanResponse_Persist) Descriptor deprecated

func (*AnalyzePlanResponse_Persist) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanResponse_Persist.ProtoReflect.Descriptor instead.

func (*AnalyzePlanResponse_Persist) ProtoMessage

func (*AnalyzePlanResponse_Persist) ProtoMessage()

func (*AnalyzePlanResponse_Persist) ProtoReflect

func (*AnalyzePlanResponse_Persist) Reset

func (x *AnalyzePlanResponse_Persist) Reset()

func (*AnalyzePlanResponse_Persist) String

func (x *AnalyzePlanResponse_Persist) String() string

type AnalyzePlanResponse_Persist_

type AnalyzePlanResponse_Persist_ struct {
	Persist *AnalyzePlanResponse_Persist `protobuf:"bytes,12,opt,name=persist,proto3,oneof"`
}

type AnalyzePlanResponse_SameSemantics

type AnalyzePlanResponse_SameSemantics struct {
	Result bool `protobuf:"varint,1,opt,name=result,proto3" json:"result,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanResponse_SameSemantics) Descriptor deprecated

func (*AnalyzePlanResponse_SameSemantics) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanResponse_SameSemantics.ProtoReflect.Descriptor instead.

func (*AnalyzePlanResponse_SameSemantics) GetResult

func (x *AnalyzePlanResponse_SameSemantics) GetResult() bool

func (*AnalyzePlanResponse_SameSemantics) ProtoMessage

func (*AnalyzePlanResponse_SameSemantics) ProtoMessage()

func (*AnalyzePlanResponse_SameSemantics) ProtoReflect

func (*AnalyzePlanResponse_SameSemantics) Reset

func (*AnalyzePlanResponse_SameSemantics) String

type AnalyzePlanResponse_SameSemantics_

type AnalyzePlanResponse_SameSemantics_ struct {
	SameSemantics *AnalyzePlanResponse_SameSemantics `protobuf:"bytes,10,opt,name=same_semantics,json=sameSemantics,proto3,oneof"`
}

type AnalyzePlanResponse_Schema

type AnalyzePlanResponse_Schema struct {
	Schema *DataType `protobuf:"bytes,1,opt,name=schema,proto3" json:"schema,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanResponse_Schema) Descriptor deprecated

func (*AnalyzePlanResponse_Schema) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanResponse_Schema.ProtoReflect.Descriptor instead.

func (*AnalyzePlanResponse_Schema) GetSchema

func (x *AnalyzePlanResponse_Schema) GetSchema() *DataType

func (*AnalyzePlanResponse_Schema) ProtoMessage

func (*AnalyzePlanResponse_Schema) ProtoMessage()

func (*AnalyzePlanResponse_Schema) ProtoReflect

func (*AnalyzePlanResponse_Schema) Reset

func (x *AnalyzePlanResponse_Schema) Reset()

func (*AnalyzePlanResponse_Schema) String

func (x *AnalyzePlanResponse_Schema) String() string

type AnalyzePlanResponse_Schema_

type AnalyzePlanResponse_Schema_ struct {
	Schema *AnalyzePlanResponse_Schema `protobuf:"bytes,2,opt,name=schema,proto3,oneof"`
}

type AnalyzePlanResponse_SemanticHash

type AnalyzePlanResponse_SemanticHash struct {
	Result int32 `protobuf:"varint,1,opt,name=result,proto3" json:"result,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanResponse_SemanticHash) Descriptor deprecated

func (*AnalyzePlanResponse_SemanticHash) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanResponse_SemanticHash.ProtoReflect.Descriptor instead.

func (*AnalyzePlanResponse_SemanticHash) GetResult

func (x *AnalyzePlanResponse_SemanticHash) GetResult() int32

func (*AnalyzePlanResponse_SemanticHash) ProtoMessage

func (*AnalyzePlanResponse_SemanticHash) ProtoMessage()

func (*AnalyzePlanResponse_SemanticHash) ProtoReflect

func (*AnalyzePlanResponse_SemanticHash) Reset

func (*AnalyzePlanResponse_SemanticHash) String

type AnalyzePlanResponse_SemanticHash_

type AnalyzePlanResponse_SemanticHash_ struct {
	SemanticHash *AnalyzePlanResponse_SemanticHash `protobuf:"bytes,11,opt,name=semantic_hash,json=semanticHash,proto3,oneof"`
}

type AnalyzePlanResponse_SparkVersion

type AnalyzePlanResponse_SparkVersion struct {
	Version string `protobuf:"bytes,1,opt,name=version,proto3" json:"version,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanResponse_SparkVersion) Descriptor deprecated

func (*AnalyzePlanResponse_SparkVersion) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanResponse_SparkVersion.ProtoReflect.Descriptor instead.

func (*AnalyzePlanResponse_SparkVersion) GetVersion

func (x *AnalyzePlanResponse_SparkVersion) GetVersion() string

func (*AnalyzePlanResponse_SparkVersion) ProtoMessage

func (*AnalyzePlanResponse_SparkVersion) ProtoMessage()

func (*AnalyzePlanResponse_SparkVersion) ProtoReflect

func (*AnalyzePlanResponse_SparkVersion) Reset

func (*AnalyzePlanResponse_SparkVersion) String

type AnalyzePlanResponse_SparkVersion_

type AnalyzePlanResponse_SparkVersion_ struct {
	SparkVersion *AnalyzePlanResponse_SparkVersion `protobuf:"bytes,8,opt,name=spark_version,json=sparkVersion,proto3,oneof"`
}

type AnalyzePlanResponse_TreeString

type AnalyzePlanResponse_TreeString struct {
	TreeString string `protobuf:"bytes,1,opt,name=tree_string,json=treeString,proto3" json:"tree_string,omitempty"`
	// contains filtered or unexported fields
}

func (*AnalyzePlanResponse_TreeString) Descriptor deprecated

func (*AnalyzePlanResponse_TreeString) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanResponse_TreeString.ProtoReflect.Descriptor instead.

func (*AnalyzePlanResponse_TreeString) GetTreeString

func (x *AnalyzePlanResponse_TreeString) GetTreeString() string

func (*AnalyzePlanResponse_TreeString) ProtoMessage

func (*AnalyzePlanResponse_TreeString) ProtoMessage()

func (*AnalyzePlanResponse_TreeString) ProtoReflect

func (*AnalyzePlanResponse_TreeString) Reset

func (x *AnalyzePlanResponse_TreeString) Reset()

func (*AnalyzePlanResponse_TreeString) String

type AnalyzePlanResponse_TreeString_

type AnalyzePlanResponse_TreeString_ struct {
	TreeString *AnalyzePlanResponse_TreeString `protobuf:"bytes,4,opt,name=tree_string,json=treeString,proto3,oneof"`
}

type AnalyzePlanResponse_Unpersist

type AnalyzePlanResponse_Unpersist struct {
	// contains filtered or unexported fields
}

func (*AnalyzePlanResponse_Unpersist) Descriptor deprecated

func (*AnalyzePlanResponse_Unpersist) Descriptor() ([]byte, []int)

Deprecated: Use AnalyzePlanResponse_Unpersist.ProtoReflect.Descriptor instead.

func (*AnalyzePlanResponse_Unpersist) ProtoMessage

func (*AnalyzePlanResponse_Unpersist) ProtoMessage()

func (*AnalyzePlanResponse_Unpersist) ProtoReflect

func (*AnalyzePlanResponse_Unpersist) Reset

func (x *AnalyzePlanResponse_Unpersist) Reset()

func (*AnalyzePlanResponse_Unpersist) String

type AnalyzePlanResponse_Unpersist_

type AnalyzePlanResponse_Unpersist_ struct {
	Unpersist *AnalyzePlanResponse_Unpersist `protobuf:"bytes,13,opt,name=unpersist,proto3,oneof"`
}

type ApplyInPandasWithState

type ApplyInPandasWithState struct {

	// (Required) Input relation for applyInPandasWithState.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) Expressions for grouping keys.
	GroupingExpressions []*Expression `protobuf:"bytes,2,rep,name=grouping_expressions,json=groupingExpressions,proto3" json:"grouping_expressions,omitempty"`
	// (Required) Input user-defined function.
	Func *CommonInlineUserDefinedFunction `protobuf:"bytes,3,opt,name=func,proto3" json:"func,omitempty"`
	// (Required) Schema for the output DataFrame.
	OutputSchema string `protobuf:"bytes,4,opt,name=output_schema,json=outputSchema,proto3" json:"output_schema,omitempty"`
	// (Required) Schema for the state.
	StateSchema string `protobuf:"bytes,5,opt,name=state_schema,json=stateSchema,proto3" json:"state_schema,omitempty"`
	// (Required) The output mode of the function.
	OutputMode string `protobuf:"bytes,6,opt,name=output_mode,json=outputMode,proto3" json:"output_mode,omitempty"`
	// (Required) Timeout configuration for groups that do not receive data for a while.
	TimeoutConf string `protobuf:"bytes,7,opt,name=timeout_conf,json=timeoutConf,proto3" json:"timeout_conf,omitempty"`
	// contains filtered or unexported fields
}

func (*ApplyInPandasWithState) Descriptor deprecated

func (*ApplyInPandasWithState) Descriptor() ([]byte, []int)

Deprecated: Use ApplyInPandasWithState.ProtoReflect.Descriptor instead.

func (*ApplyInPandasWithState) GetFunc

func (*ApplyInPandasWithState) GetGroupingExpressions

func (x *ApplyInPandasWithState) GetGroupingExpressions() []*Expression

func (*ApplyInPandasWithState) GetInput

func (x *ApplyInPandasWithState) GetInput() *Relation

func (*ApplyInPandasWithState) GetOutputMode

func (x *ApplyInPandasWithState) GetOutputMode() string

func (*ApplyInPandasWithState) GetOutputSchema

func (x *ApplyInPandasWithState) GetOutputSchema() string

func (*ApplyInPandasWithState) GetStateSchema

func (x *ApplyInPandasWithState) GetStateSchema() string

func (*ApplyInPandasWithState) GetTimeoutConf

func (x *ApplyInPandasWithState) GetTimeoutConf() string

func (*ApplyInPandasWithState) ProtoMessage

func (*ApplyInPandasWithState) ProtoMessage()

func (*ApplyInPandasWithState) ProtoReflect

func (x *ApplyInPandasWithState) ProtoReflect() protoreflect.Message

func (*ApplyInPandasWithState) Reset

func (x *ApplyInPandasWithState) Reset()

func (*ApplyInPandasWithState) String

func (x *ApplyInPandasWithState) String() string

type ArtifactStatusesRequest

type ArtifactStatusesRequest struct {

	// (Required)
	//
	// The session_id specifies a spark session for a user id (which is specified
	// by user_context.user_id). The session_id is set by the client to be able to
	// collate streaming responses from different queries within the dedicated session.
	SessionId string `protobuf:"bytes,1,opt,name=session_id,json=sessionId,proto3" json:"session_id,omitempty"`
	// User context
	UserContext *UserContext `protobuf:"bytes,2,opt,name=user_context,json=userContext,proto3" json:"user_context,omitempty"`
	// Provides optional information about the client sending the request. This field
	// can be used for language or version specific information and is only intended for
	// logging purposes and will not be interpreted by the server.
	ClientType *string `protobuf:"bytes,3,opt,name=client_type,json=clientType,proto3,oneof" json:"client_type,omitempty"`
	// The name of the artifact is expected in the form of a "Relative Path" that is made up of a
	// sequence of directories and the final file element.
	// Examples of "Relative Path"s: "jars/test.jar", "classes/xyz.class", "abc.xyz", "a/b/X.jar".
	// The server is expected to maintain the hierarchy of files as defined by their name. (i.e
	// The relative path of the file on the server's filesystem will be the same as the name of
	// the provided artifact)
	Names []string `protobuf:"bytes,4,rep,name=names,proto3" json:"names,omitempty"`
	// contains filtered or unexported fields
}

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

func (*ArtifactStatusesRequest) Descriptor deprecated

func (*ArtifactStatusesRequest) Descriptor() ([]byte, []int)

Deprecated: Use ArtifactStatusesRequest.ProtoReflect.Descriptor instead.

func (*ArtifactStatusesRequest) GetClientType

func (x *ArtifactStatusesRequest) GetClientType() string

func (*ArtifactStatusesRequest) GetNames

func (x *ArtifactStatusesRequest) GetNames() []string

func (*ArtifactStatusesRequest) GetSessionId

func (x *ArtifactStatusesRequest) GetSessionId() string

func (*ArtifactStatusesRequest) GetUserContext

func (x *ArtifactStatusesRequest) GetUserContext() *UserContext

func (*ArtifactStatusesRequest) ProtoMessage

func (*ArtifactStatusesRequest) ProtoMessage()

func (*ArtifactStatusesRequest) ProtoReflect

func (x *ArtifactStatusesRequest) ProtoReflect() protoreflect.Message

func (*ArtifactStatusesRequest) Reset

func (x *ArtifactStatusesRequest) Reset()

func (*ArtifactStatusesRequest) String

func (x *ArtifactStatusesRequest) String() string

type ArtifactStatusesResponse

type ArtifactStatusesResponse struct {

	// A map of artifact names to their statuses.
	Statuses map[string]*ArtifactStatusesResponse_ArtifactStatus `` /* 157-byte string literal not displayed */
	// contains filtered or unexported fields
}

Response to checking artifact statuses.

func (*ArtifactStatusesResponse) Descriptor deprecated

func (*ArtifactStatusesResponse) Descriptor() ([]byte, []int)

Deprecated: Use ArtifactStatusesResponse.ProtoReflect.Descriptor instead.

func (*ArtifactStatusesResponse) GetStatuses

func (*ArtifactStatusesResponse) ProtoMessage

func (*ArtifactStatusesResponse) ProtoMessage()

func (*ArtifactStatusesResponse) ProtoReflect

func (x *ArtifactStatusesResponse) ProtoReflect() protoreflect.Message

func (*ArtifactStatusesResponse) Reset

func (x *ArtifactStatusesResponse) Reset()

func (*ArtifactStatusesResponse) String

func (x *ArtifactStatusesResponse) String() string

type ArtifactStatusesResponse_ArtifactStatus

type ArtifactStatusesResponse_ArtifactStatus struct {

	// Exists or not particular artifact at the server.
	Exists bool `protobuf:"varint,1,opt,name=exists,proto3" json:"exists,omitempty"`
	// contains filtered or unexported fields
}

func (*ArtifactStatusesResponse_ArtifactStatus) Descriptor deprecated

func (*ArtifactStatusesResponse_ArtifactStatus) Descriptor() ([]byte, []int)

Deprecated: Use ArtifactStatusesResponse_ArtifactStatus.ProtoReflect.Descriptor instead.

func (*ArtifactStatusesResponse_ArtifactStatus) GetExists

func (*ArtifactStatusesResponse_ArtifactStatus) ProtoMessage

func (*ArtifactStatusesResponse_ArtifactStatus) ProtoReflect

func (*ArtifactStatusesResponse_ArtifactStatus) Reset

func (*ArtifactStatusesResponse_ArtifactStatus) String

type CacheTable

type CacheTable struct {

	// (Required)
	TableName string `protobuf:"bytes,1,opt,name=table_name,json=tableName,proto3" json:"table_name,omitempty"`
	// (Optional)
	StorageLevel *StorageLevel `protobuf:"bytes,2,opt,name=storage_level,json=storageLevel,proto3,oneof" json:"storage_level,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.cacheTable`

func (*CacheTable) Descriptor deprecated

func (*CacheTable) Descriptor() ([]byte, []int)

Deprecated: Use CacheTable.ProtoReflect.Descriptor instead.

func (*CacheTable) GetStorageLevel

func (x *CacheTable) GetStorageLevel() *StorageLevel

func (*CacheTable) GetTableName

func (x *CacheTable) GetTableName() string

func (*CacheTable) ProtoMessage

func (*CacheTable) ProtoMessage()

func (*CacheTable) ProtoReflect

func (x *CacheTable) ProtoReflect() protoreflect.Message

func (*CacheTable) Reset

func (x *CacheTable) Reset()

func (*CacheTable) String

func (x *CacheTable) String() string

type CachedLocalRelation

type CachedLocalRelation struct {

	// (Required) An identifier of the user which created the local relation
	UserId string `protobuf:"bytes,1,opt,name=userId,proto3" json:"userId,omitempty"`
	// (Required) An identifier of the Spark SQL session in which the user created the local relation.
	SessionId string `protobuf:"bytes,2,opt,name=sessionId,proto3" json:"sessionId,omitempty"`
	// (Required) A sha-256 hash of the serialized local relation in proto, see LocalRelation.
	Hash string `protobuf:"bytes,3,opt,name=hash,proto3" json:"hash,omitempty"`
	// contains filtered or unexported fields
}

A local relation that has been cached already.

func (*CachedLocalRelation) Descriptor deprecated

func (*CachedLocalRelation) Descriptor() ([]byte, []int)

Deprecated: Use CachedLocalRelation.ProtoReflect.Descriptor instead.

func (*CachedLocalRelation) GetHash

func (x *CachedLocalRelation) GetHash() string

func (*CachedLocalRelation) GetSessionId

func (x *CachedLocalRelation) GetSessionId() string

func (*CachedLocalRelation) GetUserId

func (x *CachedLocalRelation) GetUserId() string

func (*CachedLocalRelation) ProtoMessage

func (*CachedLocalRelation) ProtoMessage()

func (*CachedLocalRelation) ProtoReflect

func (x *CachedLocalRelation) ProtoReflect() protoreflect.Message

func (*CachedLocalRelation) Reset

func (x *CachedLocalRelation) Reset()

func (*CachedLocalRelation) String

func (x *CachedLocalRelation) String() string

type Catalog

type Catalog struct {

	// Types that are assignable to CatType:
	//
	//	*Catalog_CurrentDatabase
	//	*Catalog_SetCurrentDatabase
	//	*Catalog_ListDatabases
	//	*Catalog_ListTables
	//	*Catalog_ListFunctions
	//	*Catalog_ListColumns
	//	*Catalog_GetDatabase
	//	*Catalog_GetTable
	//	*Catalog_GetFunction
	//	*Catalog_DatabaseExists
	//	*Catalog_TableExists
	//	*Catalog_FunctionExists
	//	*Catalog_CreateExternalTable
	//	*Catalog_CreateTable
	//	*Catalog_DropTempView
	//	*Catalog_DropGlobalTempView
	//	*Catalog_RecoverPartitions
	//	*Catalog_IsCached
	//	*Catalog_CacheTable
	//	*Catalog_UncacheTable
	//	*Catalog_ClearCache
	//	*Catalog_RefreshTable
	//	*Catalog_RefreshByPath
	//	*Catalog_CurrentCatalog
	//	*Catalog_SetCurrentCatalog
	//	*Catalog_ListCatalogs
	CatType isCatalog_CatType `protobuf_oneof:"cat_type"`
	// contains filtered or unexported fields
}

Catalog messages are marked as unstable.

func (*Catalog) Descriptor deprecated

func (*Catalog) Descriptor() ([]byte, []int)

Deprecated: Use Catalog.ProtoReflect.Descriptor instead.

func (*Catalog) GetCacheTable

func (x *Catalog) GetCacheTable() *CacheTable

func (*Catalog) GetCatType

func (m *Catalog) GetCatType() isCatalog_CatType

func (*Catalog) GetClearCache

func (x *Catalog) GetClearCache() *ClearCache

func (*Catalog) GetCreateExternalTable

func (x *Catalog) GetCreateExternalTable() *CreateExternalTable

func (*Catalog) GetCreateTable

func (x *Catalog) GetCreateTable() *CreateTable

func (*Catalog) GetCurrentCatalog

func (x *Catalog) GetCurrentCatalog() *CurrentCatalog

func (*Catalog) GetCurrentDatabase

func (x *Catalog) GetCurrentDatabase() *CurrentDatabase

func (*Catalog) GetDatabaseExists

func (x *Catalog) GetDatabaseExists() *DatabaseExists

func (*Catalog) GetDropGlobalTempView

func (x *Catalog) GetDropGlobalTempView() *DropGlobalTempView

func (*Catalog) GetDropTempView

func (x *Catalog) GetDropTempView() *DropTempView

func (*Catalog) GetFunctionExists

func (x *Catalog) GetFunctionExists() *FunctionExists

func (*Catalog) GetGetDatabase

func (x *Catalog) GetGetDatabase() *GetDatabase

func (*Catalog) GetGetFunction

func (x *Catalog) GetGetFunction() *GetFunction

func (*Catalog) GetGetTable

func (x *Catalog) GetGetTable() *GetTable

func (*Catalog) GetIsCached

func (x *Catalog) GetIsCached() *IsCached

func (*Catalog) GetListCatalogs

func (x *Catalog) GetListCatalogs() *ListCatalogs

func (*Catalog) GetListColumns

func (x *Catalog) GetListColumns() *ListColumns

func (*Catalog) GetListDatabases

func (x *Catalog) GetListDatabases() *ListDatabases

func (*Catalog) GetListFunctions

func (x *Catalog) GetListFunctions() *ListFunctions

func (*Catalog) GetListTables

func (x *Catalog) GetListTables() *ListTables

func (*Catalog) GetRecoverPartitions

func (x *Catalog) GetRecoverPartitions() *RecoverPartitions

func (*Catalog) GetRefreshByPath

func (x *Catalog) GetRefreshByPath() *RefreshByPath

func (*Catalog) GetRefreshTable

func (x *Catalog) GetRefreshTable() *RefreshTable

func (*Catalog) GetSetCurrentCatalog

func (x *Catalog) GetSetCurrentCatalog() *SetCurrentCatalog

func (*Catalog) GetSetCurrentDatabase

func (x *Catalog) GetSetCurrentDatabase() *SetCurrentDatabase

func (*Catalog) GetTableExists

func (x *Catalog) GetTableExists() *TableExists

func (*Catalog) GetUncacheTable

func (x *Catalog) GetUncacheTable() *UncacheTable

func (*Catalog) ProtoMessage

func (*Catalog) ProtoMessage()

func (*Catalog) ProtoReflect

func (x *Catalog) ProtoReflect() protoreflect.Message

func (*Catalog) Reset

func (x *Catalog) Reset()

func (*Catalog) String

func (x *Catalog) String() string

type Catalog_CacheTable

type Catalog_CacheTable struct {
	CacheTable *CacheTable `protobuf:"bytes,19,opt,name=cache_table,json=cacheTable,proto3,oneof"`
}

type Catalog_ClearCache

type Catalog_ClearCache struct {
	ClearCache *ClearCache `protobuf:"bytes,21,opt,name=clear_cache,json=clearCache,proto3,oneof"`
}

type Catalog_CreateExternalTable

type Catalog_CreateExternalTable struct {
	CreateExternalTable *CreateExternalTable `protobuf:"bytes,13,opt,name=create_external_table,json=createExternalTable,proto3,oneof"`
}

type Catalog_CreateTable

type Catalog_CreateTable struct {
	CreateTable *CreateTable `protobuf:"bytes,14,opt,name=create_table,json=createTable,proto3,oneof"`
}

type Catalog_CurrentCatalog

type Catalog_CurrentCatalog struct {
	CurrentCatalog *CurrentCatalog `protobuf:"bytes,24,opt,name=current_catalog,json=currentCatalog,proto3,oneof"`
}

type Catalog_CurrentDatabase

type Catalog_CurrentDatabase struct {
	CurrentDatabase *CurrentDatabase `protobuf:"bytes,1,opt,name=current_database,json=currentDatabase,proto3,oneof"`
}

type Catalog_DatabaseExists

type Catalog_DatabaseExists struct {
	DatabaseExists *DatabaseExists `protobuf:"bytes,10,opt,name=database_exists,json=databaseExists,proto3,oneof"`
}

type Catalog_DropGlobalTempView

type Catalog_DropGlobalTempView struct {
	DropGlobalTempView *DropGlobalTempView `protobuf:"bytes,16,opt,name=drop_global_temp_view,json=dropGlobalTempView,proto3,oneof"`
}

type Catalog_DropTempView

type Catalog_DropTempView struct {
	DropTempView *DropTempView `protobuf:"bytes,15,opt,name=drop_temp_view,json=dropTempView,proto3,oneof"`
}

type Catalog_FunctionExists

type Catalog_FunctionExists struct {
	FunctionExists *FunctionExists `protobuf:"bytes,12,opt,name=function_exists,json=functionExists,proto3,oneof"`
}

type Catalog_GetDatabase

type Catalog_GetDatabase struct {
	GetDatabase *GetDatabase `protobuf:"bytes,7,opt,name=get_database,json=getDatabase,proto3,oneof"`
}

type Catalog_GetFunction

type Catalog_GetFunction struct {
	GetFunction *GetFunction `protobuf:"bytes,9,opt,name=get_function,json=getFunction,proto3,oneof"`
}

type Catalog_GetTable

type Catalog_GetTable struct {
	GetTable *GetTable `protobuf:"bytes,8,opt,name=get_table,json=getTable,proto3,oneof"`
}

type Catalog_IsCached

type Catalog_IsCached struct {
	IsCached *IsCached `protobuf:"bytes,18,opt,name=is_cached,json=isCached,proto3,oneof"`
}

type Catalog_ListCatalogs

type Catalog_ListCatalogs struct {
	ListCatalogs *ListCatalogs `protobuf:"bytes,26,opt,name=list_catalogs,json=listCatalogs,proto3,oneof"`
}

type Catalog_ListColumns

type Catalog_ListColumns struct {
	ListColumns *ListColumns `protobuf:"bytes,6,opt,name=list_columns,json=listColumns,proto3,oneof"`
}

type Catalog_ListDatabases

type Catalog_ListDatabases struct {
	ListDatabases *ListDatabases `protobuf:"bytes,3,opt,name=list_databases,json=listDatabases,proto3,oneof"`
}

type Catalog_ListFunctions

type Catalog_ListFunctions struct {
	ListFunctions *ListFunctions `protobuf:"bytes,5,opt,name=list_functions,json=listFunctions,proto3,oneof"`
}

type Catalog_ListTables

type Catalog_ListTables struct {
	ListTables *ListTables `protobuf:"bytes,4,opt,name=list_tables,json=listTables,proto3,oneof"`
}

type Catalog_RecoverPartitions

type Catalog_RecoverPartitions struct {
	RecoverPartitions *RecoverPartitions `protobuf:"bytes,17,opt,name=recover_partitions,json=recoverPartitions,proto3,oneof"`
}

type Catalog_RefreshByPath

type Catalog_RefreshByPath struct {
	RefreshByPath *RefreshByPath `protobuf:"bytes,23,opt,name=refresh_by_path,json=refreshByPath,proto3,oneof"`
}

type Catalog_RefreshTable

type Catalog_RefreshTable struct {
	RefreshTable *RefreshTable `protobuf:"bytes,22,opt,name=refresh_table,json=refreshTable,proto3,oneof"`
}

type Catalog_SetCurrentCatalog

type Catalog_SetCurrentCatalog struct {
	SetCurrentCatalog *SetCurrentCatalog `protobuf:"bytes,25,opt,name=set_current_catalog,json=setCurrentCatalog,proto3,oneof"`
}

type Catalog_SetCurrentDatabase

type Catalog_SetCurrentDatabase struct {
	SetCurrentDatabase *SetCurrentDatabase `protobuf:"bytes,2,opt,name=set_current_database,json=setCurrentDatabase,proto3,oneof"`
}

type Catalog_TableExists

type Catalog_TableExists struct {
	TableExists *TableExists `protobuf:"bytes,11,opt,name=table_exists,json=tableExists,proto3,oneof"`
}

type Catalog_UncacheTable

type Catalog_UncacheTable struct {
	UncacheTable *UncacheTable `protobuf:"bytes,20,opt,name=uncache_table,json=uncacheTable,proto3,oneof"`
}

type ClearCache

type ClearCache struct {
	// contains filtered or unexported fields
}

See `spark.catalog.clearCache`

func (*ClearCache) Descriptor deprecated

func (*ClearCache) Descriptor() ([]byte, []int)

Deprecated: Use ClearCache.ProtoReflect.Descriptor instead.

func (*ClearCache) ProtoMessage

func (*ClearCache) ProtoMessage()

func (*ClearCache) ProtoReflect

func (x *ClearCache) ProtoReflect() protoreflect.Message

func (*ClearCache) Reset

func (x *ClearCache) Reset()

func (*ClearCache) String

func (x *ClearCache) String() string

type CoGroupMap

type CoGroupMap struct {

	// (Required) One input relation for CoGroup Map API - applyInPandas.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// Expressions for grouping keys of the first input relation.
	InputGroupingExpressions []*Expression `` /* 135-byte string literal not displayed */
	// (Required) The other input relation.
	Other *Relation `protobuf:"bytes,3,opt,name=other,proto3" json:"other,omitempty"`
	// Expressions for grouping keys of the other input relation.
	OtherGroupingExpressions []*Expression `` /* 135-byte string literal not displayed */
	// (Required) Input user-defined function.
	Func *CommonInlineUserDefinedFunction `protobuf:"bytes,5,opt,name=func,proto3" json:"func,omitempty"`
	// (Optional) Expressions for sorting. Only used by Scala Sorted CoGroup Map API.
	InputSortingExpressions []*Expression `` /* 132-byte string literal not displayed */
	// (Optional) Expressions for sorting. Only used by Scala Sorted CoGroup Map API.
	OtherSortingExpressions []*Expression `` /* 132-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*CoGroupMap) Descriptor deprecated

func (*CoGroupMap) Descriptor() ([]byte, []int)

Deprecated: Use CoGroupMap.ProtoReflect.Descriptor instead.

func (*CoGroupMap) GetFunc

func (*CoGroupMap) GetInput

func (x *CoGroupMap) GetInput() *Relation

func (*CoGroupMap) GetInputGroupingExpressions

func (x *CoGroupMap) GetInputGroupingExpressions() []*Expression

func (*CoGroupMap) GetInputSortingExpressions

func (x *CoGroupMap) GetInputSortingExpressions() []*Expression

func (*CoGroupMap) GetOther

func (x *CoGroupMap) GetOther() *Relation

func (*CoGroupMap) GetOtherGroupingExpressions

func (x *CoGroupMap) GetOtherGroupingExpressions() []*Expression

func (*CoGroupMap) GetOtherSortingExpressions

func (x *CoGroupMap) GetOtherSortingExpressions() []*Expression

func (*CoGroupMap) ProtoMessage

func (*CoGroupMap) ProtoMessage()

func (*CoGroupMap) ProtoReflect

func (x *CoGroupMap) ProtoReflect() protoreflect.Message

func (*CoGroupMap) Reset

func (x *CoGroupMap) Reset()

func (*CoGroupMap) String

func (x *CoGroupMap) String() string

type CollectMetrics

type CollectMetrics struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) Name of the metrics.
	Name string `protobuf:"bytes,2,opt,name=name,proto3" json:"name,omitempty"`
	// (Required) The metric sequence.
	Metrics []*Expression `protobuf:"bytes,3,rep,name=metrics,proto3" json:"metrics,omitempty"`
	// contains filtered or unexported fields
}

Collect arbitrary (named) metrics from a dataset.

func (*CollectMetrics) Descriptor deprecated

func (*CollectMetrics) Descriptor() ([]byte, []int)

Deprecated: Use CollectMetrics.ProtoReflect.Descriptor instead.

func (*CollectMetrics) GetInput

func (x *CollectMetrics) GetInput() *Relation

func (*CollectMetrics) GetMetrics

func (x *CollectMetrics) GetMetrics() []*Expression

func (*CollectMetrics) GetName

func (x *CollectMetrics) GetName() string

func (*CollectMetrics) ProtoMessage

func (*CollectMetrics) ProtoMessage()

func (*CollectMetrics) ProtoReflect

func (x *CollectMetrics) ProtoReflect() protoreflect.Message

func (*CollectMetrics) Reset

func (x *CollectMetrics) Reset()

func (*CollectMetrics) String

func (x *CollectMetrics) String() string

type Command

type Command struct {

	// Types that are assignable to CommandType:
	//
	//	*Command_RegisterFunction
	//	*Command_WriteOperation
	//	*Command_CreateDataframeView
	//	*Command_WriteOperationV2
	//	*Command_SqlCommand
	//	*Command_WriteStreamOperationStart
	//	*Command_StreamingQueryCommand
	//	*Command_GetResourcesCommand
	//	*Command_StreamingQueryManagerCommand
	//	*Command_Extension
	CommandType isCommand_CommandType `protobuf_oneof:"command_type"`
	// contains filtered or unexported fields
}

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

func (*Command) Descriptor deprecated

func (*Command) Descriptor() ([]byte, []int)

Deprecated: Use Command.ProtoReflect.Descriptor instead.

func (*Command) GetCommandType

func (m *Command) GetCommandType() isCommand_CommandType

func (*Command) GetCreateDataframeView

func (x *Command) GetCreateDataframeView() *CreateDataFrameViewCommand

func (*Command) GetExtension

func (x *Command) GetExtension() *anypb.Any

func (*Command) GetGetResourcesCommand

func (x *Command) GetGetResourcesCommand() *GetResourcesCommand

func (*Command) GetRegisterFunction

func (x *Command) GetRegisterFunction() *CommonInlineUserDefinedFunction

func (*Command) GetSqlCommand

func (x *Command) GetSqlCommand() *SqlCommand

func (*Command) GetStreamingQueryCommand

func (x *Command) GetStreamingQueryCommand() *StreamingQueryCommand

func (*Command) GetStreamingQueryManagerCommand

func (x *Command) GetStreamingQueryManagerCommand() *StreamingQueryManagerCommand

func (*Command) GetWriteOperation

func (x *Command) GetWriteOperation() *WriteOperation

func (*Command) GetWriteOperationV2

func (x *Command) GetWriteOperationV2() *WriteOperationV2

func (*Command) GetWriteStreamOperationStart

func (x *Command) GetWriteStreamOperationStart() *WriteStreamOperationStart

func (*Command) ProtoMessage

func (*Command) ProtoMessage()

func (*Command) ProtoReflect

func (x *Command) ProtoReflect() protoreflect.Message

func (*Command) Reset

func (x *Command) Reset()

func (*Command) String

func (x *Command) String() string

type Command_CreateDataframeView

type Command_CreateDataframeView struct {
	CreateDataframeView *CreateDataFrameViewCommand `protobuf:"bytes,3,opt,name=create_dataframe_view,json=createDataframeView,proto3,oneof"`
}

type Command_Extension

type Command_Extension struct {
	// This field is used to mark extensions to the protocol. When plugins generate arbitrary
	// Commands they can add them here. During the planning the correct resolution is done.
	Extension *anypb.Any `protobuf:"bytes,999,opt,name=extension,proto3,oneof"`
}

type Command_GetResourcesCommand

type Command_GetResourcesCommand struct {
	GetResourcesCommand *GetResourcesCommand `protobuf:"bytes,8,opt,name=get_resources_command,json=getResourcesCommand,proto3,oneof"`
}

type Command_RegisterFunction

type Command_RegisterFunction struct {
	RegisterFunction *CommonInlineUserDefinedFunction `protobuf:"bytes,1,opt,name=register_function,json=registerFunction,proto3,oneof"`
}

type Command_SqlCommand

type Command_SqlCommand struct {
	SqlCommand *SqlCommand `protobuf:"bytes,5,opt,name=sql_command,json=sqlCommand,proto3,oneof"`
}

type Command_StreamingQueryCommand

type Command_StreamingQueryCommand struct {
	StreamingQueryCommand *StreamingQueryCommand `protobuf:"bytes,7,opt,name=streaming_query_command,json=streamingQueryCommand,proto3,oneof"`
}

type Command_StreamingQueryManagerCommand

type Command_StreamingQueryManagerCommand struct {
	StreamingQueryManagerCommand *StreamingQueryManagerCommand `protobuf:"bytes,9,opt,name=streaming_query_manager_command,json=streamingQueryManagerCommand,proto3,oneof"`
}

type Command_WriteOperation

type Command_WriteOperation struct {
	WriteOperation *WriteOperation `protobuf:"bytes,2,opt,name=write_operation,json=writeOperation,proto3,oneof"`
}

type Command_WriteOperationV2

type Command_WriteOperationV2 struct {
	WriteOperationV2 *WriteOperationV2 `protobuf:"bytes,4,opt,name=write_operation_v2,json=writeOperationV2,proto3,oneof"`
}

type Command_WriteStreamOperationStart

type Command_WriteStreamOperationStart struct {
	WriteStreamOperationStart *WriteStreamOperationStart `protobuf:"bytes,6,opt,name=write_stream_operation_start,json=writeStreamOperationStart,proto3,oneof"`
}

type CommonInlineUserDefinedFunction

type CommonInlineUserDefinedFunction struct {

	// (Required) Name of the user-defined function.
	FunctionName string `protobuf:"bytes,1,opt,name=function_name,json=functionName,proto3" json:"function_name,omitempty"`
	// (Optional) Indicate if the user-defined function is deterministic.
	Deterministic bool `protobuf:"varint,2,opt,name=deterministic,proto3" json:"deterministic,omitempty"`
	// (Optional) Function arguments. Empty arguments are allowed.
	Arguments []*Expression `protobuf:"bytes,3,rep,name=arguments,proto3" json:"arguments,omitempty"`
	// (Required) Indicate the function type of the user-defined function.
	//
	// Types that are assignable to Function:
	//
	//	*CommonInlineUserDefinedFunction_PythonUdf
	//	*CommonInlineUserDefinedFunction_ScalarScalaUdf
	//	*CommonInlineUserDefinedFunction_JavaUdf
	Function isCommonInlineUserDefinedFunction_Function `protobuf_oneof:"function"`
	// contains filtered or unexported fields
}

func (*CommonInlineUserDefinedFunction) Descriptor deprecated

func (*CommonInlineUserDefinedFunction) Descriptor() ([]byte, []int)

Deprecated: Use CommonInlineUserDefinedFunction.ProtoReflect.Descriptor instead.

func (*CommonInlineUserDefinedFunction) GetArguments

func (x *CommonInlineUserDefinedFunction) GetArguments() []*Expression

func (*CommonInlineUserDefinedFunction) GetDeterministic

func (x *CommonInlineUserDefinedFunction) GetDeterministic() bool

func (*CommonInlineUserDefinedFunction) GetFunction

func (m *CommonInlineUserDefinedFunction) GetFunction() isCommonInlineUserDefinedFunction_Function

func (*CommonInlineUserDefinedFunction) GetFunctionName

func (x *CommonInlineUserDefinedFunction) GetFunctionName() string

func (*CommonInlineUserDefinedFunction) GetJavaUdf

func (x *CommonInlineUserDefinedFunction) GetJavaUdf() *JavaUDF

func (*CommonInlineUserDefinedFunction) GetPythonUdf

func (x *CommonInlineUserDefinedFunction) GetPythonUdf() *PythonUDF

func (*CommonInlineUserDefinedFunction) GetScalarScalaUdf

func (x *CommonInlineUserDefinedFunction) GetScalarScalaUdf() *ScalarScalaUDF

func (*CommonInlineUserDefinedFunction) ProtoMessage

func (*CommonInlineUserDefinedFunction) ProtoMessage()

func (*CommonInlineUserDefinedFunction) ProtoReflect

func (*CommonInlineUserDefinedFunction) Reset

func (*CommonInlineUserDefinedFunction) String

type CommonInlineUserDefinedFunction_JavaUdf

type CommonInlineUserDefinedFunction_JavaUdf struct {
	JavaUdf *JavaUDF `protobuf:"bytes,6,opt,name=java_udf,json=javaUdf,proto3,oneof"`
}

type CommonInlineUserDefinedFunction_PythonUdf

type CommonInlineUserDefinedFunction_PythonUdf struct {
	PythonUdf *PythonUDF `protobuf:"bytes,4,opt,name=python_udf,json=pythonUdf,proto3,oneof"`
}

type CommonInlineUserDefinedFunction_ScalarScalaUdf

type CommonInlineUserDefinedFunction_ScalarScalaUdf struct {
	ScalarScalaUdf *ScalarScalaUDF `protobuf:"bytes,5,opt,name=scalar_scala_udf,json=scalarScalaUdf,proto3,oneof"`
}

type ConfigRequest

type ConfigRequest struct {

	// (Required)
	//
	// The session_id specifies a spark session for a user id (which is specified
	// by user_context.user_id). The session_id is set by the client to be able to
	// collate streaming responses from different queries within the dedicated session.
	SessionId string `protobuf:"bytes,1,opt,name=session_id,json=sessionId,proto3" json:"session_id,omitempty"`
	// (Required) User context
	UserContext *UserContext `protobuf:"bytes,2,opt,name=user_context,json=userContext,proto3" json:"user_context,omitempty"`
	// (Required) The operation for the config.
	Operation *ConfigRequest_Operation `protobuf:"bytes,3,opt,name=operation,proto3" json:"operation,omitempty"`
	// Provides optional information about the client sending the request. This field
	// can be used for language or version specific information and is only intended for
	// logging purposes and will not be interpreted by the server.
	ClientType *string `protobuf:"bytes,4,opt,name=client_type,json=clientType,proto3,oneof" json:"client_type,omitempty"`
	// contains filtered or unexported fields
}

Request to update or fetch the configurations.

func (*ConfigRequest) Descriptor deprecated

func (*ConfigRequest) Descriptor() ([]byte, []int)

Deprecated: Use ConfigRequest.ProtoReflect.Descriptor instead.

func (*ConfigRequest) GetClientType

func (x *ConfigRequest) GetClientType() string

func (*ConfigRequest) GetOperation

func (x *ConfigRequest) GetOperation() *ConfigRequest_Operation

func (*ConfigRequest) GetSessionId

func (x *ConfigRequest) GetSessionId() string

func (*ConfigRequest) GetUserContext

func (x *ConfigRequest) GetUserContext() *UserContext

func (*ConfigRequest) ProtoMessage

func (*ConfigRequest) ProtoMessage()

func (*ConfigRequest) ProtoReflect

func (x *ConfigRequest) ProtoReflect() protoreflect.Message

func (*ConfigRequest) Reset

func (x *ConfigRequest) Reset()

func (*ConfigRequest) String

func (x *ConfigRequest) String() string

type ConfigRequest_Get

type ConfigRequest_Get struct {

	// (Required) The config keys to get.
	Keys []string `protobuf:"bytes,1,rep,name=keys,proto3" json:"keys,omitempty"`
	// contains filtered or unexported fields
}

func (*ConfigRequest_Get) Descriptor deprecated

func (*ConfigRequest_Get) Descriptor() ([]byte, []int)

Deprecated: Use ConfigRequest_Get.ProtoReflect.Descriptor instead.

func (*ConfigRequest_Get) GetKeys

func (x *ConfigRequest_Get) GetKeys() []string

func (*ConfigRequest_Get) ProtoMessage

func (*ConfigRequest_Get) ProtoMessage()

func (*ConfigRequest_Get) ProtoReflect

func (x *ConfigRequest_Get) ProtoReflect() protoreflect.Message

func (*ConfigRequest_Get) Reset

func (x *ConfigRequest_Get) Reset()

func (*ConfigRequest_Get) String

func (x *ConfigRequest_Get) String() string

type ConfigRequest_GetAll

type ConfigRequest_GetAll struct {

	// (Optional) The prefix of the config key to get.
	Prefix *string `protobuf:"bytes,1,opt,name=prefix,proto3,oneof" json:"prefix,omitempty"`
	// contains filtered or unexported fields
}

func (*ConfigRequest_GetAll) Descriptor deprecated

func (*ConfigRequest_GetAll) Descriptor() ([]byte, []int)

Deprecated: Use ConfigRequest_GetAll.ProtoReflect.Descriptor instead.

func (*ConfigRequest_GetAll) GetPrefix

func (x *ConfigRequest_GetAll) GetPrefix() string

func (*ConfigRequest_GetAll) ProtoMessage

func (*ConfigRequest_GetAll) ProtoMessage()

func (*ConfigRequest_GetAll) ProtoReflect

func (x *ConfigRequest_GetAll) ProtoReflect() protoreflect.Message

func (*ConfigRequest_GetAll) Reset

func (x *ConfigRequest_GetAll) Reset()

func (*ConfigRequest_GetAll) String

func (x *ConfigRequest_GetAll) String() string

type ConfigRequest_GetOption

type ConfigRequest_GetOption struct {

	// (Required) The config keys to get optionally.
	Keys []string `protobuf:"bytes,1,rep,name=keys,proto3" json:"keys,omitempty"`
	// contains filtered or unexported fields
}

func (*ConfigRequest_GetOption) Descriptor deprecated

func (*ConfigRequest_GetOption) Descriptor() ([]byte, []int)

Deprecated: Use ConfigRequest_GetOption.ProtoReflect.Descriptor instead.

func (*ConfigRequest_GetOption) GetKeys

func (x *ConfigRequest_GetOption) GetKeys() []string

func (*ConfigRequest_GetOption) ProtoMessage

func (*ConfigRequest_GetOption) ProtoMessage()

func (*ConfigRequest_GetOption) ProtoReflect

func (x *ConfigRequest_GetOption) ProtoReflect() protoreflect.Message

func (*ConfigRequest_GetOption) Reset

func (x *ConfigRequest_GetOption) Reset()

func (*ConfigRequest_GetOption) String

func (x *ConfigRequest_GetOption) String() string

type ConfigRequest_GetWithDefault

type ConfigRequest_GetWithDefault struct {

	// (Required) The config key-value paris to get. The value will be used as the default value.
	Pairs []*KeyValue `protobuf:"bytes,1,rep,name=pairs,proto3" json:"pairs,omitempty"`
	// contains filtered or unexported fields
}

func (*ConfigRequest_GetWithDefault) Descriptor deprecated

func (*ConfigRequest_GetWithDefault) Descriptor() ([]byte, []int)

Deprecated: Use ConfigRequest_GetWithDefault.ProtoReflect.Descriptor instead.

func (*ConfigRequest_GetWithDefault) GetPairs

func (x *ConfigRequest_GetWithDefault) GetPairs() []*KeyValue

func (*ConfigRequest_GetWithDefault) ProtoMessage

func (*ConfigRequest_GetWithDefault) ProtoMessage()

func (*ConfigRequest_GetWithDefault) ProtoReflect

func (*ConfigRequest_GetWithDefault) Reset

func (x *ConfigRequest_GetWithDefault) Reset()

func (*ConfigRequest_GetWithDefault) String

type ConfigRequest_IsModifiable

type ConfigRequest_IsModifiable struct {

	// (Required) The config keys to check the config is modifiable.
	Keys []string `protobuf:"bytes,1,rep,name=keys,proto3" json:"keys,omitempty"`
	// contains filtered or unexported fields
}

func (*ConfigRequest_IsModifiable) Descriptor deprecated

func (*ConfigRequest_IsModifiable) Descriptor() ([]byte, []int)

Deprecated: Use ConfigRequest_IsModifiable.ProtoReflect.Descriptor instead.

func (*ConfigRequest_IsModifiable) GetKeys

func (x *ConfigRequest_IsModifiable) GetKeys() []string

func (*ConfigRequest_IsModifiable) ProtoMessage

func (*ConfigRequest_IsModifiable) ProtoMessage()

func (*ConfigRequest_IsModifiable) ProtoReflect

func (*ConfigRequest_IsModifiable) Reset

func (x *ConfigRequest_IsModifiable) Reset()

func (*ConfigRequest_IsModifiable) String

func (x *ConfigRequest_IsModifiable) String() string

type ConfigRequest_Operation

type ConfigRequest_Operation struct {

	// Types that are assignable to OpType:
	//
	//	*ConfigRequest_Operation_Set
	//	*ConfigRequest_Operation_Get
	//	*ConfigRequest_Operation_GetWithDefault
	//	*ConfigRequest_Operation_GetOption
	//	*ConfigRequest_Operation_GetAll
	//	*ConfigRequest_Operation_Unset
	//	*ConfigRequest_Operation_IsModifiable
	OpType isConfigRequest_Operation_OpType `protobuf_oneof:"op_type"`
	// contains filtered or unexported fields
}

func (*ConfigRequest_Operation) Descriptor deprecated

func (*ConfigRequest_Operation) Descriptor() ([]byte, []int)

Deprecated: Use ConfigRequest_Operation.ProtoReflect.Descriptor instead.

func (*ConfigRequest_Operation) GetGet

func (*ConfigRequest_Operation) GetGetAll

func (*ConfigRequest_Operation) GetGetOption

func (*ConfigRequest_Operation) GetGetWithDefault

func (x *ConfigRequest_Operation) GetGetWithDefault() *ConfigRequest_GetWithDefault

func (*ConfigRequest_Operation) GetIsModifiable

func (*ConfigRequest_Operation) GetOpType

func (m *ConfigRequest_Operation) GetOpType() isConfigRequest_Operation_OpType

func (*ConfigRequest_Operation) GetSet

func (*ConfigRequest_Operation) GetUnset

func (*ConfigRequest_Operation) ProtoMessage

func (*ConfigRequest_Operation) ProtoMessage()

func (*ConfigRequest_Operation) ProtoReflect

func (x *ConfigRequest_Operation) ProtoReflect() protoreflect.Message

func (*ConfigRequest_Operation) Reset

func (x *ConfigRequest_Operation) Reset()

func (*ConfigRequest_Operation) String

func (x *ConfigRequest_Operation) String() string

type ConfigRequest_Operation_Get

type ConfigRequest_Operation_Get struct {
	Get *ConfigRequest_Get `protobuf:"bytes,2,opt,name=get,proto3,oneof"`
}

type ConfigRequest_Operation_GetAll

type ConfigRequest_Operation_GetAll struct {
	GetAll *ConfigRequest_GetAll `protobuf:"bytes,5,opt,name=get_all,json=getAll,proto3,oneof"`
}

type ConfigRequest_Operation_GetOption

type ConfigRequest_Operation_GetOption struct {
	GetOption *ConfigRequest_GetOption `protobuf:"bytes,4,opt,name=get_option,json=getOption,proto3,oneof"`
}

type ConfigRequest_Operation_GetWithDefault

type ConfigRequest_Operation_GetWithDefault struct {
	GetWithDefault *ConfigRequest_GetWithDefault `protobuf:"bytes,3,opt,name=get_with_default,json=getWithDefault,proto3,oneof"`
}

type ConfigRequest_Operation_IsModifiable

type ConfigRequest_Operation_IsModifiable struct {
	IsModifiable *ConfigRequest_IsModifiable `protobuf:"bytes,7,opt,name=is_modifiable,json=isModifiable,proto3,oneof"`
}

type ConfigRequest_Operation_Set

type ConfigRequest_Operation_Set struct {
	Set *ConfigRequest_Set `protobuf:"bytes,1,opt,name=set,proto3,oneof"`
}

type ConfigRequest_Operation_Unset

type ConfigRequest_Operation_Unset struct {
	Unset *ConfigRequest_Unset `protobuf:"bytes,6,opt,name=unset,proto3,oneof"`
}

type ConfigRequest_Set

type ConfigRequest_Set struct {

	// (Required) The config key-value pairs to set.
	Pairs []*KeyValue `protobuf:"bytes,1,rep,name=pairs,proto3" json:"pairs,omitempty"`
	// contains filtered or unexported fields
}

func (*ConfigRequest_Set) Descriptor deprecated

func (*ConfigRequest_Set) Descriptor() ([]byte, []int)

Deprecated: Use ConfigRequest_Set.ProtoReflect.Descriptor instead.

func (*ConfigRequest_Set) GetPairs

func (x *ConfigRequest_Set) GetPairs() []*KeyValue

func (*ConfigRequest_Set) ProtoMessage

func (*ConfigRequest_Set) ProtoMessage()

func (*ConfigRequest_Set) ProtoReflect

func (x *ConfigRequest_Set) ProtoReflect() protoreflect.Message

func (*ConfigRequest_Set) Reset

func (x *ConfigRequest_Set) Reset()

func (*ConfigRequest_Set) String

func (x *ConfigRequest_Set) String() string

type ConfigRequest_Unset

type ConfigRequest_Unset struct {

	// (Required) The config keys to unset.
	Keys []string `protobuf:"bytes,1,rep,name=keys,proto3" json:"keys,omitempty"`
	// contains filtered or unexported fields
}

func (*ConfigRequest_Unset) Descriptor deprecated

func (*ConfigRequest_Unset) Descriptor() ([]byte, []int)

Deprecated: Use ConfigRequest_Unset.ProtoReflect.Descriptor instead.

func (*ConfigRequest_Unset) GetKeys

func (x *ConfigRequest_Unset) GetKeys() []string

func (*ConfigRequest_Unset) ProtoMessage

func (*ConfigRequest_Unset) ProtoMessage()

func (*ConfigRequest_Unset) ProtoReflect

func (x *ConfigRequest_Unset) ProtoReflect() protoreflect.Message

func (*ConfigRequest_Unset) Reset

func (x *ConfigRequest_Unset) Reset()

func (*ConfigRequest_Unset) String

func (x *ConfigRequest_Unset) String() string

type ConfigResponse

type ConfigResponse struct {
	SessionId string `protobuf:"bytes,1,opt,name=session_id,json=sessionId,proto3" json:"session_id,omitempty"`
	// (Optional) The result key-value pairs.
	//
	// Available when the operation is 'Get', 'GetWithDefault', 'GetOption', 'GetAll'.
	// Also available for the operation 'IsModifiable' with boolean string "true" and "false".
	Pairs []*KeyValue `protobuf:"bytes,2,rep,name=pairs,proto3" json:"pairs,omitempty"`
	// (Optional)
	//
	// Warning messages for deprecated or unsupported configurations.
	Warnings []string `protobuf:"bytes,3,rep,name=warnings,proto3" json:"warnings,omitempty"`
	// contains filtered or unexported fields
}

Response to the config request.

func (*ConfigResponse) Descriptor deprecated

func (*ConfigResponse) Descriptor() ([]byte, []int)

Deprecated: Use ConfigResponse.ProtoReflect.Descriptor instead.

func (*ConfigResponse) GetPairs

func (x *ConfigResponse) GetPairs() []*KeyValue

func (*ConfigResponse) GetSessionId

func (x *ConfigResponse) GetSessionId() string

func (*ConfigResponse) GetWarnings

func (x *ConfigResponse) GetWarnings() []string

func (*ConfigResponse) ProtoMessage

func (*ConfigResponse) ProtoMessage()

func (*ConfigResponse) ProtoReflect

func (x *ConfigResponse) ProtoReflect() protoreflect.Message

func (*ConfigResponse) Reset

func (x *ConfigResponse) Reset()

func (*ConfigResponse) String

func (x *ConfigResponse) String() string

type CreateDataFrameViewCommand

type CreateDataFrameViewCommand struct {

	// (Required) The relation that this view will be built on.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) View name.
	Name string `protobuf:"bytes,2,opt,name=name,proto3" json:"name,omitempty"`
	// (Required) Whether this is global temp view or local temp view.
	IsGlobal bool `protobuf:"varint,3,opt,name=is_global,json=isGlobal,proto3" json:"is_global,omitempty"`
	// (Required)
	//
	// If true, and if the view already exists, updates it; if false, and if the view
	// already exists, throws exception.
	Replace bool `protobuf:"varint,4,opt,name=replace,proto3" json:"replace,omitempty"`
	// contains filtered or unexported fields
}

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

func (*CreateDataFrameViewCommand) Descriptor deprecated

func (*CreateDataFrameViewCommand) Descriptor() ([]byte, []int)

Deprecated: Use CreateDataFrameViewCommand.ProtoReflect.Descriptor instead.

func (*CreateDataFrameViewCommand) GetInput

func (x *CreateDataFrameViewCommand) GetInput() *Relation

func (*CreateDataFrameViewCommand) GetIsGlobal

func (x *CreateDataFrameViewCommand) GetIsGlobal() bool

func (*CreateDataFrameViewCommand) GetName

func (x *CreateDataFrameViewCommand) GetName() string

func (*CreateDataFrameViewCommand) GetReplace

func (x *CreateDataFrameViewCommand) GetReplace() bool

func (*CreateDataFrameViewCommand) ProtoMessage

func (*CreateDataFrameViewCommand) ProtoMessage()

func (*CreateDataFrameViewCommand) ProtoReflect

func (*CreateDataFrameViewCommand) Reset

func (x *CreateDataFrameViewCommand) Reset()

func (*CreateDataFrameViewCommand) String

func (x *CreateDataFrameViewCommand) String() string

type CreateExternalTable

type CreateExternalTable struct {

	// (Required)
	TableName string `protobuf:"bytes,1,opt,name=table_name,json=tableName,proto3" json:"table_name,omitempty"`
	// (Optional)
	Path *string `protobuf:"bytes,2,opt,name=path,proto3,oneof" json:"path,omitempty"`
	// (Optional)
	Source *string `protobuf:"bytes,3,opt,name=source,proto3,oneof" json:"source,omitempty"`
	// (Optional)
	Schema *DataType `protobuf:"bytes,4,opt,name=schema,proto3,oneof" json:"schema,omitempty"`
	// Options could be empty for valid data source format.
	// The map key is case insensitive.
	Options map[string]string `` /* 155-byte string literal not displayed */
	// contains filtered or unexported fields
}

See `spark.catalog.createExternalTable`

func (*CreateExternalTable) Descriptor deprecated

func (*CreateExternalTable) Descriptor() ([]byte, []int)

Deprecated: Use CreateExternalTable.ProtoReflect.Descriptor instead.

func (*CreateExternalTable) GetOptions

func (x *CreateExternalTable) GetOptions() map[string]string

func (*CreateExternalTable) GetPath

func (x *CreateExternalTable) GetPath() string

func (*CreateExternalTable) GetSchema

func (x *CreateExternalTable) GetSchema() *DataType

func (*CreateExternalTable) GetSource

func (x *CreateExternalTable) GetSource() string

func (*CreateExternalTable) GetTableName

func (x *CreateExternalTable) GetTableName() string

func (*CreateExternalTable) ProtoMessage

func (*CreateExternalTable) ProtoMessage()

func (*CreateExternalTable) ProtoReflect

func (x *CreateExternalTable) ProtoReflect() protoreflect.Message

func (*CreateExternalTable) Reset

func (x *CreateExternalTable) Reset()

func (*CreateExternalTable) String

func (x *CreateExternalTable) String() string

type CreateTable

type CreateTable struct {

	// (Required)
	TableName string `protobuf:"bytes,1,opt,name=table_name,json=tableName,proto3" json:"table_name,omitempty"`
	// (Optional)
	Path *string `protobuf:"bytes,2,opt,name=path,proto3,oneof" json:"path,omitempty"`
	// (Optional)
	Source *string `protobuf:"bytes,3,opt,name=source,proto3,oneof" json:"source,omitempty"`
	// (Optional)
	Description *string `protobuf:"bytes,4,opt,name=description,proto3,oneof" json:"description,omitempty"`
	// (Optional)
	Schema *DataType `protobuf:"bytes,5,opt,name=schema,proto3,oneof" json:"schema,omitempty"`
	// Options could be empty for valid data source format.
	// The map key is case insensitive.
	Options map[string]string `` /* 155-byte string literal not displayed */
	// contains filtered or unexported fields
}

See `spark.catalog.createTable`

func (*CreateTable) Descriptor deprecated

func (*CreateTable) Descriptor() ([]byte, []int)

Deprecated: Use CreateTable.ProtoReflect.Descriptor instead.

func (*CreateTable) GetDescription

func (x *CreateTable) GetDescription() string

func (*CreateTable) GetOptions

func (x *CreateTable) GetOptions() map[string]string

func (*CreateTable) GetPath

func (x *CreateTable) GetPath() string

func (*CreateTable) GetSchema

func (x *CreateTable) GetSchema() *DataType

func (*CreateTable) GetSource

func (x *CreateTable) GetSource() string

func (*CreateTable) GetTableName

func (x *CreateTable) GetTableName() string

func (*CreateTable) ProtoMessage

func (*CreateTable) ProtoMessage()

func (*CreateTable) ProtoReflect

func (x *CreateTable) ProtoReflect() protoreflect.Message

func (*CreateTable) Reset

func (x *CreateTable) Reset()

func (*CreateTable) String

func (x *CreateTable) String() string

type CurrentCatalog

type CurrentCatalog struct {
	// contains filtered or unexported fields
}

See `spark.catalog.currentCatalog`

func (*CurrentCatalog) Descriptor deprecated

func (*CurrentCatalog) Descriptor() ([]byte, []int)

Deprecated: Use CurrentCatalog.ProtoReflect.Descriptor instead.

func (*CurrentCatalog) ProtoMessage

func (*CurrentCatalog) ProtoMessage()

func (*CurrentCatalog) ProtoReflect

func (x *CurrentCatalog) ProtoReflect() protoreflect.Message

func (*CurrentCatalog) Reset

func (x *CurrentCatalog) Reset()

func (*CurrentCatalog) String

func (x *CurrentCatalog) String() string

type CurrentDatabase

type CurrentDatabase struct {
	// contains filtered or unexported fields
}

See `spark.catalog.currentDatabase`

func (*CurrentDatabase) Descriptor deprecated

func (*CurrentDatabase) Descriptor() ([]byte, []int)

Deprecated: Use CurrentDatabase.ProtoReflect.Descriptor instead.

func (*CurrentDatabase) ProtoMessage

func (*CurrentDatabase) ProtoMessage()

func (*CurrentDatabase) ProtoReflect

func (x *CurrentDatabase) ProtoReflect() protoreflect.Message

func (*CurrentDatabase) Reset

func (x *CurrentDatabase) Reset()

func (*CurrentDatabase) String

func (x *CurrentDatabase) String() string

type DataType

type DataType struct {

	// Types that are assignable to Kind:
	//
	//	*DataType_Null
	//	*DataType_Binary_
	//	*DataType_Boolean_
	//	*DataType_Byte_
	//	*DataType_Short_
	//	*DataType_Integer_
	//	*DataType_Long_
	//	*DataType_Float_
	//	*DataType_Double_
	//	*DataType_Decimal_
	//	*DataType_String_
	//	*DataType_Char_
	//	*DataType_VarChar_
	//	*DataType_Date_
	//	*DataType_Timestamp_
	//	*DataType_TimestampNtz
	//	*DataType_CalendarInterval_
	//	*DataType_YearMonthInterval_
	//	*DataType_DayTimeInterval_
	//	*DataType_Array_
	//	*DataType_Struct_
	//	*DataType_Map_
	//	*DataType_Udt
	//	*DataType_Unparsed_
	Kind isDataType_Kind `protobuf_oneof:"kind"`
	// contains filtered or unexported fields
}

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

func (*DataType) Descriptor deprecated

func (*DataType) Descriptor() ([]byte, []int)

Deprecated: Use DataType.ProtoReflect.Descriptor instead.

func (*DataType) GetArray

func (x *DataType) GetArray() *DataType_Array

func (*DataType) GetBinary

func (x *DataType) GetBinary() *DataType_Binary

func (*DataType) GetBoolean

func (x *DataType) GetBoolean() *DataType_Boolean

func (*DataType) GetByte

func (x *DataType) GetByte() *DataType_Byte

func (*DataType) GetCalendarInterval

func (x *DataType) GetCalendarInterval() *DataType_CalendarInterval

func (*DataType) GetChar

func (x *DataType) GetChar() *DataType_Char

func (*DataType) GetDate

func (x *DataType) GetDate() *DataType_Date

func (*DataType) GetDayTimeInterval

func (x *DataType) GetDayTimeInterval() *DataType_DayTimeInterval

func (*DataType) GetDecimal

func (x *DataType) GetDecimal() *DataType_Decimal

func (*DataType) GetDouble

func (x *DataType) GetDouble() *DataType_Double

func (*DataType) GetFloat

func (x *DataType) GetFloat() *DataType_Float

func (*DataType) GetInteger

func (x *DataType) GetInteger() *DataType_Integer

func (*DataType) GetKind

func (m *DataType) GetKind() isDataType_Kind

func (*DataType) GetLong

func (x *DataType) GetLong() *DataType_Long

func (*DataType) GetMap

func (x *DataType) GetMap() *DataType_Map

func (*DataType) GetNull

func (x *DataType) GetNull() *DataType_NULL

func (*DataType) GetShort

func (x *DataType) GetShort() *DataType_Short

func (*DataType) GetString_

func (x *DataType) GetString_() *DataType_String

func (*DataType) GetStruct

func (x *DataType) GetStruct() *DataType_Struct

func (*DataType) GetTimestamp

func (x *DataType) GetTimestamp() *DataType_Timestamp

func (*DataType) GetTimestampNtz

func (x *DataType) GetTimestampNtz() *DataType_TimestampNTZ

func (*DataType) GetUdt

func (x *DataType) GetUdt() *DataType_UDT

func (*DataType) GetUnparsed

func (x *DataType) GetUnparsed() *DataType_Unparsed

func (*DataType) GetVarChar

func (x *DataType) GetVarChar() *DataType_VarChar

func (*DataType) GetYearMonthInterval

func (x *DataType) GetYearMonthInterval() *DataType_YearMonthInterval

func (*DataType) ProtoMessage

func (*DataType) ProtoMessage()

func (*DataType) ProtoReflect

func (x *DataType) ProtoReflect() protoreflect.Message

func (*DataType) Reset

func (x *DataType) Reset()

func (*DataType) String

func (x *DataType) String() string

type DataType_Array

type DataType_Array struct {
	ElementType            *DataType `protobuf:"bytes,1,opt,name=element_type,json=elementType,proto3" json:"element_type,omitempty"`
	ContainsNull           bool      `protobuf:"varint,2,opt,name=contains_null,json=containsNull,proto3" json:"contains_null,omitempty"`
	TypeVariationReference uint32    `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_Array) Descriptor deprecated

func (*DataType_Array) Descriptor() ([]byte, []int)

Deprecated: Use DataType_Array.ProtoReflect.Descriptor instead.

func (*DataType_Array) GetContainsNull

func (x *DataType_Array) GetContainsNull() bool

func (*DataType_Array) GetElementType

func (x *DataType_Array) GetElementType() *DataType

func (*DataType_Array) GetTypeVariationReference

func (x *DataType_Array) GetTypeVariationReference() uint32

func (*DataType_Array) ProtoMessage

func (*DataType_Array) ProtoMessage()

func (*DataType_Array) ProtoReflect

func (x *DataType_Array) ProtoReflect() protoreflect.Message

func (*DataType_Array) Reset

func (x *DataType_Array) Reset()

func (*DataType_Array) String

func (x *DataType_Array) String() string

type DataType_Array_

type DataType_Array_ struct {
	// Complex types
	Array *DataType_Array `protobuf:"bytes,20,opt,name=array,proto3,oneof"`
}

type DataType_Binary

type DataType_Binary struct {
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_Binary) Descriptor deprecated

func (*DataType_Binary) Descriptor() ([]byte, []int)

Deprecated: Use DataType_Binary.ProtoReflect.Descriptor instead.

func (*DataType_Binary) GetTypeVariationReference

func (x *DataType_Binary) GetTypeVariationReference() uint32

func (*DataType_Binary) ProtoMessage

func (*DataType_Binary) ProtoMessage()

func (*DataType_Binary) ProtoReflect

func (x *DataType_Binary) ProtoReflect() protoreflect.Message

func (*DataType_Binary) Reset

func (x *DataType_Binary) Reset()

func (*DataType_Binary) String

func (x *DataType_Binary) String() string

type DataType_Binary_

type DataType_Binary_ struct {
	Binary *DataType_Binary `protobuf:"bytes,2,opt,name=binary,proto3,oneof"`
}

type DataType_Boolean

type DataType_Boolean struct {
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_Boolean) Descriptor deprecated

func (*DataType_Boolean) Descriptor() ([]byte, []int)

Deprecated: Use DataType_Boolean.ProtoReflect.Descriptor instead.

func (*DataType_Boolean) GetTypeVariationReference

func (x *DataType_Boolean) GetTypeVariationReference() uint32

func (*DataType_Boolean) ProtoMessage

func (*DataType_Boolean) ProtoMessage()

func (*DataType_Boolean) ProtoReflect

func (x *DataType_Boolean) ProtoReflect() protoreflect.Message

func (*DataType_Boolean) Reset

func (x *DataType_Boolean) Reset()

func (*DataType_Boolean) String

func (x *DataType_Boolean) String() string

type DataType_Boolean_

type DataType_Boolean_ struct {
	Boolean *DataType_Boolean `protobuf:"bytes,3,opt,name=boolean,proto3,oneof"`
}

type DataType_Byte

type DataType_Byte struct {
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_Byte) Descriptor deprecated

func (*DataType_Byte) Descriptor() ([]byte, []int)

Deprecated: Use DataType_Byte.ProtoReflect.Descriptor instead.

func (*DataType_Byte) GetTypeVariationReference

func (x *DataType_Byte) GetTypeVariationReference() uint32

func (*DataType_Byte) ProtoMessage

func (*DataType_Byte) ProtoMessage()

func (*DataType_Byte) ProtoReflect

func (x *DataType_Byte) ProtoReflect() protoreflect.Message

func (*DataType_Byte) Reset

func (x *DataType_Byte) Reset()

func (*DataType_Byte) String

func (x *DataType_Byte) String() string

type DataType_Byte_

type DataType_Byte_ struct {
	// Numeric types
	Byte *DataType_Byte `protobuf:"bytes,4,opt,name=byte,proto3,oneof"`
}

type DataType_CalendarInterval

type DataType_CalendarInterval struct {
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_CalendarInterval) Descriptor deprecated

func (*DataType_CalendarInterval) Descriptor() ([]byte, []int)

Deprecated: Use DataType_CalendarInterval.ProtoReflect.Descriptor instead.

func (*DataType_CalendarInterval) GetTypeVariationReference

func (x *DataType_CalendarInterval) GetTypeVariationReference() uint32

func (*DataType_CalendarInterval) ProtoMessage

func (*DataType_CalendarInterval) ProtoMessage()

func (*DataType_CalendarInterval) ProtoReflect

func (*DataType_CalendarInterval) Reset

func (x *DataType_CalendarInterval) Reset()

func (*DataType_CalendarInterval) String

func (x *DataType_CalendarInterval) String() string

type DataType_CalendarInterval_

type DataType_CalendarInterval_ struct {
	// Interval types
	CalendarInterval *DataType_CalendarInterval `protobuf:"bytes,17,opt,name=calendar_interval,json=calendarInterval,proto3,oneof"`
}

type DataType_Char

type DataType_Char struct {
	Length                 int32  `protobuf:"varint,1,opt,name=length,proto3" json:"length,omitempty"`
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

Start compound types.

func (*DataType_Char) Descriptor deprecated

func (*DataType_Char) Descriptor() ([]byte, []int)

Deprecated: Use DataType_Char.ProtoReflect.Descriptor instead.

func (*DataType_Char) GetLength

func (x *DataType_Char) GetLength() int32

func (*DataType_Char) GetTypeVariationReference

func (x *DataType_Char) GetTypeVariationReference() uint32

func (*DataType_Char) ProtoMessage

func (*DataType_Char) ProtoMessage()

func (*DataType_Char) ProtoReflect

func (x *DataType_Char) ProtoReflect() protoreflect.Message

func (*DataType_Char) Reset

func (x *DataType_Char) Reset()

func (*DataType_Char) String

func (x *DataType_Char) String() string

type DataType_Char_

type DataType_Char_ struct {
	Char *DataType_Char `protobuf:"bytes,12,opt,name=char,proto3,oneof"`
}

type DataType_Date

type DataType_Date struct {
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_Date) Descriptor deprecated

func (*DataType_Date) Descriptor() ([]byte, []int)

Deprecated: Use DataType_Date.ProtoReflect.Descriptor instead.

func (*DataType_Date) GetTypeVariationReference

func (x *DataType_Date) GetTypeVariationReference() uint32

func (*DataType_Date) ProtoMessage

func (*DataType_Date) ProtoMessage()

func (*DataType_Date) ProtoReflect

func (x *DataType_Date) ProtoReflect() protoreflect.Message

func (*DataType_Date) Reset

func (x *DataType_Date) Reset()

func (*DataType_Date) String

func (x *DataType_Date) String() string

type DataType_Date_

type DataType_Date_ struct {
	// Datatime types
	Date *DataType_Date `protobuf:"bytes,14,opt,name=date,proto3,oneof"`
}

type DataType_DayTimeInterval

type DataType_DayTimeInterval struct {
	StartField             *int32 `protobuf:"varint,1,opt,name=start_field,json=startField,proto3,oneof" json:"start_field,omitempty"`
	EndField               *int32 `protobuf:"varint,2,opt,name=end_field,json=endField,proto3,oneof" json:"end_field,omitempty"`
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_DayTimeInterval) Descriptor deprecated

func (*DataType_DayTimeInterval) Descriptor() ([]byte, []int)

Deprecated: Use DataType_DayTimeInterval.ProtoReflect.Descriptor instead.

func (*DataType_DayTimeInterval) GetEndField

func (x *DataType_DayTimeInterval) GetEndField() int32

func (*DataType_DayTimeInterval) GetStartField

func (x *DataType_DayTimeInterval) GetStartField() int32

func (*DataType_DayTimeInterval) GetTypeVariationReference

func (x *DataType_DayTimeInterval) GetTypeVariationReference() uint32

func (*DataType_DayTimeInterval) ProtoMessage

func (*DataType_DayTimeInterval) ProtoMessage()

func (*DataType_DayTimeInterval) ProtoReflect

func (x *DataType_DayTimeInterval) ProtoReflect() protoreflect.Message

func (*DataType_DayTimeInterval) Reset

func (x *DataType_DayTimeInterval) Reset()

func (*DataType_DayTimeInterval) String

func (x *DataType_DayTimeInterval) String() string

type DataType_DayTimeInterval_

type DataType_DayTimeInterval_ struct {
	DayTimeInterval *DataType_DayTimeInterval `protobuf:"bytes,19,opt,name=day_time_interval,json=dayTimeInterval,proto3,oneof"`
}

type DataType_Decimal

type DataType_Decimal struct {
	Scale                  *int32 `protobuf:"varint,1,opt,name=scale,proto3,oneof" json:"scale,omitempty"`
	Precision              *int32 `protobuf:"varint,2,opt,name=precision,proto3,oneof" json:"precision,omitempty"`
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_Decimal) Descriptor deprecated

func (*DataType_Decimal) Descriptor() ([]byte, []int)

Deprecated: Use DataType_Decimal.ProtoReflect.Descriptor instead.

func (*DataType_Decimal) GetPrecision

func (x *DataType_Decimal) GetPrecision() int32

func (*DataType_Decimal) GetScale

func (x *DataType_Decimal) GetScale() int32

func (*DataType_Decimal) GetTypeVariationReference

func (x *DataType_Decimal) GetTypeVariationReference() uint32

func (*DataType_Decimal) ProtoMessage

func (*DataType_Decimal) ProtoMessage()

func (*DataType_Decimal) ProtoReflect

func (x *DataType_Decimal) ProtoReflect() protoreflect.Message

func (*DataType_Decimal) Reset

func (x *DataType_Decimal) Reset()

func (*DataType_Decimal) String

func (x *DataType_Decimal) String() string

type DataType_Decimal_

type DataType_Decimal_ struct {
	Decimal *DataType_Decimal `protobuf:"bytes,10,opt,name=decimal,proto3,oneof"`
}

type DataType_Double

type DataType_Double struct {
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_Double) Descriptor deprecated

func (*DataType_Double) Descriptor() ([]byte, []int)

Deprecated: Use DataType_Double.ProtoReflect.Descriptor instead.

func (*DataType_Double) GetTypeVariationReference

func (x *DataType_Double) GetTypeVariationReference() uint32

func (*DataType_Double) ProtoMessage

func (*DataType_Double) ProtoMessage()

func (*DataType_Double) ProtoReflect

func (x *DataType_Double) ProtoReflect() protoreflect.Message

func (*DataType_Double) Reset

func (x *DataType_Double) Reset()

func (*DataType_Double) String

func (x *DataType_Double) String() string

type DataType_Double_

type DataType_Double_ struct {
	Double *DataType_Double `protobuf:"bytes,9,opt,name=double,proto3,oneof"`
}

type DataType_Float

type DataType_Float struct {
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_Float) Descriptor deprecated

func (*DataType_Float) Descriptor() ([]byte, []int)

Deprecated: Use DataType_Float.ProtoReflect.Descriptor instead.

func (*DataType_Float) GetTypeVariationReference

func (x *DataType_Float) GetTypeVariationReference() uint32

func (*DataType_Float) ProtoMessage

func (*DataType_Float) ProtoMessage()

func (*DataType_Float) ProtoReflect

func (x *DataType_Float) ProtoReflect() protoreflect.Message

func (*DataType_Float) Reset

func (x *DataType_Float) Reset()

func (*DataType_Float) String

func (x *DataType_Float) String() string

type DataType_Float_

type DataType_Float_ struct {
	Float *DataType_Float `protobuf:"bytes,8,opt,name=float,proto3,oneof"`
}

type DataType_Integer

type DataType_Integer struct {
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_Integer) Descriptor deprecated

func (*DataType_Integer) Descriptor() ([]byte, []int)

Deprecated: Use DataType_Integer.ProtoReflect.Descriptor instead.

func (*DataType_Integer) GetTypeVariationReference

func (x *DataType_Integer) GetTypeVariationReference() uint32

func (*DataType_Integer) ProtoMessage

func (*DataType_Integer) ProtoMessage()

func (*DataType_Integer) ProtoReflect

func (x *DataType_Integer) ProtoReflect() protoreflect.Message

func (*DataType_Integer) Reset

func (x *DataType_Integer) Reset()

func (*DataType_Integer) String

func (x *DataType_Integer) String() string

type DataType_Integer_

type DataType_Integer_ struct {
	Integer *DataType_Integer `protobuf:"bytes,6,opt,name=integer,proto3,oneof"`
}

type DataType_Long

type DataType_Long struct {
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_Long) Descriptor deprecated

func (*DataType_Long) Descriptor() ([]byte, []int)

Deprecated: Use DataType_Long.ProtoReflect.Descriptor instead.

func (*DataType_Long) GetTypeVariationReference

func (x *DataType_Long) GetTypeVariationReference() uint32

func (*DataType_Long) ProtoMessage

func (*DataType_Long) ProtoMessage()

func (*DataType_Long) ProtoReflect

func (x *DataType_Long) ProtoReflect() protoreflect.Message

func (*DataType_Long) Reset

func (x *DataType_Long) Reset()

func (*DataType_Long) String

func (x *DataType_Long) String() string

type DataType_Long_

type DataType_Long_ struct {
	Long *DataType_Long `protobuf:"bytes,7,opt,name=long,proto3,oneof"`
}

type DataType_Map

type DataType_Map struct {
	KeyType                *DataType `protobuf:"bytes,1,opt,name=key_type,json=keyType,proto3" json:"key_type,omitempty"`
	ValueType              *DataType `protobuf:"bytes,2,opt,name=value_type,json=valueType,proto3" json:"value_type,omitempty"`
	ValueContainsNull      bool      `protobuf:"varint,3,opt,name=value_contains_null,json=valueContainsNull,proto3" json:"value_contains_null,omitempty"`
	TypeVariationReference uint32    `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_Map) Descriptor deprecated

func (*DataType_Map) Descriptor() ([]byte, []int)

Deprecated: Use DataType_Map.ProtoReflect.Descriptor instead.

func (*DataType_Map) GetKeyType

func (x *DataType_Map) GetKeyType() *DataType

func (*DataType_Map) GetTypeVariationReference

func (x *DataType_Map) GetTypeVariationReference() uint32

func (*DataType_Map) GetValueContainsNull

func (x *DataType_Map) GetValueContainsNull() bool

func (*DataType_Map) GetValueType

func (x *DataType_Map) GetValueType() *DataType

func (*DataType_Map) ProtoMessage

func (*DataType_Map) ProtoMessage()

func (*DataType_Map) ProtoReflect

func (x *DataType_Map) ProtoReflect() protoreflect.Message

func (*DataType_Map) Reset

func (x *DataType_Map) Reset()

func (*DataType_Map) String

func (x *DataType_Map) String() string

type DataType_Map_

type DataType_Map_ struct {
	Map *DataType_Map `protobuf:"bytes,22,opt,name=map,proto3,oneof"`
}

type DataType_NULL

type DataType_NULL struct {
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_NULL) Descriptor deprecated

func (*DataType_NULL) Descriptor() ([]byte, []int)

Deprecated: Use DataType_NULL.ProtoReflect.Descriptor instead.

func (*DataType_NULL) GetTypeVariationReference

func (x *DataType_NULL) GetTypeVariationReference() uint32

func (*DataType_NULL) ProtoMessage

func (*DataType_NULL) ProtoMessage()

func (*DataType_NULL) ProtoReflect

func (x *DataType_NULL) ProtoReflect() protoreflect.Message

func (*DataType_NULL) Reset

func (x *DataType_NULL) Reset()

func (*DataType_NULL) String

func (x *DataType_NULL) String() string

type DataType_Null

type DataType_Null struct {
	Null *DataType_NULL `protobuf:"bytes,1,opt,name=null,proto3,oneof"`
}

type DataType_Short

type DataType_Short struct {
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_Short) Descriptor deprecated

func (*DataType_Short) Descriptor() ([]byte, []int)

Deprecated: Use DataType_Short.ProtoReflect.Descriptor instead.

func (*DataType_Short) GetTypeVariationReference

func (x *DataType_Short) GetTypeVariationReference() uint32

func (*DataType_Short) ProtoMessage

func (*DataType_Short) ProtoMessage()

func (*DataType_Short) ProtoReflect

func (x *DataType_Short) ProtoReflect() protoreflect.Message

func (*DataType_Short) Reset

func (x *DataType_Short) Reset()

func (*DataType_Short) String

func (x *DataType_Short) String() string

type DataType_Short_

type DataType_Short_ struct {
	Short *DataType_Short `protobuf:"bytes,5,opt,name=short,proto3,oneof"`
}

type DataType_String

type DataType_String struct {
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_String) Descriptor deprecated

func (*DataType_String) Descriptor() ([]byte, []int)

Deprecated: Use DataType_String.ProtoReflect.Descriptor instead.

func (*DataType_String) GetTypeVariationReference

func (x *DataType_String) GetTypeVariationReference() uint32

func (*DataType_String) ProtoMessage

func (*DataType_String) ProtoMessage()

func (*DataType_String) ProtoReflect

func (x *DataType_String) ProtoReflect() protoreflect.Message

func (*DataType_String) Reset

func (x *DataType_String) Reset()

func (*DataType_String) String

func (x *DataType_String) String() string

type DataType_String_

type DataType_String_ struct {
	// String types
	String_ *DataType_String `protobuf:"bytes,11,opt,name=string,proto3,oneof"`
}

type DataType_Struct

type DataType_Struct struct {
	Fields                 []*DataType_StructField `protobuf:"bytes,1,rep,name=fields,proto3" json:"fields,omitempty"`
	TypeVariationReference uint32                  `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_Struct) Descriptor deprecated

func (*DataType_Struct) Descriptor() ([]byte, []int)

Deprecated: Use DataType_Struct.ProtoReflect.Descriptor instead.

func (*DataType_Struct) GetFields

func (x *DataType_Struct) GetFields() []*DataType_StructField

func (*DataType_Struct) GetTypeVariationReference

func (x *DataType_Struct) GetTypeVariationReference() uint32

func (*DataType_Struct) ProtoMessage

func (*DataType_Struct) ProtoMessage()

func (*DataType_Struct) ProtoReflect

func (x *DataType_Struct) ProtoReflect() protoreflect.Message

func (*DataType_Struct) Reset

func (x *DataType_Struct) Reset()

func (*DataType_Struct) String

func (x *DataType_Struct) String() string

type DataType_StructField

type DataType_StructField struct {
	Name     string    `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	DataType *DataType `protobuf:"bytes,2,opt,name=data_type,json=dataType,proto3" json:"data_type,omitempty"`
	Nullable bool      `protobuf:"varint,3,opt,name=nullable,proto3" json:"nullable,omitempty"`
	Metadata *string   `protobuf:"bytes,4,opt,name=metadata,proto3,oneof" json:"metadata,omitempty"`
	// contains filtered or unexported fields
}

func (*DataType_StructField) Descriptor deprecated

func (*DataType_StructField) Descriptor() ([]byte, []int)

Deprecated: Use DataType_StructField.ProtoReflect.Descriptor instead.

func (*DataType_StructField) GetDataType

func (x *DataType_StructField) GetDataType() *DataType

func (*DataType_StructField) GetMetadata

func (x *DataType_StructField) GetMetadata() string

func (*DataType_StructField) GetName

func (x *DataType_StructField) GetName() string

func (*DataType_StructField) GetNullable

func (x *DataType_StructField) GetNullable() bool

func (*DataType_StructField) ProtoMessage

func (*DataType_StructField) ProtoMessage()

func (*DataType_StructField) ProtoReflect

func (x *DataType_StructField) ProtoReflect() protoreflect.Message

func (*DataType_StructField) Reset

func (x *DataType_StructField) Reset()

func (*DataType_StructField) String

func (x *DataType_StructField) String() string

type DataType_Struct_

type DataType_Struct_ struct {
	Struct *DataType_Struct `protobuf:"bytes,21,opt,name=struct,proto3,oneof"`
}

type DataType_Timestamp

type DataType_Timestamp struct {
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_Timestamp) Descriptor deprecated

func (*DataType_Timestamp) Descriptor() ([]byte, []int)

Deprecated: Use DataType_Timestamp.ProtoReflect.Descriptor instead.

func (*DataType_Timestamp) GetTypeVariationReference

func (x *DataType_Timestamp) GetTypeVariationReference() uint32

func (*DataType_Timestamp) ProtoMessage

func (*DataType_Timestamp) ProtoMessage()

func (*DataType_Timestamp) ProtoReflect

func (x *DataType_Timestamp) ProtoReflect() protoreflect.Message

func (*DataType_Timestamp) Reset

func (x *DataType_Timestamp) Reset()

func (*DataType_Timestamp) String

func (x *DataType_Timestamp) String() string

type DataType_TimestampNTZ

type DataType_TimestampNTZ struct {
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_TimestampNTZ) Descriptor deprecated

func (*DataType_TimestampNTZ) Descriptor() ([]byte, []int)

Deprecated: Use DataType_TimestampNTZ.ProtoReflect.Descriptor instead.

func (*DataType_TimestampNTZ) GetTypeVariationReference

func (x *DataType_TimestampNTZ) GetTypeVariationReference() uint32

func (*DataType_TimestampNTZ) ProtoMessage

func (*DataType_TimestampNTZ) ProtoMessage()

func (*DataType_TimestampNTZ) ProtoReflect

func (x *DataType_TimestampNTZ) ProtoReflect() protoreflect.Message

func (*DataType_TimestampNTZ) Reset

func (x *DataType_TimestampNTZ) Reset()

func (*DataType_TimestampNTZ) String

func (x *DataType_TimestampNTZ) String() string

type DataType_TimestampNtz

type DataType_TimestampNtz struct {
	TimestampNtz *DataType_TimestampNTZ `protobuf:"bytes,16,opt,name=timestamp_ntz,json=timestampNtz,proto3,oneof"`
}

type DataType_Timestamp_

type DataType_Timestamp_ struct {
	Timestamp *DataType_Timestamp `protobuf:"bytes,15,opt,name=timestamp,proto3,oneof"`
}

type DataType_UDT

type DataType_UDT struct {
	Type                  string    `protobuf:"bytes,1,opt,name=type,proto3" json:"type,omitempty"`
	JvmClass              *string   `protobuf:"bytes,2,opt,name=jvm_class,json=jvmClass,proto3,oneof" json:"jvm_class,omitempty"`
	PythonClass           *string   `protobuf:"bytes,3,opt,name=python_class,json=pythonClass,proto3,oneof" json:"python_class,omitempty"`
	SerializedPythonClass *string   `` /* 132-byte string literal not displayed */
	SqlType               *DataType `protobuf:"bytes,5,opt,name=sql_type,json=sqlType,proto3" json:"sql_type,omitempty"`
	// contains filtered or unexported fields
}

func (*DataType_UDT) Descriptor deprecated

func (*DataType_UDT) Descriptor() ([]byte, []int)

Deprecated: Use DataType_UDT.ProtoReflect.Descriptor instead.

func (*DataType_UDT) GetJvmClass

func (x *DataType_UDT) GetJvmClass() string

func (*DataType_UDT) GetPythonClass

func (x *DataType_UDT) GetPythonClass() string

func (*DataType_UDT) GetSerializedPythonClass

func (x *DataType_UDT) GetSerializedPythonClass() string

func (*DataType_UDT) GetSqlType

func (x *DataType_UDT) GetSqlType() *DataType

func (*DataType_UDT) GetType

func (x *DataType_UDT) GetType() string

func (*DataType_UDT) ProtoMessage

func (*DataType_UDT) ProtoMessage()

func (*DataType_UDT) ProtoReflect

func (x *DataType_UDT) ProtoReflect() protoreflect.Message

func (*DataType_UDT) Reset

func (x *DataType_UDT) Reset()

func (*DataType_UDT) String

func (x *DataType_UDT) String() string

type DataType_Udt

type DataType_Udt struct {
	// UserDefinedType
	Udt *DataType_UDT `protobuf:"bytes,23,opt,name=udt,proto3,oneof"`
}

type DataType_Unparsed

type DataType_Unparsed struct {

	// (Required) The unparsed data type string
	DataTypeString string `protobuf:"bytes,1,opt,name=data_type_string,json=dataTypeString,proto3" json:"data_type_string,omitempty"`
	// contains filtered or unexported fields
}

func (*DataType_Unparsed) Descriptor deprecated

func (*DataType_Unparsed) Descriptor() ([]byte, []int)

Deprecated: Use DataType_Unparsed.ProtoReflect.Descriptor instead.

func (*DataType_Unparsed) GetDataTypeString

func (x *DataType_Unparsed) GetDataTypeString() string

func (*DataType_Unparsed) ProtoMessage

func (*DataType_Unparsed) ProtoMessage()

func (*DataType_Unparsed) ProtoReflect

func (x *DataType_Unparsed) ProtoReflect() protoreflect.Message

func (*DataType_Unparsed) Reset

func (x *DataType_Unparsed) Reset()

func (*DataType_Unparsed) String

func (x *DataType_Unparsed) String() string

type DataType_Unparsed_

type DataType_Unparsed_ struct {
	// UnparsedDataType
	Unparsed *DataType_Unparsed `protobuf:"bytes,24,opt,name=unparsed,proto3,oneof"`
}

type DataType_VarChar

type DataType_VarChar struct {
	Length                 int32  `protobuf:"varint,1,opt,name=length,proto3" json:"length,omitempty"`
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_VarChar) Descriptor deprecated

func (*DataType_VarChar) Descriptor() ([]byte, []int)

Deprecated: Use DataType_VarChar.ProtoReflect.Descriptor instead.

func (*DataType_VarChar) GetLength

func (x *DataType_VarChar) GetLength() int32

func (*DataType_VarChar) GetTypeVariationReference

func (x *DataType_VarChar) GetTypeVariationReference() uint32

func (*DataType_VarChar) ProtoMessage

func (*DataType_VarChar) ProtoMessage()

func (*DataType_VarChar) ProtoReflect

func (x *DataType_VarChar) ProtoReflect() protoreflect.Message

func (*DataType_VarChar) Reset

func (x *DataType_VarChar) Reset()

func (*DataType_VarChar) String

func (x *DataType_VarChar) String() string

type DataType_VarChar_

type DataType_VarChar_ struct {
	VarChar *DataType_VarChar `protobuf:"bytes,13,opt,name=var_char,json=varChar,proto3,oneof"`
}

type DataType_YearMonthInterval

type DataType_YearMonthInterval struct {
	StartField             *int32 `protobuf:"varint,1,opt,name=start_field,json=startField,proto3,oneof" json:"start_field,omitempty"`
	EndField               *int32 `protobuf:"varint,2,opt,name=end_field,json=endField,proto3,oneof" json:"end_field,omitempty"`
	TypeVariationReference uint32 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*DataType_YearMonthInterval) Descriptor deprecated

func (*DataType_YearMonthInterval) Descriptor() ([]byte, []int)

Deprecated: Use DataType_YearMonthInterval.ProtoReflect.Descriptor instead.

func (*DataType_YearMonthInterval) GetEndField

func (x *DataType_YearMonthInterval) GetEndField() int32

func (*DataType_YearMonthInterval) GetStartField

func (x *DataType_YearMonthInterval) GetStartField() int32

func (*DataType_YearMonthInterval) GetTypeVariationReference

func (x *DataType_YearMonthInterval) GetTypeVariationReference() uint32

func (*DataType_YearMonthInterval) ProtoMessage

func (*DataType_YearMonthInterval) ProtoMessage()

func (*DataType_YearMonthInterval) ProtoReflect

func (*DataType_YearMonthInterval) Reset

func (x *DataType_YearMonthInterval) Reset()

func (*DataType_YearMonthInterval) String

func (x *DataType_YearMonthInterval) String() string

type DataType_YearMonthInterval_

type DataType_YearMonthInterval_ struct {
	YearMonthInterval *DataType_YearMonthInterval `protobuf:"bytes,18,opt,name=year_month_interval,json=yearMonthInterval,proto3,oneof"`
}

type DatabaseExists

type DatabaseExists struct {

	// (Required)
	DbName string `protobuf:"bytes,1,opt,name=db_name,json=dbName,proto3" json:"db_name,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.databaseExists`

func (*DatabaseExists) Descriptor deprecated

func (*DatabaseExists) Descriptor() ([]byte, []int)

Deprecated: Use DatabaseExists.ProtoReflect.Descriptor instead.

func (*DatabaseExists) GetDbName

func (x *DatabaseExists) GetDbName() string

func (*DatabaseExists) ProtoMessage

func (*DatabaseExists) ProtoMessage()

func (*DatabaseExists) ProtoReflect

func (x *DatabaseExists) ProtoReflect() protoreflect.Message

func (*DatabaseExists) Reset

func (x *DatabaseExists) Reset()

func (*DatabaseExists) String

func (x *DatabaseExists) String() string

type Deduplicate

type Deduplicate struct {

	// (Required) Input relation for a Deduplicate.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Optional) Deduplicate based on a list of column names.
	//
	// This field does not co-use with `all_columns_as_keys`.
	ColumnNames []string `protobuf:"bytes,2,rep,name=column_names,json=columnNames,proto3" json:"column_names,omitempty"`
	// (Optional) Deduplicate based on all the columns of the input relation.
	//
	// This field does not co-use with `column_names`.
	AllColumnsAsKeys *bool `protobuf:"varint,3,opt,name=all_columns_as_keys,json=allColumnsAsKeys,proto3,oneof" json:"all_columns_as_keys,omitempty"`
	// (Optional) Deduplicate within the time range of watermark.
	WithinWatermark *bool `protobuf:"varint,4,opt,name=within_watermark,json=withinWatermark,proto3,oneof" json:"within_watermark,omitempty"`
	// contains filtered or unexported fields
}

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

func (*Deduplicate) Descriptor deprecated

func (*Deduplicate) Descriptor() ([]byte, []int)

Deprecated: Use Deduplicate.ProtoReflect.Descriptor instead.

func (*Deduplicate) GetAllColumnsAsKeys

func (x *Deduplicate) GetAllColumnsAsKeys() bool

func (*Deduplicate) GetColumnNames

func (x *Deduplicate) GetColumnNames() []string

func (*Deduplicate) GetInput

func (x *Deduplicate) GetInput() *Relation

func (*Deduplicate) GetWithinWatermark

func (x *Deduplicate) GetWithinWatermark() bool

func (*Deduplicate) ProtoMessage

func (*Deduplicate) ProtoMessage()

func (*Deduplicate) ProtoReflect

func (x *Deduplicate) ProtoReflect() protoreflect.Message

func (*Deduplicate) Reset

func (x *Deduplicate) Reset()

func (*Deduplicate) String

func (x *Deduplicate) String() string

type Drop

type Drop struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Optional) columns to drop.
	Columns []*Expression `protobuf:"bytes,2,rep,name=columns,proto3" json:"columns,omitempty"`
	// (Optional) names of columns to drop.
	ColumnNames []string `protobuf:"bytes,3,rep,name=column_names,json=columnNames,proto3" json:"column_names,omitempty"`
	// contains filtered or unexported fields
}

Drop specified columns.

func (*Drop) Descriptor deprecated

func (*Drop) Descriptor() ([]byte, []int)

Deprecated: Use Drop.ProtoReflect.Descriptor instead.

func (*Drop) GetColumnNames

func (x *Drop) GetColumnNames() []string

func (*Drop) GetColumns

func (x *Drop) GetColumns() []*Expression

func (*Drop) GetInput

func (x *Drop) GetInput() *Relation

func (*Drop) ProtoMessage

func (*Drop) ProtoMessage()

func (*Drop) ProtoReflect

func (x *Drop) ProtoReflect() protoreflect.Message

func (*Drop) Reset

func (x *Drop) Reset()

func (*Drop) String

func (x *Drop) String() string

type DropGlobalTempView

type DropGlobalTempView struct {

	// (Required)
	ViewName string `protobuf:"bytes,1,opt,name=view_name,json=viewName,proto3" json:"view_name,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.dropGlobalTempView`

func (*DropGlobalTempView) Descriptor deprecated

func (*DropGlobalTempView) Descriptor() ([]byte, []int)

Deprecated: Use DropGlobalTempView.ProtoReflect.Descriptor instead.

func (*DropGlobalTempView) GetViewName

func (x *DropGlobalTempView) GetViewName() string

func (*DropGlobalTempView) ProtoMessage

func (*DropGlobalTempView) ProtoMessage()

func (*DropGlobalTempView) ProtoReflect

func (x *DropGlobalTempView) ProtoReflect() protoreflect.Message

func (*DropGlobalTempView) Reset

func (x *DropGlobalTempView) Reset()

func (*DropGlobalTempView) String

func (x *DropGlobalTempView) String() string

type DropTempView

type DropTempView struct {

	// (Required)
	ViewName string `protobuf:"bytes,1,opt,name=view_name,json=viewName,proto3" json:"view_name,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.dropTempView`

func (*DropTempView) Descriptor deprecated

func (*DropTempView) Descriptor() ([]byte, []int)

Deprecated: Use DropTempView.ProtoReflect.Descriptor instead.

func (*DropTempView) GetViewName

func (x *DropTempView) GetViewName() string

func (*DropTempView) ProtoMessage

func (*DropTempView) ProtoMessage()

func (*DropTempView) ProtoReflect

func (x *DropTempView) ProtoReflect() protoreflect.Message

func (*DropTempView) Reset

func (x *DropTempView) Reset()

func (*DropTempView) String

func (x *DropTempView) String() string

type ExamplePluginCommand

type ExamplePluginCommand struct {
	CustomField string `protobuf:"bytes,1,opt,name=custom_field,json=customField,proto3" json:"custom_field,omitempty"`
	// contains filtered or unexported fields
}

func (*ExamplePluginCommand) Descriptor deprecated

func (*ExamplePluginCommand) Descriptor() ([]byte, []int)

Deprecated: Use ExamplePluginCommand.ProtoReflect.Descriptor instead.

func (*ExamplePluginCommand) GetCustomField

func (x *ExamplePluginCommand) GetCustomField() string

func (*ExamplePluginCommand) ProtoMessage

func (*ExamplePluginCommand) ProtoMessage()

func (*ExamplePluginCommand) ProtoReflect

func (x *ExamplePluginCommand) ProtoReflect() protoreflect.Message

func (*ExamplePluginCommand) Reset

func (x *ExamplePluginCommand) Reset()

func (*ExamplePluginCommand) String

func (x *ExamplePluginCommand) String() string

type ExamplePluginExpression

type ExamplePluginExpression struct {
	Child       *Expression `protobuf:"bytes,1,opt,name=child,proto3" json:"child,omitempty"`
	CustomField string      `protobuf:"bytes,2,opt,name=custom_field,json=customField,proto3" json:"custom_field,omitempty"`
	// contains filtered or unexported fields
}

func (*ExamplePluginExpression) Descriptor deprecated

func (*ExamplePluginExpression) Descriptor() ([]byte, []int)

Deprecated: Use ExamplePluginExpression.ProtoReflect.Descriptor instead.

func (*ExamplePluginExpression) GetChild

func (x *ExamplePluginExpression) GetChild() *Expression

func (*ExamplePluginExpression) GetCustomField

func (x *ExamplePluginExpression) GetCustomField() string

func (*ExamplePluginExpression) ProtoMessage

func (*ExamplePluginExpression) ProtoMessage()

func (*ExamplePluginExpression) ProtoReflect

func (x *ExamplePluginExpression) ProtoReflect() protoreflect.Message

func (*ExamplePluginExpression) Reset

func (x *ExamplePluginExpression) Reset()

func (*ExamplePluginExpression) String

func (x *ExamplePluginExpression) String() string

type ExamplePluginRelation

type ExamplePluginRelation struct {
	Input       *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	CustomField string    `protobuf:"bytes,2,opt,name=custom_field,json=customField,proto3" json:"custom_field,omitempty"`
	// contains filtered or unexported fields
}

func (*ExamplePluginRelation) Descriptor deprecated

func (*ExamplePluginRelation) Descriptor() ([]byte, []int)

Deprecated: Use ExamplePluginRelation.ProtoReflect.Descriptor instead.

func (*ExamplePluginRelation) GetCustomField

func (x *ExamplePluginRelation) GetCustomField() string

func (*ExamplePluginRelation) GetInput

func (x *ExamplePluginRelation) GetInput() *Relation

func (*ExamplePluginRelation) ProtoMessage

func (*ExamplePluginRelation) ProtoMessage()

func (*ExamplePluginRelation) ProtoReflect

func (x *ExamplePluginRelation) ProtoReflect() protoreflect.Message

func (*ExamplePluginRelation) Reset

func (x *ExamplePluginRelation) Reset()

func (*ExamplePluginRelation) String

func (x *ExamplePluginRelation) String() string

type ExecutePlanRequest

type ExecutePlanRequest struct {

	// (Required)
	//
	// The session_id specifies a spark session for a user id (which is specified
	// by user_context.user_id). The session_id is set by the client to be able to
	// collate streaming responses from different queries within the dedicated session.
	SessionId string `protobuf:"bytes,1,opt,name=session_id,json=sessionId,proto3" json:"session_id,omitempty"`
	// (Required) User context
	//
	// user_context.user_id and session+id both identify a unique remote spark session on the
	// server side.
	UserContext *UserContext `protobuf:"bytes,2,opt,name=user_context,json=userContext,proto3" json:"user_context,omitempty"`
	// (Required) The logical plan to be executed / analyzed.
	Plan *Plan `protobuf:"bytes,3,opt,name=plan,proto3" json:"plan,omitempty"`
	// Provides optional information about the client sending the request. This field
	// can be used for language or version specific information and is only intended for
	// logging purposes and will not be interpreted by the server.
	ClientType *string `protobuf:"bytes,4,opt,name=client_type,json=clientType,proto3,oneof" json:"client_type,omitempty"`
	// Repeated element for options that can be passed to the request. This element is currently
	// unused but allows to pass in an extension value used for arbitrary options.
	RequestOptions []*ExecutePlanRequest_RequestOption `protobuf:"bytes,5,rep,name=request_options,json=requestOptions,proto3" json:"request_options,omitempty"`
	// contains filtered or unexported fields
}

A request to be executed by the service.

func (*ExecutePlanRequest) Descriptor deprecated

func (*ExecutePlanRequest) Descriptor() ([]byte, []int)

Deprecated: Use ExecutePlanRequest.ProtoReflect.Descriptor instead.

func (*ExecutePlanRequest) GetClientType

func (x *ExecutePlanRequest) GetClientType() string

func (*ExecutePlanRequest) GetPlan

func (x *ExecutePlanRequest) GetPlan() *Plan

func (*ExecutePlanRequest) GetRequestOptions

func (x *ExecutePlanRequest) GetRequestOptions() []*ExecutePlanRequest_RequestOption

func (*ExecutePlanRequest) GetSessionId

func (x *ExecutePlanRequest) GetSessionId() string

func (*ExecutePlanRequest) GetUserContext

func (x *ExecutePlanRequest) GetUserContext() *UserContext

func (*ExecutePlanRequest) ProtoMessage

func (*ExecutePlanRequest) ProtoMessage()

func (*ExecutePlanRequest) ProtoReflect

func (x *ExecutePlanRequest) ProtoReflect() protoreflect.Message

func (*ExecutePlanRequest) Reset

func (x *ExecutePlanRequest) Reset()

func (*ExecutePlanRequest) String

func (x *ExecutePlanRequest) String() string

type ExecutePlanRequest_RequestOption

type ExecutePlanRequest_RequestOption struct {

	// Types that are assignable to RequestOption:
	//
	//	*ExecutePlanRequest_RequestOption_Extension
	RequestOption isExecutePlanRequest_RequestOption_RequestOption `protobuf_oneof:"request_option"`
	// contains filtered or unexported fields
}

func (*ExecutePlanRequest_RequestOption) Descriptor deprecated

func (*ExecutePlanRequest_RequestOption) Descriptor() ([]byte, []int)

Deprecated: Use ExecutePlanRequest_RequestOption.ProtoReflect.Descriptor instead.

func (*ExecutePlanRequest_RequestOption) GetExtension

func (x *ExecutePlanRequest_RequestOption) GetExtension() *anypb.Any

func (*ExecutePlanRequest_RequestOption) GetRequestOption

func (m *ExecutePlanRequest_RequestOption) GetRequestOption() isExecutePlanRequest_RequestOption_RequestOption

func (*ExecutePlanRequest_RequestOption) ProtoMessage

func (*ExecutePlanRequest_RequestOption) ProtoMessage()

func (*ExecutePlanRequest_RequestOption) ProtoReflect

func (*ExecutePlanRequest_RequestOption) Reset

func (*ExecutePlanRequest_RequestOption) String

type ExecutePlanRequest_RequestOption_Extension

type ExecutePlanRequest_RequestOption_Extension struct {
	// Extension type for request options
	Extension *anypb.Any `protobuf:"bytes,999,opt,name=extension,proto3,oneof"`
}

type ExecutePlanResponse

type ExecutePlanResponse struct {
	SessionId string `protobuf:"bytes,1,opt,name=session_id,json=sessionId,proto3" json:"session_id,omitempty"`
	// Union type for the different response messages.
	//
	// Types that are assignable to ResponseType:
	//
	//	*ExecutePlanResponse_ArrowBatch_
	//	*ExecutePlanResponse_SqlCommandResult_
	//	*ExecutePlanResponse_WriteStreamOperationStartResult
	//	*ExecutePlanResponse_StreamingQueryCommandResult
	//	*ExecutePlanResponse_GetResourcesCommandResult
	//	*ExecutePlanResponse_StreamingQueryManagerCommandResult
	//	*ExecutePlanResponse_Extension
	ResponseType isExecutePlanResponse_ResponseType `protobuf_oneof:"response_type"`
	// Metrics for the query execution. Typically, this field is only present in the last
	// batch of results and then represent the overall state of the query execution.
	Metrics *ExecutePlanResponse_Metrics `protobuf:"bytes,4,opt,name=metrics,proto3" json:"metrics,omitempty"`
	// The metrics observed during the execution of the query plan.
	ObservedMetrics []*ExecutePlanResponse_ObservedMetrics `protobuf:"bytes,6,rep,name=observed_metrics,json=observedMetrics,proto3" json:"observed_metrics,omitempty"`
	// (Optional) The Spark schema. This field is available when `collect` is called.
	Schema *DataType `protobuf:"bytes,7,opt,name=schema,proto3" json:"schema,omitempty"`
	// contains filtered or unexported fields
}

The response of a query, can be one or more for each request. Responses belonging to the same input query, carry the same `session_id`.

func (*ExecutePlanResponse) Descriptor deprecated

func (*ExecutePlanResponse) Descriptor() ([]byte, []int)

Deprecated: Use ExecutePlanResponse.ProtoReflect.Descriptor instead.

func (*ExecutePlanResponse) GetArrowBatch

func (*ExecutePlanResponse) GetExtension

func (x *ExecutePlanResponse) GetExtension() *anypb.Any

func (*ExecutePlanResponse) GetGetResourcesCommandResult

func (x *ExecutePlanResponse) GetGetResourcesCommandResult() *GetResourcesCommandResult

func (*ExecutePlanResponse) GetMetrics

func (*ExecutePlanResponse) GetObservedMetrics

func (x *ExecutePlanResponse) GetObservedMetrics() []*ExecutePlanResponse_ObservedMetrics

func (*ExecutePlanResponse) GetResponseType

func (m *ExecutePlanResponse) GetResponseType() isExecutePlanResponse_ResponseType

func (*ExecutePlanResponse) GetSchema

func (x *ExecutePlanResponse) GetSchema() *DataType

func (*ExecutePlanResponse) GetSessionId

func (x *ExecutePlanResponse) GetSessionId() string

func (*ExecutePlanResponse) GetSqlCommandResult

func (*ExecutePlanResponse) GetStreamingQueryCommandResult

func (x *ExecutePlanResponse) GetStreamingQueryCommandResult() *StreamingQueryCommandResult

func (*ExecutePlanResponse) GetStreamingQueryManagerCommandResult

func (x *ExecutePlanResponse) GetStreamingQueryManagerCommandResult() *StreamingQueryManagerCommandResult

func (*ExecutePlanResponse) GetWriteStreamOperationStartResult

func (x *ExecutePlanResponse) GetWriteStreamOperationStartResult() *WriteStreamOperationStartResult

func (*ExecutePlanResponse) ProtoMessage

func (*ExecutePlanResponse) ProtoMessage()

func (*ExecutePlanResponse) ProtoReflect

func (x *ExecutePlanResponse) ProtoReflect() protoreflect.Message

func (*ExecutePlanResponse) Reset

func (x *ExecutePlanResponse) Reset()

func (*ExecutePlanResponse) String

func (x *ExecutePlanResponse) String() string

type ExecutePlanResponse_ArrowBatch

type ExecutePlanResponse_ArrowBatch struct {
	RowCount int64  `protobuf:"varint,1,opt,name=row_count,json=rowCount,proto3" json:"row_count,omitempty"`
	Data     []byte `protobuf:"bytes,2,opt,name=data,proto3" json:"data,omitempty"`
	// contains filtered or unexported fields
}

Batch results of metrics.

func (*ExecutePlanResponse_ArrowBatch) Descriptor deprecated

func (*ExecutePlanResponse_ArrowBatch) Descriptor() ([]byte, []int)

Deprecated: Use ExecutePlanResponse_ArrowBatch.ProtoReflect.Descriptor instead.

func (*ExecutePlanResponse_ArrowBatch) GetData

func (x *ExecutePlanResponse_ArrowBatch) GetData() []byte

func (*ExecutePlanResponse_ArrowBatch) GetRowCount

func (x *ExecutePlanResponse_ArrowBatch) GetRowCount() int64

func (*ExecutePlanResponse_ArrowBatch) ProtoMessage

func (*ExecutePlanResponse_ArrowBatch) ProtoMessage()

func (*ExecutePlanResponse_ArrowBatch) ProtoReflect

func (*ExecutePlanResponse_ArrowBatch) Reset

func (x *ExecutePlanResponse_ArrowBatch) Reset()

func (*ExecutePlanResponse_ArrowBatch) String

type ExecutePlanResponse_ArrowBatch_

type ExecutePlanResponse_ArrowBatch_ struct {
	ArrowBatch *ExecutePlanResponse_ArrowBatch `protobuf:"bytes,2,opt,name=arrow_batch,json=arrowBatch,proto3,oneof"`
}

type ExecutePlanResponse_Extension

type ExecutePlanResponse_Extension struct {
	// Support arbitrary result objects.
	Extension *anypb.Any `protobuf:"bytes,999,opt,name=extension,proto3,oneof"`
}

type ExecutePlanResponse_GetResourcesCommandResult

type ExecutePlanResponse_GetResourcesCommandResult struct {
	// Response for 'SparkContext.resources'.
	GetResourcesCommandResult *GetResourcesCommandResult `protobuf:"bytes,10,opt,name=get_resources_command_result,json=getResourcesCommandResult,proto3,oneof"`
}

type ExecutePlanResponse_Metrics

type ExecutePlanResponse_Metrics struct {
	Metrics []*ExecutePlanResponse_Metrics_MetricObject `protobuf:"bytes,1,rep,name=metrics,proto3" json:"metrics,omitempty"`
	// contains filtered or unexported fields
}

func (*ExecutePlanResponse_Metrics) Descriptor deprecated

func (*ExecutePlanResponse_Metrics) Descriptor() ([]byte, []int)

Deprecated: Use ExecutePlanResponse_Metrics.ProtoReflect.Descriptor instead.

func (*ExecutePlanResponse_Metrics) GetMetrics

func (*ExecutePlanResponse_Metrics) ProtoMessage

func (*ExecutePlanResponse_Metrics) ProtoMessage()

func (*ExecutePlanResponse_Metrics) ProtoReflect

func (*ExecutePlanResponse_Metrics) Reset

func (x *ExecutePlanResponse_Metrics) Reset()

func (*ExecutePlanResponse_Metrics) String

func (x *ExecutePlanResponse_Metrics) String() string

type ExecutePlanResponse_Metrics_MetricObject

type ExecutePlanResponse_Metrics_MetricObject struct {
	Name             string                                              `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	PlanId           int64                                               `protobuf:"varint,2,opt,name=plan_id,json=planId,proto3" json:"plan_id,omitempty"`
	Parent           int64                                               `protobuf:"varint,3,opt,name=parent,proto3" json:"parent,omitempty"`
	ExecutionMetrics map[string]*ExecutePlanResponse_Metrics_MetricValue `` /* 197-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*ExecutePlanResponse_Metrics_MetricObject) Descriptor deprecated

func (*ExecutePlanResponse_Metrics_MetricObject) Descriptor() ([]byte, []int)

Deprecated: Use ExecutePlanResponse_Metrics_MetricObject.ProtoReflect.Descriptor instead.

func (*ExecutePlanResponse_Metrics_MetricObject) GetExecutionMetrics

func (*ExecutePlanResponse_Metrics_MetricObject) GetName

func (*ExecutePlanResponse_Metrics_MetricObject) GetParent

func (*ExecutePlanResponse_Metrics_MetricObject) GetPlanId

func (*ExecutePlanResponse_Metrics_MetricObject) ProtoMessage

func (*ExecutePlanResponse_Metrics_MetricObject) ProtoReflect

func (*ExecutePlanResponse_Metrics_MetricObject) Reset

func (*ExecutePlanResponse_Metrics_MetricObject) String

type ExecutePlanResponse_Metrics_MetricValue

type ExecutePlanResponse_Metrics_MetricValue struct {
	Name       string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	Value      int64  `protobuf:"varint,2,opt,name=value,proto3" json:"value,omitempty"`
	MetricType string `protobuf:"bytes,3,opt,name=metric_type,json=metricType,proto3" json:"metric_type,omitempty"`
	// contains filtered or unexported fields
}

func (*ExecutePlanResponse_Metrics_MetricValue) Descriptor deprecated

func (*ExecutePlanResponse_Metrics_MetricValue) Descriptor() ([]byte, []int)

Deprecated: Use ExecutePlanResponse_Metrics_MetricValue.ProtoReflect.Descriptor instead.

func (*ExecutePlanResponse_Metrics_MetricValue) GetMetricType

func (*ExecutePlanResponse_Metrics_MetricValue) GetName

func (*ExecutePlanResponse_Metrics_MetricValue) GetValue

func (*ExecutePlanResponse_Metrics_MetricValue) ProtoMessage

func (*ExecutePlanResponse_Metrics_MetricValue) ProtoReflect

func (*ExecutePlanResponse_Metrics_MetricValue) Reset

func (*ExecutePlanResponse_Metrics_MetricValue) String

type ExecutePlanResponse_ObservedMetrics

type ExecutePlanResponse_ObservedMetrics struct {
	Name   string                `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	Values []*Expression_Literal `protobuf:"bytes,2,rep,name=values,proto3" json:"values,omitempty"`
	// contains filtered or unexported fields
}

func (*ExecutePlanResponse_ObservedMetrics) Descriptor deprecated

func (*ExecutePlanResponse_ObservedMetrics) Descriptor() ([]byte, []int)

Deprecated: Use ExecutePlanResponse_ObservedMetrics.ProtoReflect.Descriptor instead.

func (*ExecutePlanResponse_ObservedMetrics) GetName

func (*ExecutePlanResponse_ObservedMetrics) GetValues

func (*ExecutePlanResponse_ObservedMetrics) ProtoMessage

func (*ExecutePlanResponse_ObservedMetrics) ProtoMessage()

func (*ExecutePlanResponse_ObservedMetrics) ProtoReflect

func (*ExecutePlanResponse_ObservedMetrics) Reset

func (*ExecutePlanResponse_ObservedMetrics) String

type ExecutePlanResponse_SqlCommandResult

type ExecutePlanResponse_SqlCommandResult struct {
	Relation *Relation `protobuf:"bytes,1,opt,name=relation,proto3" json:"relation,omitempty"`
	// contains filtered or unexported fields
}

A SQL command returns an opaque Relation that can be directly used as input for the next call.

func (*ExecutePlanResponse_SqlCommandResult) Descriptor deprecated

func (*ExecutePlanResponse_SqlCommandResult) Descriptor() ([]byte, []int)

Deprecated: Use ExecutePlanResponse_SqlCommandResult.ProtoReflect.Descriptor instead.

func (*ExecutePlanResponse_SqlCommandResult) GetRelation

func (*ExecutePlanResponse_SqlCommandResult) ProtoMessage

func (*ExecutePlanResponse_SqlCommandResult) ProtoMessage()

func (*ExecutePlanResponse_SqlCommandResult) ProtoReflect

func (*ExecutePlanResponse_SqlCommandResult) Reset

func (*ExecutePlanResponse_SqlCommandResult) String

type ExecutePlanResponse_SqlCommandResult_

type ExecutePlanResponse_SqlCommandResult_ struct {
	// Special case for executing SQL commands.
	SqlCommandResult *ExecutePlanResponse_SqlCommandResult `protobuf:"bytes,5,opt,name=sql_command_result,json=sqlCommandResult,proto3,oneof"`
}

type ExecutePlanResponse_StreamingQueryCommandResult

type ExecutePlanResponse_StreamingQueryCommandResult struct {
	// Response for commands on a streaming query.
	StreamingQueryCommandResult *StreamingQueryCommandResult `protobuf:"bytes,9,opt,name=streaming_query_command_result,json=streamingQueryCommandResult,proto3,oneof"`
}

type ExecutePlanResponse_StreamingQueryManagerCommandResult

type ExecutePlanResponse_StreamingQueryManagerCommandResult struct {
	// Response for commands on the streaming query manager.
	StreamingQueryManagerCommandResult *StreamingQueryManagerCommandResult `protobuf:"bytes,11,opt,name=streaming_query_manager_command_result,json=streamingQueryManagerCommandResult,proto3,oneof"`
}

type ExecutePlanResponse_WriteStreamOperationStartResult

type ExecutePlanResponse_WriteStreamOperationStartResult struct {
	// Response for a streaming query.
	WriteStreamOperationStartResult *WriteStreamOperationStartResult `protobuf:"bytes,8,opt,name=write_stream_operation_start_result,json=writeStreamOperationStartResult,proto3,oneof"`
}

type Expression

type Expression struct {

	// Types that are assignable to ExprType:
	//
	//	*Expression_Literal_
	//	*Expression_UnresolvedAttribute_
	//	*Expression_UnresolvedFunction_
	//	*Expression_ExpressionString_
	//	*Expression_UnresolvedStar_
	//	*Expression_Alias_
	//	*Expression_Cast_
	//	*Expression_UnresolvedRegex_
	//	*Expression_SortOrder_
	//	*Expression_LambdaFunction_
	//	*Expression_Window_
	//	*Expression_UnresolvedExtractValue_
	//	*Expression_UpdateFields_
	//	*Expression_UnresolvedNamedLambdaVariable_
	//	*Expression_CommonInlineUserDefinedFunction
	//	*Expression_Extension
	ExprType isExpression_ExprType `protobuf_oneof:"expr_type"`
	// contains filtered or unexported fields
}

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

func (*Expression) Descriptor deprecated

func (*Expression) Descriptor() ([]byte, []int)

Deprecated: Use Expression.ProtoReflect.Descriptor instead.

func (*Expression) GetAlias

func (x *Expression) GetAlias() *Expression_Alias

func (*Expression) GetCast

func (x *Expression) GetCast() *Expression_Cast

func (*Expression) GetCommonInlineUserDefinedFunction

func (x *Expression) GetCommonInlineUserDefinedFunction() *CommonInlineUserDefinedFunction

func (*Expression) GetExprType

func (m *Expression) GetExprType() isExpression_ExprType

func (*Expression) GetExpressionString

func (x *Expression) GetExpressionString() *Expression_ExpressionString

func (*Expression) GetExtension

func (x *Expression) GetExtension() *anypb.Any

func (*Expression) GetLambdaFunction

func (x *Expression) GetLambdaFunction() *Expression_LambdaFunction

func (*Expression) GetLiteral

func (x *Expression) GetLiteral() *Expression_Literal

func (*Expression) GetSortOrder

func (x *Expression) GetSortOrder() *Expression_SortOrder

func (*Expression) GetUnresolvedAttribute

func (x *Expression) GetUnresolvedAttribute() *Expression_UnresolvedAttribute

func (*Expression) GetUnresolvedExtractValue

func (x *Expression) GetUnresolvedExtractValue() *Expression_UnresolvedExtractValue

func (*Expression) GetUnresolvedFunction

func (x *Expression) GetUnresolvedFunction() *Expression_UnresolvedFunction

func (*Expression) GetUnresolvedNamedLambdaVariable

func (x *Expression) GetUnresolvedNamedLambdaVariable() *Expression_UnresolvedNamedLambdaVariable

func (*Expression) GetUnresolvedRegex

func (x *Expression) GetUnresolvedRegex() *Expression_UnresolvedRegex

func (*Expression) GetUnresolvedStar

func (x *Expression) GetUnresolvedStar() *Expression_UnresolvedStar

func (*Expression) GetUpdateFields

func (x *Expression) GetUpdateFields() *Expression_UpdateFields

func (*Expression) GetWindow

func (x *Expression) GetWindow() *Expression_Window

func (*Expression) ProtoMessage

func (*Expression) ProtoMessage()

func (*Expression) ProtoReflect

func (x *Expression) ProtoReflect() protoreflect.Message

func (*Expression) Reset

func (x *Expression) Reset()

func (*Expression) String

func (x *Expression) String() string

type Expression_Alias

type Expression_Alias struct {

	// (Required) The expression that alias will be added on.
	Expr *Expression `protobuf:"bytes,1,opt,name=expr,proto3" json:"expr,omitempty"`
	// (Required) a list of name parts for the alias.
	//
	// Scalar columns only has one name that presents.
	Name []string `protobuf:"bytes,2,rep,name=name,proto3" json:"name,omitempty"`
	// (Optional) Alias metadata expressed as a JSON map.
	Metadata *string `protobuf:"bytes,3,opt,name=metadata,proto3,oneof" json:"metadata,omitempty"`
	// contains filtered or unexported fields
}

func (*Expression_Alias) Descriptor deprecated

func (*Expression_Alias) Descriptor() ([]byte, []int)

Deprecated: Use Expression_Alias.ProtoReflect.Descriptor instead.

func (*Expression_Alias) GetExpr

func (x *Expression_Alias) GetExpr() *Expression

func (*Expression_Alias) GetMetadata

func (x *Expression_Alias) GetMetadata() string

func (*Expression_Alias) GetName

func (x *Expression_Alias) GetName() []string

func (*Expression_Alias) ProtoMessage

func (*Expression_Alias) ProtoMessage()

func (*Expression_Alias) ProtoReflect

func (x *Expression_Alias) ProtoReflect() protoreflect.Message

func (*Expression_Alias) Reset

func (x *Expression_Alias) Reset()

func (*Expression_Alias) String

func (x *Expression_Alias) String() string

type Expression_Alias_

type Expression_Alias_ struct {
	Alias *Expression_Alias `protobuf:"bytes,6,opt,name=alias,proto3,oneof"`
}

type Expression_Cast

type Expression_Cast struct {

	// (Required) the expression to be casted.
	Expr *Expression `protobuf:"bytes,1,opt,name=expr,proto3" json:"expr,omitempty"`
	// (Required) the data type that the expr to be casted to.
	//
	// Types that are assignable to CastToType:
	//
	//	*Expression_Cast_Type
	//	*Expression_Cast_TypeStr
	CastToType isExpression_Cast_CastToType `protobuf_oneof:"cast_to_type"`
	// contains filtered or unexported fields
}

func (*Expression_Cast) Descriptor deprecated

func (*Expression_Cast) Descriptor() ([]byte, []int)

Deprecated: Use Expression_Cast.ProtoReflect.Descriptor instead.

func (*Expression_Cast) GetCastToType

func (m *Expression_Cast) GetCastToType() isExpression_Cast_CastToType

func (*Expression_Cast) GetExpr

func (x *Expression_Cast) GetExpr() *Expression

func (*Expression_Cast) GetType

func (x *Expression_Cast) GetType() *DataType

func (*Expression_Cast) GetTypeStr

func (x *Expression_Cast) GetTypeStr() string

func (*Expression_Cast) ProtoMessage

func (*Expression_Cast) ProtoMessage()

func (*Expression_Cast) ProtoReflect

func (x *Expression_Cast) ProtoReflect() protoreflect.Message

func (*Expression_Cast) Reset

func (x *Expression_Cast) Reset()

func (*Expression_Cast) String

func (x *Expression_Cast) String() string

type Expression_Cast_

type Expression_Cast_ struct {
	Cast *Expression_Cast `protobuf:"bytes,7,opt,name=cast,proto3,oneof"`
}

type Expression_Cast_Type

type Expression_Cast_Type struct {
	Type *DataType `protobuf:"bytes,2,opt,name=type,proto3,oneof"`
}

type Expression_Cast_TypeStr

type Expression_Cast_TypeStr struct {
	// If this is set, Server will use Catalyst parser to parse this string to DataType.
	TypeStr string `protobuf:"bytes,3,opt,name=type_str,json=typeStr,proto3,oneof"`
}

type Expression_CommonInlineUserDefinedFunction

type Expression_CommonInlineUserDefinedFunction struct {
	CommonInlineUserDefinedFunction *CommonInlineUserDefinedFunction `protobuf:"bytes,15,opt,name=common_inline_user_defined_function,json=commonInlineUserDefinedFunction,proto3,oneof"`
}

type Expression_ExpressionString

type Expression_ExpressionString struct {

	// (Required) A SQL expression that will be parsed by Catalyst parser.
	Expression string `protobuf:"bytes,1,opt,name=expression,proto3" json:"expression,omitempty"`
	// contains filtered or unexported fields
}

Expression as string.

func (*Expression_ExpressionString) Descriptor deprecated

func (*Expression_ExpressionString) Descriptor() ([]byte, []int)

Deprecated: Use Expression_ExpressionString.ProtoReflect.Descriptor instead.

func (*Expression_ExpressionString) GetExpression

func (x *Expression_ExpressionString) GetExpression() string

func (*Expression_ExpressionString) ProtoMessage

func (*Expression_ExpressionString) ProtoMessage()

func (*Expression_ExpressionString) ProtoReflect

func (*Expression_ExpressionString) Reset

func (x *Expression_ExpressionString) Reset()

func (*Expression_ExpressionString) String

func (x *Expression_ExpressionString) String() string

type Expression_ExpressionString_

type Expression_ExpressionString_ struct {
	ExpressionString *Expression_ExpressionString `protobuf:"bytes,4,opt,name=expression_string,json=expressionString,proto3,oneof"`
}

type Expression_Extension

type Expression_Extension struct {
	// 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.
	Extension *anypb.Any `protobuf:"bytes,999,opt,name=extension,proto3,oneof"`
}

type Expression_LambdaFunction

type Expression_LambdaFunction struct {

	// (Required) The lambda function.
	//
	// The function body should use 'UnresolvedAttribute' as arguments, the sever side will
	// replace 'UnresolvedAttribute' with 'UnresolvedNamedLambdaVariable'.
	Function *Expression `protobuf:"bytes,1,opt,name=function,proto3" json:"function,omitempty"`
	// (Required) Function variables. Must contains 1 ~ 3 variables.
	Arguments []*Expression_UnresolvedNamedLambdaVariable `protobuf:"bytes,2,rep,name=arguments,proto3" json:"arguments,omitempty"`
	// contains filtered or unexported fields
}

func (*Expression_LambdaFunction) Descriptor deprecated

func (*Expression_LambdaFunction) Descriptor() ([]byte, []int)

Deprecated: Use Expression_LambdaFunction.ProtoReflect.Descriptor instead.

func (*Expression_LambdaFunction) GetArguments

func (*Expression_LambdaFunction) GetFunction

func (x *Expression_LambdaFunction) GetFunction() *Expression

func (*Expression_LambdaFunction) ProtoMessage

func (*Expression_LambdaFunction) ProtoMessage()

func (*Expression_LambdaFunction) ProtoReflect

func (*Expression_LambdaFunction) Reset

func (x *Expression_LambdaFunction) Reset()

func (*Expression_LambdaFunction) String

func (x *Expression_LambdaFunction) String() string

type Expression_LambdaFunction_

type Expression_LambdaFunction_ struct {
	LambdaFunction *Expression_LambdaFunction `protobuf:"bytes,10,opt,name=lambda_function,json=lambdaFunction,proto3,oneof"`
}

type Expression_Literal

type Expression_Literal struct {

	// Types that are assignable to LiteralType:
	//
	//	*Expression_Literal_Null
	//	*Expression_Literal_Binary
	//	*Expression_Literal_Boolean
	//	*Expression_Literal_Byte
	//	*Expression_Literal_Short
	//	*Expression_Literal_Integer
	//	*Expression_Literal_Long
	//	*Expression_Literal_Float
	//	*Expression_Literal_Double
	//	*Expression_Literal_Decimal_
	//	*Expression_Literal_String_
	//	*Expression_Literal_Date
	//	*Expression_Literal_Timestamp
	//	*Expression_Literal_TimestampNtz
	//	*Expression_Literal_CalendarInterval_
	//	*Expression_Literal_YearMonthInterval
	//	*Expression_Literal_DayTimeInterval
	//	*Expression_Literal_Array_
	//	*Expression_Literal_Map_
	//	*Expression_Literal_Struct_
	LiteralType isExpression_Literal_LiteralType `protobuf_oneof:"literal_type"`
	// contains filtered or unexported fields
}

func (*Expression_Literal) Descriptor deprecated

func (*Expression_Literal) Descriptor() ([]byte, []int)

Deprecated: Use Expression_Literal.ProtoReflect.Descriptor instead.

func (*Expression_Literal) GetArray

func (*Expression_Literal) GetBinary

func (x *Expression_Literal) GetBinary() []byte

func (*Expression_Literal) GetBoolean

func (x *Expression_Literal) GetBoolean() bool

func (*Expression_Literal) GetByte

func (x *Expression_Literal) GetByte() int32

func (*Expression_Literal) GetCalendarInterval

func (x *Expression_Literal) GetCalendarInterval() *Expression_Literal_CalendarInterval

func (*Expression_Literal) GetDate

func (x *Expression_Literal) GetDate() int32

func (*Expression_Literal) GetDayTimeInterval

func (x *Expression_Literal) GetDayTimeInterval() int64

func (*Expression_Literal) GetDecimal

func (*Expression_Literal) GetDouble

func (x *Expression_Literal) GetDouble() float64

func (*Expression_Literal) GetFloat

func (x *Expression_Literal) GetFloat() float32

func (*Expression_Literal) GetInteger

func (x *Expression_Literal) GetInteger() int32

func (*Expression_Literal) GetLiteralType

func (m *Expression_Literal) GetLiteralType() isExpression_Literal_LiteralType

func (*Expression_Literal) GetLong

func (x *Expression_Literal) GetLong() int64

func (*Expression_Literal) GetMap

func (*Expression_Literal) GetNull

func (x *Expression_Literal) GetNull() *DataType

func (*Expression_Literal) GetShort

func (x *Expression_Literal) GetShort() int32

func (*Expression_Literal) GetString_

func (x *Expression_Literal) GetString_() string

func (*Expression_Literal) GetStruct

func (*Expression_Literal) GetTimestamp

func (x *Expression_Literal) GetTimestamp() int64

func (*Expression_Literal) GetTimestampNtz

func (x *Expression_Literal) GetTimestampNtz() int64

func (*Expression_Literal) GetYearMonthInterval

func (x *Expression_Literal) GetYearMonthInterval() int32

func (*Expression_Literal) ProtoMessage

func (*Expression_Literal) ProtoMessage()

func (*Expression_Literal) ProtoReflect

func (x *Expression_Literal) ProtoReflect() protoreflect.Message

func (*Expression_Literal) Reset

func (x *Expression_Literal) Reset()

func (*Expression_Literal) String

func (x *Expression_Literal) String() string

type Expression_Literal_

type Expression_Literal_ struct {
	Literal *Expression_Literal `protobuf:"bytes,1,opt,name=literal,proto3,oneof"`
}

type Expression_Literal_Array

type Expression_Literal_Array struct {
	ElementType *DataType             `protobuf:"bytes,1,opt,name=element_type,json=elementType,proto3" json:"element_type,omitempty"`
	Elements    []*Expression_Literal `protobuf:"bytes,2,rep,name=elements,proto3" json:"elements,omitempty"`
	// contains filtered or unexported fields
}

func (*Expression_Literal_Array) Descriptor deprecated

func (*Expression_Literal_Array) Descriptor() ([]byte, []int)

Deprecated: Use Expression_Literal_Array.ProtoReflect.Descriptor instead.

func (*Expression_Literal_Array) GetElementType

func (x *Expression_Literal_Array) GetElementType() *DataType

func (*Expression_Literal_Array) GetElements

func (x *Expression_Literal_Array) GetElements() []*Expression_Literal

func (*Expression_Literal_Array) ProtoMessage

func (*Expression_Literal_Array) ProtoMessage()

func (*Expression_Literal_Array) ProtoReflect

func (x *Expression_Literal_Array) ProtoReflect() protoreflect.Message

func (*Expression_Literal_Array) Reset

func (x *Expression_Literal_Array) Reset()

func (*Expression_Literal_Array) String

func (x *Expression_Literal_Array) String() string

type Expression_Literal_Array_

type Expression_Literal_Array_ struct {
	Array *Expression_Literal_Array `protobuf:"bytes,22,opt,name=array,proto3,oneof"`
}

type Expression_Literal_Binary

type Expression_Literal_Binary struct {
	Binary []byte `protobuf:"bytes,2,opt,name=binary,proto3,oneof"`
}

type Expression_Literal_Boolean

type Expression_Literal_Boolean struct {
	Boolean bool `protobuf:"varint,3,opt,name=boolean,proto3,oneof"`
}

type Expression_Literal_Byte

type Expression_Literal_Byte struct {
	Byte int32 `protobuf:"varint,4,opt,name=byte,proto3,oneof"`
}

type Expression_Literal_CalendarInterval

type Expression_Literal_CalendarInterval struct {
	Months       int32 `protobuf:"varint,1,opt,name=months,proto3" json:"months,omitempty"`
	Days         int32 `protobuf:"varint,2,opt,name=days,proto3" json:"days,omitempty"`
	Microseconds int64 `protobuf:"varint,3,opt,name=microseconds,proto3" json:"microseconds,omitempty"`
	// contains filtered or unexported fields
}

func (*Expression_Literal_CalendarInterval) Descriptor deprecated

func (*Expression_Literal_CalendarInterval) Descriptor() ([]byte, []int)

Deprecated: Use Expression_Literal_CalendarInterval.ProtoReflect.Descriptor instead.

func (*Expression_Literal_CalendarInterval) GetDays

func (*Expression_Literal_CalendarInterval) GetMicroseconds

func (x *Expression_Literal_CalendarInterval) GetMicroseconds() int64

func (*Expression_Literal_CalendarInterval) GetMonths

func (*Expression_Literal_CalendarInterval) ProtoMessage

func (*Expression_Literal_CalendarInterval) ProtoMessage()

func (*Expression_Literal_CalendarInterval) ProtoReflect

func (*Expression_Literal_CalendarInterval) Reset

func (*Expression_Literal_CalendarInterval) String

type Expression_Literal_CalendarInterval_

type Expression_Literal_CalendarInterval_ struct {
	CalendarInterval *Expression_Literal_CalendarInterval `protobuf:"bytes,19,opt,name=calendar_interval,json=calendarInterval,proto3,oneof"`
}

type Expression_Literal_Date

type Expression_Literal_Date struct {
	// Date in units of days since the UNIX epoch.
	Date int32 `protobuf:"varint,16,opt,name=date,proto3,oneof"`
}

type Expression_Literal_DayTimeInterval

type Expression_Literal_DayTimeInterval struct {
	DayTimeInterval int64 `protobuf:"varint,21,opt,name=day_time_interval,json=dayTimeInterval,proto3,oneof"`
}

type Expression_Literal_Decimal

type Expression_Literal_Decimal struct {

	// the string representation.
	Value string `protobuf:"bytes,1,opt,name=value,proto3" json:"value,omitempty"`
	// The maximum number of digits allowed in the value.
	// the maximum precision is 38.
	Precision *int32 `protobuf:"varint,2,opt,name=precision,proto3,oneof" json:"precision,omitempty"`
	// declared scale of decimal literal
	Scale *int32 `protobuf:"varint,3,opt,name=scale,proto3,oneof" json:"scale,omitempty"`
	// contains filtered or unexported fields
}

func (*Expression_Literal_Decimal) Descriptor deprecated

func (*Expression_Literal_Decimal) Descriptor() ([]byte, []int)

Deprecated: Use Expression_Literal_Decimal.ProtoReflect.Descriptor instead.

func (*Expression_Literal_Decimal) GetPrecision

func (x *Expression_Literal_Decimal) GetPrecision() int32

func (*Expression_Literal_Decimal) GetScale

func (x *Expression_Literal_Decimal) GetScale() int32

func (*Expression_Literal_Decimal) GetValue

func (x *Expression_Literal_Decimal) GetValue() string

func (*Expression_Literal_Decimal) ProtoMessage

func (*Expression_Literal_Decimal) ProtoMessage()

func (*Expression_Literal_Decimal) ProtoReflect

func (*Expression_Literal_Decimal) Reset

func (x *Expression_Literal_Decimal) Reset()

func (*Expression_Literal_Decimal) String

func (x *Expression_Literal_Decimal) String() string

type Expression_Literal_Decimal_

type Expression_Literal_Decimal_ struct {
	Decimal *Expression_Literal_Decimal `protobuf:"bytes,12,opt,name=decimal,proto3,oneof"`
}

type Expression_Literal_Double

type Expression_Literal_Double struct {
	Double float64 `protobuf:"fixed64,11,opt,name=double,proto3,oneof"`
}

type Expression_Literal_Float

type Expression_Literal_Float struct {
	Float float32 `protobuf:"fixed32,10,opt,name=float,proto3,oneof"`
}

type Expression_Literal_Integer

type Expression_Literal_Integer struct {
	Integer int32 `protobuf:"varint,6,opt,name=integer,proto3,oneof"`
}

type Expression_Literal_Long

type Expression_Literal_Long struct {
	Long int64 `protobuf:"varint,7,opt,name=long,proto3,oneof"`
}

type Expression_Literal_Map

type Expression_Literal_Map struct {
	KeyType   *DataType             `protobuf:"bytes,1,opt,name=key_type,json=keyType,proto3" json:"key_type,omitempty"`
	ValueType *DataType             `protobuf:"bytes,2,opt,name=value_type,json=valueType,proto3" json:"value_type,omitempty"`
	Keys      []*Expression_Literal `protobuf:"bytes,3,rep,name=keys,proto3" json:"keys,omitempty"`
	Values    []*Expression_Literal `protobuf:"bytes,4,rep,name=values,proto3" json:"values,omitempty"`
	// contains filtered or unexported fields
}

func (*Expression_Literal_Map) Descriptor deprecated

func (*Expression_Literal_Map) Descriptor() ([]byte, []int)

Deprecated: Use Expression_Literal_Map.ProtoReflect.Descriptor instead.

func (*Expression_Literal_Map) GetKeyType

func (x *Expression_Literal_Map) GetKeyType() *DataType

func (*Expression_Literal_Map) GetKeys

func (*Expression_Literal_Map) GetValueType

func (x *Expression_Literal_Map) GetValueType() *DataType

func (*Expression_Literal_Map) GetValues

func (x *Expression_Literal_Map) GetValues() []*Expression_Literal

func (*Expression_Literal_Map) ProtoMessage

func (*Expression_Literal_Map) ProtoMessage()

func (*Expression_Literal_Map) ProtoReflect

func (x *Expression_Literal_Map) ProtoReflect() protoreflect.Message

func (*Expression_Literal_Map) Reset

func (x *Expression_Literal_Map) Reset()

func (*Expression_Literal_Map) String

func (x *Expression_Literal_Map) String() string

type Expression_Literal_Map_

type Expression_Literal_Map_ struct {
	Map *Expression_Literal_Map `protobuf:"bytes,23,opt,name=map,proto3,oneof"`
}

type Expression_Literal_Null

type Expression_Literal_Null struct {
	Null *DataType `protobuf:"bytes,1,opt,name=null,proto3,oneof"`
}

type Expression_Literal_Short

type Expression_Literal_Short struct {
	Short int32 `protobuf:"varint,5,opt,name=short,proto3,oneof"`
}

type Expression_Literal_String_

type Expression_Literal_String_ struct {
	String_ string `protobuf:"bytes,13,opt,name=string,proto3,oneof"`
}

type Expression_Literal_Struct

type Expression_Literal_Struct struct {
	StructType *DataType             `protobuf:"bytes,1,opt,name=struct_type,json=structType,proto3" json:"struct_type,omitempty"`
	Elements   []*Expression_Literal `protobuf:"bytes,2,rep,name=elements,proto3" json:"elements,omitempty"`
	// contains filtered or unexported fields
}

func (*Expression_Literal_Struct) Descriptor deprecated

func (*Expression_Literal_Struct) Descriptor() ([]byte, []int)

Deprecated: Use Expression_Literal_Struct.ProtoReflect.Descriptor instead.

func (*Expression_Literal_Struct) GetElements

func (x *Expression_Literal_Struct) GetElements() []*Expression_Literal

func (*Expression_Literal_Struct) GetStructType

func (x *Expression_Literal_Struct) GetStructType() *DataType

func (*Expression_Literal_Struct) ProtoMessage

func (*Expression_Literal_Struct) ProtoMessage()

func (*Expression_Literal_Struct) ProtoReflect

func (*Expression_Literal_Struct) Reset

func (x *Expression_Literal_Struct) Reset()

func (*Expression_Literal_Struct) String

func (x *Expression_Literal_Struct) String() string

type Expression_Literal_Struct_

type Expression_Literal_Struct_ struct {
	Struct *Expression_Literal_Struct `protobuf:"bytes,24,opt,name=struct,proto3,oneof"`
}

type Expression_Literal_Timestamp

type Expression_Literal_Timestamp struct {
	// Timestamp in units of microseconds since the UNIX epoch.
	Timestamp int64 `protobuf:"varint,17,opt,name=timestamp,proto3,oneof"`
}

type Expression_Literal_TimestampNtz

type Expression_Literal_TimestampNtz struct {
	// Timestamp in units of microseconds since the UNIX epoch (without timezone information).
	TimestampNtz int64 `protobuf:"varint,18,opt,name=timestamp_ntz,json=timestampNtz,proto3,oneof"`
}

type Expression_Literal_YearMonthInterval

type Expression_Literal_YearMonthInterval struct {
	YearMonthInterval int32 `protobuf:"varint,20,opt,name=year_month_interval,json=yearMonthInterval,proto3,oneof"`
}

type Expression_SortOrder

type Expression_SortOrder struct {

	// (Required) The expression to be sorted.
	Child *Expression `protobuf:"bytes,1,opt,name=child,proto3" json:"child,omitempty"`
	// (Required) The sort direction, should be ASCENDING or DESCENDING.
	Direction Expression_SortOrder_SortDirection `` /* 126-byte string literal not displayed */
	// (Required) How to deal with NULLs, should be NULLS_FIRST or NULLS_LAST.
	NullOrdering Expression_SortOrder_NullOrdering `` /* 151-byte string literal not displayed */
	// contains filtered or unexported fields
}

SortOrder is used to specify the data ordering, it is normally used in Sort and Window. It is an unevaluable expression and cannot be evaluated, so can not be used in Projection.

func (*Expression_SortOrder) Descriptor deprecated

func (*Expression_SortOrder) Descriptor() ([]byte, []int)

Deprecated: Use Expression_SortOrder.ProtoReflect.Descriptor instead.

func (*Expression_SortOrder) GetChild

func (x *Expression_SortOrder) GetChild() *Expression

func (*Expression_SortOrder) GetDirection

func (*Expression_SortOrder) GetNullOrdering

func (*Expression_SortOrder) ProtoMessage

func (*Expression_SortOrder) ProtoMessage()

func (*Expression_SortOrder) ProtoReflect

func (x *Expression_SortOrder) ProtoReflect() protoreflect.Message

func (*Expression_SortOrder) Reset

func (x *Expression_SortOrder) Reset()

func (*Expression_SortOrder) String

func (x *Expression_SortOrder) String() string

type Expression_SortOrder_

type Expression_SortOrder_ struct {
	SortOrder *Expression_SortOrder `protobuf:"bytes,9,opt,name=sort_order,json=sortOrder,proto3,oneof"`
}

type Expression_SortOrder_NullOrdering

type Expression_SortOrder_NullOrdering int32
const (
	Expression_SortOrder_SORT_NULLS_UNSPECIFIED Expression_SortOrder_NullOrdering = 0
	Expression_SortOrder_SORT_NULLS_FIRST       Expression_SortOrder_NullOrdering = 1
	Expression_SortOrder_SORT_NULLS_LAST        Expression_SortOrder_NullOrdering = 2
)

func (Expression_SortOrder_NullOrdering) Descriptor

func (Expression_SortOrder_NullOrdering) Enum

func (Expression_SortOrder_NullOrdering) EnumDescriptor deprecated

func (Expression_SortOrder_NullOrdering) EnumDescriptor() ([]byte, []int)

Deprecated: Use Expression_SortOrder_NullOrdering.Descriptor instead.

func (Expression_SortOrder_NullOrdering) Number

func (Expression_SortOrder_NullOrdering) String

func (Expression_SortOrder_NullOrdering) Type

type Expression_SortOrder_SortDirection

type Expression_SortOrder_SortDirection int32
const (
	Expression_SortOrder_SORT_DIRECTION_UNSPECIFIED Expression_SortOrder_SortDirection = 0
	Expression_SortOrder_SORT_DIRECTION_ASCENDING   Expression_SortOrder_SortDirection = 1
	Expression_SortOrder_SORT_DIRECTION_DESCENDING  Expression_SortOrder_SortDirection = 2
)

func (Expression_SortOrder_SortDirection) Descriptor

func (Expression_SortOrder_SortDirection) Enum

func (Expression_SortOrder_SortDirection) EnumDescriptor deprecated

func (Expression_SortOrder_SortDirection) EnumDescriptor() ([]byte, []int)

Deprecated: Use Expression_SortOrder_SortDirection.Descriptor instead.

func (Expression_SortOrder_SortDirection) Number

func (Expression_SortOrder_SortDirection) String

func (Expression_SortOrder_SortDirection) Type

type Expression_UnresolvedAttribute

type Expression_UnresolvedAttribute struct {

	// (Required) An identifier that will be parsed by Catalyst parser. This should follow the
	// Spark SQL identifier syntax.
	UnparsedIdentifier string `protobuf:"bytes,1,opt,name=unparsed_identifier,json=unparsedIdentifier,proto3" json:"unparsed_identifier,omitempty"`
	// (Optional) The id of corresponding connect plan.
	PlanId *int64 `protobuf:"varint,2,opt,name=plan_id,json=planId,proto3,oneof" json:"plan_id,omitempty"`
	// contains filtered or unexported fields
}

An unresolved attribute that is not explicitly bound to a specific column, but the column is resolved during analysis by name.

func (*Expression_UnresolvedAttribute) Descriptor deprecated

func (*Expression_UnresolvedAttribute) Descriptor() ([]byte, []int)

Deprecated: Use Expression_UnresolvedAttribute.ProtoReflect.Descriptor instead.

func (*Expression_UnresolvedAttribute) GetPlanId

func (x *Expression_UnresolvedAttribute) GetPlanId() int64

func (*Expression_UnresolvedAttribute) GetUnparsedIdentifier

func (x *Expression_UnresolvedAttribute) GetUnparsedIdentifier() string

func (*Expression_UnresolvedAttribute) ProtoMessage

func (*Expression_UnresolvedAttribute) ProtoMessage()

func (*Expression_UnresolvedAttribute) ProtoReflect

func (*Expression_UnresolvedAttribute) Reset

func (x *Expression_UnresolvedAttribute) Reset()

func (*Expression_UnresolvedAttribute) String

type Expression_UnresolvedAttribute_

type Expression_UnresolvedAttribute_ struct {
	UnresolvedAttribute *Expression_UnresolvedAttribute `protobuf:"bytes,2,opt,name=unresolved_attribute,json=unresolvedAttribute,proto3,oneof"`
}

type Expression_UnresolvedExtractValue

type Expression_UnresolvedExtractValue struct {

	// (Required) The expression to extract value from, can be
	// Map, Array, Struct or array of Structs.
	Child *Expression `protobuf:"bytes,1,opt,name=child,proto3" json:"child,omitempty"`
	// (Required) The expression to describe the extraction, can be
	// key of Map, index of Array, field name of Struct.
	Extraction *Expression `protobuf:"bytes,2,opt,name=extraction,proto3" json:"extraction,omitempty"`
	// contains filtered or unexported fields
}

Extracts a value or values from an Expression

func (*Expression_UnresolvedExtractValue) Descriptor deprecated

func (*Expression_UnresolvedExtractValue) Descriptor() ([]byte, []int)

Deprecated: Use Expression_UnresolvedExtractValue.ProtoReflect.Descriptor instead.

func (*Expression_UnresolvedExtractValue) GetChild

func (*Expression_UnresolvedExtractValue) GetExtraction

func (x *Expression_UnresolvedExtractValue) GetExtraction() *Expression

func (*Expression_UnresolvedExtractValue) ProtoMessage

func (*Expression_UnresolvedExtractValue) ProtoMessage()

func (*Expression_UnresolvedExtractValue) ProtoReflect

func (*Expression_UnresolvedExtractValue) Reset

func (*Expression_UnresolvedExtractValue) String

type Expression_UnresolvedExtractValue_

type Expression_UnresolvedExtractValue_ struct {
	UnresolvedExtractValue *Expression_UnresolvedExtractValue `protobuf:"bytes,12,opt,name=unresolved_extract_value,json=unresolvedExtractValue,proto3,oneof"`
}

type Expression_UnresolvedFunction

type Expression_UnresolvedFunction struct {

	// (Required) name (or unparsed name for user defined function) for the unresolved function.
	FunctionName string `protobuf:"bytes,1,opt,name=function_name,json=functionName,proto3" json:"function_name,omitempty"`
	// (Optional) Function arguments. Empty arguments are allowed.
	Arguments []*Expression `protobuf:"bytes,2,rep,name=arguments,proto3" json:"arguments,omitempty"`
	// (Required) Indicate if this function should be applied on distinct values.
	IsDistinct bool `protobuf:"varint,3,opt,name=is_distinct,json=isDistinct,proto3" json:"is_distinct,omitempty"`
	// (Required) Indicate if this is a user defined function.
	//
	// When it is not a user defined function, Connect will use the function name directly.
	// When it is a user defined function, Connect will parse the function name first.
	IsUserDefinedFunction bool `` /* 129-byte string literal not displayed */
	// contains filtered or unexported fields
}

An unresolved function is not explicitly bound to one explicit function, but the function is resolved during analysis following Sparks name resolution rules.

func (*Expression_UnresolvedFunction) Descriptor deprecated

func (*Expression_UnresolvedFunction) Descriptor() ([]byte, []int)

Deprecated: Use Expression_UnresolvedFunction.ProtoReflect.Descriptor instead.

func (*Expression_UnresolvedFunction) GetArguments

func (x *Expression_UnresolvedFunction) GetArguments() []*Expression

func (*Expression_UnresolvedFunction) GetFunctionName

func (x *Expression_UnresolvedFunction) GetFunctionName() string

func (*Expression_UnresolvedFunction) GetIsDistinct

func (x *Expression_UnresolvedFunction) GetIsDistinct() bool

func (*Expression_UnresolvedFunction) GetIsUserDefinedFunction

func (x *Expression_UnresolvedFunction) GetIsUserDefinedFunction() bool

func (*Expression_UnresolvedFunction) ProtoMessage

func (*Expression_UnresolvedFunction) ProtoMessage()

func (*Expression_UnresolvedFunction) ProtoReflect

func (*Expression_UnresolvedFunction) Reset

func (x *Expression_UnresolvedFunction) Reset()

func (*Expression_UnresolvedFunction) String

type Expression_UnresolvedFunction_

type Expression_UnresolvedFunction_ struct {
	UnresolvedFunction *Expression_UnresolvedFunction `protobuf:"bytes,3,opt,name=unresolved_function,json=unresolvedFunction,proto3,oneof"`
}

type Expression_UnresolvedNamedLambdaVariable

type Expression_UnresolvedNamedLambdaVariable struct {

	// (Required) a list of name parts for the variable. Must not be empty.
	NameParts []string `protobuf:"bytes,1,rep,name=name_parts,json=nameParts,proto3" json:"name_parts,omitempty"`
	// contains filtered or unexported fields
}

func (*Expression_UnresolvedNamedLambdaVariable) Descriptor deprecated

func (*Expression_UnresolvedNamedLambdaVariable) Descriptor() ([]byte, []int)

Deprecated: Use Expression_UnresolvedNamedLambdaVariable.ProtoReflect.Descriptor instead.

func (*Expression_UnresolvedNamedLambdaVariable) GetNameParts

func (*Expression_UnresolvedNamedLambdaVariable) ProtoMessage

func (*Expression_UnresolvedNamedLambdaVariable) ProtoReflect

func (*Expression_UnresolvedNamedLambdaVariable) Reset

func (*Expression_UnresolvedNamedLambdaVariable) String

type Expression_UnresolvedNamedLambdaVariable_

type Expression_UnresolvedNamedLambdaVariable_ struct {
	UnresolvedNamedLambdaVariable *Expression_UnresolvedNamedLambdaVariable `protobuf:"bytes,14,opt,name=unresolved_named_lambda_variable,json=unresolvedNamedLambdaVariable,proto3,oneof"`
}

type Expression_UnresolvedRegex

type Expression_UnresolvedRegex struct {

	// (Required) The column name used to extract column with regex.
	ColName string `protobuf:"bytes,1,opt,name=col_name,json=colName,proto3" json:"col_name,omitempty"`
	// (Optional) The id of corresponding connect plan.
	PlanId *int64 `protobuf:"varint,2,opt,name=plan_id,json=planId,proto3,oneof" json:"plan_id,omitempty"`
	// contains filtered or unexported fields
}

Represents all of the input attributes to a given relational operator, for example in "SELECT `(id)?+.+` FROM ...".

func (*Expression_UnresolvedRegex) Descriptor deprecated

func (*Expression_UnresolvedRegex) Descriptor() ([]byte, []int)

Deprecated: Use Expression_UnresolvedRegex.ProtoReflect.Descriptor instead.

func (*Expression_UnresolvedRegex) GetColName

func (x *Expression_UnresolvedRegex) GetColName() string

func (*Expression_UnresolvedRegex) GetPlanId

func (x *Expression_UnresolvedRegex) GetPlanId() int64

func (*Expression_UnresolvedRegex) ProtoMessage

func (*Expression_UnresolvedRegex) ProtoMessage()

func (*Expression_UnresolvedRegex) ProtoReflect

func (*Expression_UnresolvedRegex) Reset

func (x *Expression_UnresolvedRegex) Reset()

func (*Expression_UnresolvedRegex) String

func (x *Expression_UnresolvedRegex) String() string

type Expression_UnresolvedRegex_

type Expression_UnresolvedRegex_ struct {
	UnresolvedRegex *Expression_UnresolvedRegex `protobuf:"bytes,8,opt,name=unresolved_regex,json=unresolvedRegex,proto3,oneof"`
}

type Expression_UnresolvedStar

type Expression_UnresolvedStar struct {

	// (Optional) The target of the expansion.
	//
	// If set, it should end with '.*' and will be parsed by 'parseAttributeName'
	// in the server side.
	UnparsedTarget *string `protobuf:"bytes,1,opt,name=unparsed_target,json=unparsedTarget,proto3,oneof" json:"unparsed_target,omitempty"`
	// contains filtered or unexported fields
}

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

func (*Expression_UnresolvedStar) Descriptor deprecated

func (*Expression_UnresolvedStar) Descriptor() ([]byte, []int)

Deprecated: Use Expression_UnresolvedStar.ProtoReflect.Descriptor instead.

func (*Expression_UnresolvedStar) GetUnparsedTarget

func (x *Expression_UnresolvedStar) GetUnparsedTarget() string

func (*Expression_UnresolvedStar) ProtoMessage

func (*Expression_UnresolvedStar) ProtoMessage()

func (*Expression_UnresolvedStar) ProtoReflect

func (*Expression_UnresolvedStar) Reset

func (x *Expression_UnresolvedStar) Reset()

func (*Expression_UnresolvedStar) String

func (x *Expression_UnresolvedStar) String() string

type Expression_UnresolvedStar_

type Expression_UnresolvedStar_ struct {
	UnresolvedStar *Expression_UnresolvedStar `protobuf:"bytes,5,opt,name=unresolved_star,json=unresolvedStar,proto3,oneof"`
}

type Expression_UpdateFields

type Expression_UpdateFields struct {

	// (Required) The struct expression.
	StructExpression *Expression `protobuf:"bytes,1,opt,name=struct_expression,json=structExpression,proto3" json:"struct_expression,omitempty"`
	// (Required) The field name.
	FieldName string `protobuf:"bytes,2,opt,name=field_name,json=fieldName,proto3" json:"field_name,omitempty"`
	// (Optional) The expression to add or replace.
	//
	// When not set, it means this field will be dropped.
	ValueExpression *Expression `protobuf:"bytes,3,opt,name=value_expression,json=valueExpression,proto3" json:"value_expression,omitempty"`
	// contains filtered or unexported fields
}

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

func (*Expression_UpdateFields) Descriptor deprecated

func (*Expression_UpdateFields) Descriptor() ([]byte, []int)

Deprecated: Use Expression_UpdateFields.ProtoReflect.Descriptor instead.

func (*Expression_UpdateFields) GetFieldName

func (x *Expression_UpdateFields) GetFieldName() string

func (*Expression_UpdateFields) GetStructExpression

func (x *Expression_UpdateFields) GetStructExpression() *Expression

func (*Expression_UpdateFields) GetValueExpression

func (x *Expression_UpdateFields) GetValueExpression() *Expression

func (*Expression_UpdateFields) ProtoMessage

func (*Expression_UpdateFields) ProtoMessage()

func (*Expression_UpdateFields) ProtoReflect

func (x *Expression_UpdateFields) ProtoReflect() protoreflect.Message

func (*Expression_UpdateFields) Reset

func (x *Expression_UpdateFields) Reset()

func (*Expression_UpdateFields) String

func (x *Expression_UpdateFields) String() string

type Expression_UpdateFields_

type Expression_UpdateFields_ struct {
	UpdateFields *Expression_UpdateFields `protobuf:"bytes,13,opt,name=update_fields,json=updateFields,proto3,oneof"`
}

type Expression_Window

type Expression_Window struct {

	// (Required) The window function.
	WindowFunction *Expression `protobuf:"bytes,1,opt,name=window_function,json=windowFunction,proto3" json:"window_function,omitempty"`
	// (Optional) The way that input rows are partitioned.
	PartitionSpec []*Expression `protobuf:"bytes,2,rep,name=partition_spec,json=partitionSpec,proto3" json:"partition_spec,omitempty"`
	// (Optional) Ordering of rows in a partition.
	OrderSpec []*Expression_SortOrder `protobuf:"bytes,3,rep,name=order_spec,json=orderSpec,proto3" json:"order_spec,omitempty"`
	// (Optional) Window frame in a partition.
	//
	// If not set, it will be treated as 'UnspecifiedFrame'.
	FrameSpec *Expression_Window_WindowFrame `protobuf:"bytes,4,opt,name=frame_spec,json=frameSpec,proto3" json:"frame_spec,omitempty"`
	// contains filtered or unexported fields
}

Expression for the OVER clause or WINDOW clause.

func (*Expression_Window) Descriptor deprecated

func (*Expression_Window) Descriptor() ([]byte, []int)

Deprecated: Use Expression_Window.ProtoReflect.Descriptor instead.

func (*Expression_Window) GetFrameSpec

func (*Expression_Window) GetOrderSpec

func (x *Expression_Window) GetOrderSpec() []*Expression_SortOrder

func (*Expression_Window) GetPartitionSpec

func (x *Expression_Window) GetPartitionSpec() []*Expression

func (*Expression_Window) GetWindowFunction

func (x *Expression_Window) GetWindowFunction() *Expression

func (*Expression_Window) ProtoMessage

func (*Expression_Window) ProtoMessage()

func (*Expression_Window) ProtoReflect

func (x *Expression_Window) ProtoReflect() protoreflect.Message

func (*Expression_Window) Reset

func (x *Expression_Window) Reset()

func (*Expression_Window) String

func (x *Expression_Window) String() string

type Expression_Window_

type Expression_Window_ struct {
	Window *Expression_Window `protobuf:"bytes,11,opt,name=window,proto3,oneof"`
}

type Expression_Window_WindowFrame

type Expression_Window_WindowFrame struct {

	// (Required) The type of the frame.
	FrameType Expression_Window_WindowFrame_FrameType `` /* 148-byte string literal not displayed */
	// (Required) The lower bound of the frame.
	Lower *Expression_Window_WindowFrame_FrameBoundary `protobuf:"bytes,2,opt,name=lower,proto3" json:"lower,omitempty"`
	// (Required) The upper bound of the frame.
	Upper *Expression_Window_WindowFrame_FrameBoundary `protobuf:"bytes,3,opt,name=upper,proto3" json:"upper,omitempty"`
	// contains filtered or unexported fields
}

The window frame

func (*Expression_Window_WindowFrame) Descriptor deprecated

func (*Expression_Window_WindowFrame) Descriptor() ([]byte, []int)

Deprecated: Use Expression_Window_WindowFrame.ProtoReflect.Descriptor instead.

func (*Expression_Window_WindowFrame) GetFrameType

func (*Expression_Window_WindowFrame) GetLower

func (*Expression_Window_WindowFrame) GetUpper

func (*Expression_Window_WindowFrame) ProtoMessage

func (*Expression_Window_WindowFrame) ProtoMessage()

func (*Expression_Window_WindowFrame) ProtoReflect

func (*Expression_Window_WindowFrame) Reset

func (x *Expression_Window_WindowFrame) Reset()

func (*Expression_Window_WindowFrame) String

type Expression_Window_WindowFrame_FrameBoundary

type Expression_Window_WindowFrame_FrameBoundary struct {

	// Types that are assignable to Boundary:
	//
	//	*Expression_Window_WindowFrame_FrameBoundary_CurrentRow
	//	*Expression_Window_WindowFrame_FrameBoundary_Unbounded
	//	*Expression_Window_WindowFrame_FrameBoundary_Value
	Boundary isExpression_Window_WindowFrame_FrameBoundary_Boundary `protobuf_oneof:"boundary"`
	// contains filtered or unexported fields
}

func (*Expression_Window_WindowFrame_FrameBoundary) Descriptor deprecated

Deprecated: Use Expression_Window_WindowFrame_FrameBoundary.ProtoReflect.Descriptor instead.

func (*Expression_Window_WindowFrame_FrameBoundary) GetBoundary

func (m *Expression_Window_WindowFrame_FrameBoundary) GetBoundary() isExpression_Window_WindowFrame_FrameBoundary_Boundary

func (*Expression_Window_WindowFrame_FrameBoundary) GetCurrentRow

func (*Expression_Window_WindowFrame_FrameBoundary) GetUnbounded

func (*Expression_Window_WindowFrame_FrameBoundary) GetValue

func (*Expression_Window_WindowFrame_FrameBoundary) ProtoMessage

func (*Expression_Window_WindowFrame_FrameBoundary) ProtoReflect

func (*Expression_Window_WindowFrame_FrameBoundary) Reset

func (*Expression_Window_WindowFrame_FrameBoundary) String

type Expression_Window_WindowFrame_FrameBoundary_CurrentRow

type Expression_Window_WindowFrame_FrameBoundary_CurrentRow struct {
	// CURRENT ROW boundary
	CurrentRow bool `protobuf:"varint,1,opt,name=current_row,json=currentRow,proto3,oneof"`
}

type Expression_Window_WindowFrame_FrameBoundary_Unbounded

type Expression_Window_WindowFrame_FrameBoundary_Unbounded struct {
	// UNBOUNDED boundary.
	// For lower bound, it will be converted to 'UnboundedPreceding'.
	// for upper bound, it will be converted to 'UnboundedFollowing'.
	Unbounded bool `protobuf:"varint,2,opt,name=unbounded,proto3,oneof"`
}

type Expression_Window_WindowFrame_FrameBoundary_Value

type Expression_Window_WindowFrame_FrameBoundary_Value struct {
	// This is an expression for future proofing. We are expecting literals on the server side.
	Value *Expression `protobuf:"bytes,3,opt,name=value,proto3,oneof"`
}

type Expression_Window_WindowFrame_FrameType

type Expression_Window_WindowFrame_FrameType int32
const (
	Expression_Window_WindowFrame_FRAME_TYPE_UNDEFINED Expression_Window_WindowFrame_FrameType = 0
	// RowFrame treats rows in a partition individually.
	Expression_Window_WindowFrame_FRAME_TYPE_ROW Expression_Window_WindowFrame_FrameType = 1
	// RangeFrame treats rows in a partition as groups of peers.
	// All rows having the same 'ORDER BY' ordering are considered as peers.
	Expression_Window_WindowFrame_FRAME_TYPE_RANGE Expression_Window_WindowFrame_FrameType = 2
)

func (Expression_Window_WindowFrame_FrameType) Descriptor

func (Expression_Window_WindowFrame_FrameType) Enum

func (Expression_Window_WindowFrame_FrameType) EnumDescriptor deprecated

func (Expression_Window_WindowFrame_FrameType) EnumDescriptor() ([]byte, []int)

Deprecated: Use Expression_Window_WindowFrame_FrameType.Descriptor instead.

func (Expression_Window_WindowFrame_FrameType) Number

func (Expression_Window_WindowFrame_FrameType) String

func (Expression_Window_WindowFrame_FrameType) Type

type Filter

type Filter struct {

	// (Required) Input relation for a Filter.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) A Filter must have a condition expression.
	Condition *Expression `protobuf:"bytes,2,opt,name=condition,proto3" json:"condition,omitempty"`
	// contains filtered or unexported fields
}

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

func (*Filter) Descriptor deprecated

func (*Filter) Descriptor() ([]byte, []int)

Deprecated: Use Filter.ProtoReflect.Descriptor instead.

func (*Filter) GetCondition

func (x *Filter) GetCondition() *Expression

func (*Filter) GetInput

func (x *Filter) GetInput() *Relation

func (*Filter) ProtoMessage

func (*Filter) ProtoMessage()

func (*Filter) ProtoReflect

func (x *Filter) ProtoReflect() protoreflect.Message

func (*Filter) Reset

func (x *Filter) Reset()

func (*Filter) String

func (x *Filter) String() string

type FunctionExists

type FunctionExists struct {

	// (Required)
	FunctionName string `protobuf:"bytes,1,opt,name=function_name,json=functionName,proto3" json:"function_name,omitempty"`
	// (Optional)
	DbName *string `protobuf:"bytes,2,opt,name=db_name,json=dbName,proto3,oneof" json:"db_name,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.functionExists`

func (*FunctionExists) Descriptor deprecated

func (*FunctionExists) Descriptor() ([]byte, []int)

Deprecated: Use FunctionExists.ProtoReflect.Descriptor instead.

func (*FunctionExists) GetDbName

func (x *FunctionExists) GetDbName() string

func (*FunctionExists) GetFunctionName

func (x *FunctionExists) GetFunctionName() string

func (*FunctionExists) ProtoMessage

func (*FunctionExists) ProtoMessage()

func (*FunctionExists) ProtoReflect

func (x *FunctionExists) ProtoReflect() protoreflect.Message

func (*FunctionExists) Reset

func (x *FunctionExists) Reset()

func (*FunctionExists) String

func (x *FunctionExists) String() string

type GetDatabase

type GetDatabase struct {

	// (Required)
	DbName string `protobuf:"bytes,1,opt,name=db_name,json=dbName,proto3" json:"db_name,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.getDatabase`

func (*GetDatabase) Descriptor deprecated

func (*GetDatabase) Descriptor() ([]byte, []int)

Deprecated: Use GetDatabase.ProtoReflect.Descriptor instead.

func (*GetDatabase) GetDbName

func (x *GetDatabase) GetDbName() string

func (*GetDatabase) ProtoMessage

func (*GetDatabase) ProtoMessage()

func (*GetDatabase) ProtoReflect

func (x *GetDatabase) ProtoReflect() protoreflect.Message

func (*GetDatabase) Reset

func (x *GetDatabase) Reset()

func (*GetDatabase) String

func (x *GetDatabase) String() string

type GetFunction

type GetFunction struct {

	// (Required)
	FunctionName string `protobuf:"bytes,1,opt,name=function_name,json=functionName,proto3" json:"function_name,omitempty"`
	// (Optional)
	DbName *string `protobuf:"bytes,2,opt,name=db_name,json=dbName,proto3,oneof" json:"db_name,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.getFunction`

func (*GetFunction) Descriptor deprecated

func (*GetFunction) Descriptor() ([]byte, []int)

Deprecated: Use GetFunction.ProtoReflect.Descriptor instead.

func (*GetFunction) GetDbName

func (x *GetFunction) GetDbName() string

func (*GetFunction) GetFunctionName

func (x *GetFunction) GetFunctionName() string

func (*GetFunction) ProtoMessage

func (*GetFunction) ProtoMessage()

func (*GetFunction) ProtoReflect

func (x *GetFunction) ProtoReflect() protoreflect.Message

func (*GetFunction) Reset

func (x *GetFunction) Reset()

func (*GetFunction) String

func (x *GetFunction) String() string

type GetResourcesCommand

type GetResourcesCommand struct {
	// contains filtered or unexported fields
}

Command to get the output of 'SparkContext.resources'

func (*GetResourcesCommand) Descriptor deprecated

func (*GetResourcesCommand) Descriptor() ([]byte, []int)

Deprecated: Use GetResourcesCommand.ProtoReflect.Descriptor instead.

func (*GetResourcesCommand) ProtoMessage

func (*GetResourcesCommand) ProtoMessage()

func (*GetResourcesCommand) ProtoReflect

func (x *GetResourcesCommand) ProtoReflect() protoreflect.Message

func (*GetResourcesCommand) Reset

func (x *GetResourcesCommand) Reset()

func (*GetResourcesCommand) String

func (x *GetResourcesCommand) String() string

type GetResourcesCommandResult

type GetResourcesCommandResult struct {
	Resources map[string]*ResourceInformation `` /* 159-byte string literal not displayed */
	// contains filtered or unexported fields
}

Response for command 'GetResourcesCommand'.

func (*GetResourcesCommandResult) Descriptor deprecated

func (*GetResourcesCommandResult) Descriptor() ([]byte, []int)

Deprecated: Use GetResourcesCommandResult.ProtoReflect.Descriptor instead.

func (*GetResourcesCommandResult) GetResources

func (x *GetResourcesCommandResult) GetResources() map[string]*ResourceInformation

func (*GetResourcesCommandResult) ProtoMessage

func (*GetResourcesCommandResult) ProtoMessage()

func (*GetResourcesCommandResult) ProtoReflect

func (*GetResourcesCommandResult) Reset

func (x *GetResourcesCommandResult) Reset()

func (*GetResourcesCommandResult) String

func (x *GetResourcesCommandResult) String() string

type GetTable

type GetTable struct {

	// (Required)
	TableName string `protobuf:"bytes,1,opt,name=table_name,json=tableName,proto3" json:"table_name,omitempty"`
	// (Optional)
	DbName *string `protobuf:"bytes,2,opt,name=db_name,json=dbName,proto3,oneof" json:"db_name,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.getTable`

func (*GetTable) Descriptor deprecated

func (*GetTable) Descriptor() ([]byte, []int)

Deprecated: Use GetTable.ProtoReflect.Descriptor instead.

func (*GetTable) GetDbName

func (x *GetTable) GetDbName() string

func (*GetTable) GetTableName

func (x *GetTable) GetTableName() string

func (*GetTable) ProtoMessage

func (*GetTable) ProtoMessage()

func (*GetTable) ProtoReflect

func (x *GetTable) ProtoReflect() protoreflect.Message

func (*GetTable) Reset

func (x *GetTable) Reset()

func (*GetTable) String

func (x *GetTable) String() string

type GroupMap

type GroupMap struct {

	// (Required) Input relation for Group Map API: apply, applyInPandas.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) Expressions for grouping keys.
	GroupingExpressions []*Expression `protobuf:"bytes,2,rep,name=grouping_expressions,json=groupingExpressions,proto3" json:"grouping_expressions,omitempty"`
	// (Required) Input user-defined function.
	Func *CommonInlineUserDefinedFunction `protobuf:"bytes,3,opt,name=func,proto3" json:"func,omitempty"`
	// (Optional) Expressions for sorting. Only used by Scala Sorted Group Map API.
	SortingExpressions []*Expression `protobuf:"bytes,4,rep,name=sorting_expressions,json=sortingExpressions,proto3" json:"sorting_expressions,omitempty"`
	// contains filtered or unexported fields
}

func (*GroupMap) Descriptor deprecated

func (*GroupMap) Descriptor() ([]byte, []int)

Deprecated: Use GroupMap.ProtoReflect.Descriptor instead.

func (*GroupMap) GetFunc

func (*GroupMap) GetGroupingExpressions

func (x *GroupMap) GetGroupingExpressions() []*Expression

func (*GroupMap) GetInput

func (x *GroupMap) GetInput() *Relation

func (*GroupMap) GetSortingExpressions

func (x *GroupMap) GetSortingExpressions() []*Expression

func (*GroupMap) ProtoMessage

func (*GroupMap) ProtoMessage()

func (*GroupMap) ProtoReflect

func (x *GroupMap) ProtoReflect() protoreflect.Message

func (*GroupMap) Reset

func (x *GroupMap) Reset()

func (*GroupMap) String

func (x *GroupMap) String() string

type Hint

type Hint struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) Hint name.
	//
	// Supported Join hints include BROADCAST, MERGE, SHUFFLE_HASH, SHUFFLE_REPLICATE_NL.
	//
	// Supported partitioning hints include COALESCE, REPARTITION, REPARTITION_BY_RANGE.
	Name string `protobuf:"bytes,2,opt,name=name,proto3" json:"name,omitempty"`
	// (Optional) Hint parameters.
	Parameters []*Expression `protobuf:"bytes,3,rep,name=parameters,proto3" json:"parameters,omitempty"`
	// contains filtered or unexported fields
}

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

func (*Hint) Descriptor deprecated

func (*Hint) Descriptor() ([]byte, []int)

Deprecated: Use Hint.ProtoReflect.Descriptor instead.

func (*Hint) GetInput

func (x *Hint) GetInput() *Relation

func (*Hint) GetName

func (x *Hint) GetName() string

func (*Hint) GetParameters

func (x *Hint) GetParameters() []*Expression

func (*Hint) ProtoMessage

func (*Hint) ProtoMessage()

func (*Hint) ProtoReflect

func (x *Hint) ProtoReflect() protoreflect.Message

func (*Hint) Reset

func (x *Hint) Reset()

func (*Hint) String

func (x *Hint) String() string

type HtmlString

type HtmlString struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) Number of rows to show.
	NumRows int32 `protobuf:"varint,2,opt,name=num_rows,json=numRows,proto3" json:"num_rows,omitempty"`
	// (Required) If set to more than 0, truncates strings to
	// `truncate` characters and all cells will be aligned right.
	Truncate int32 `protobuf:"varint,3,opt,name=truncate,proto3" json:"truncate,omitempty"`
	// contains filtered or unexported fields
}

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

func (*HtmlString) Descriptor deprecated

func (*HtmlString) Descriptor() ([]byte, []int)

Deprecated: Use HtmlString.ProtoReflect.Descriptor instead.

func (*HtmlString) GetInput

func (x *HtmlString) GetInput() *Relation

func (*HtmlString) GetNumRows

func (x *HtmlString) GetNumRows() int32

func (*HtmlString) GetTruncate

func (x *HtmlString) GetTruncate() int32

func (*HtmlString) ProtoMessage

func (*HtmlString) ProtoMessage()

func (*HtmlString) ProtoReflect

func (x *HtmlString) ProtoReflect() protoreflect.Message

func (*HtmlString) Reset

func (x *HtmlString) Reset()

func (*HtmlString) String

func (x *HtmlString) String() string

type InterruptRequest

type InterruptRequest struct {

	// (Required)
	//
	// The session_id specifies a spark session for a user id (which is specified
	// by user_context.user_id). The session_id is set by the client to be able to
	// collate streaming responses from different queries within the dedicated session.
	SessionId string `protobuf:"bytes,1,opt,name=session_id,json=sessionId,proto3" json:"session_id,omitempty"`
	// (Required) User context
	UserContext *UserContext `protobuf:"bytes,2,opt,name=user_context,json=userContext,proto3" json:"user_context,omitempty"`
	// Provides optional information about the client sending the request. This field
	// can be used for language or version specific information and is only intended for
	// logging purposes and will not be interpreted by the server.
	ClientType *string `protobuf:"bytes,3,opt,name=client_type,json=clientType,proto3,oneof" json:"client_type,omitempty"`
	// (Required) The type of interrupt to execute.
	InterruptType InterruptRequest_InterruptType `` /* 151-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*InterruptRequest) Descriptor deprecated

func (*InterruptRequest) Descriptor() ([]byte, []int)

Deprecated: Use InterruptRequest.ProtoReflect.Descriptor instead.

func (*InterruptRequest) GetClientType

func (x *InterruptRequest) GetClientType() string

func (*InterruptRequest) GetInterruptType

func (x *InterruptRequest) GetInterruptType() InterruptRequest_InterruptType

func (*InterruptRequest) GetSessionId

func (x *InterruptRequest) GetSessionId() string

func (*InterruptRequest) GetUserContext

func (x *InterruptRequest) GetUserContext() *UserContext

func (*InterruptRequest) ProtoMessage

func (*InterruptRequest) ProtoMessage()

func (*InterruptRequest) ProtoReflect

func (x *InterruptRequest) ProtoReflect() protoreflect.Message

func (*InterruptRequest) Reset

func (x *InterruptRequest) Reset()

func (*InterruptRequest) String

func (x *InterruptRequest) String() string

type InterruptRequest_InterruptType

type InterruptRequest_InterruptType int32
const (
	InterruptRequest_INTERRUPT_TYPE_UNSPECIFIED InterruptRequest_InterruptType = 0
	// Interrupt all running executions within session with provided session_id.
	InterruptRequest_INTERRUPT_TYPE_ALL InterruptRequest_InterruptType = 1
)

func (InterruptRequest_InterruptType) Descriptor

func (InterruptRequest_InterruptType) Enum

func (InterruptRequest_InterruptType) EnumDescriptor deprecated

func (InterruptRequest_InterruptType) EnumDescriptor() ([]byte, []int)

Deprecated: Use InterruptRequest_InterruptType.Descriptor instead.

func (InterruptRequest_InterruptType) Number

func (InterruptRequest_InterruptType) String

func (InterruptRequest_InterruptType) Type

type InterruptResponse

type InterruptResponse struct {
	SessionId string `protobuf:"bytes,1,opt,name=session_id,json=sessionId,proto3" json:"session_id,omitempty"`
	// contains filtered or unexported fields
}

func (*InterruptResponse) Descriptor deprecated

func (*InterruptResponse) Descriptor() ([]byte, []int)

Deprecated: Use InterruptResponse.ProtoReflect.Descriptor instead.

func (*InterruptResponse) GetSessionId

func (x *InterruptResponse) GetSessionId() string

func (*InterruptResponse) ProtoMessage

func (*InterruptResponse) ProtoMessage()

func (*InterruptResponse) ProtoReflect

func (x *InterruptResponse) ProtoReflect() protoreflect.Message

func (*InterruptResponse) Reset

func (x *InterruptResponse) Reset()

func (*InterruptResponse) String

func (x *InterruptResponse) String() string

type IsCached

type IsCached struct {

	// (Required)
	TableName string `protobuf:"bytes,1,opt,name=table_name,json=tableName,proto3" json:"table_name,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.isCached`

func (*IsCached) Descriptor deprecated

func (*IsCached) Descriptor() ([]byte, []int)

Deprecated: Use IsCached.ProtoReflect.Descriptor instead.

func (*IsCached) GetTableName

func (x *IsCached) GetTableName() string

func (*IsCached) ProtoMessage

func (*IsCached) ProtoMessage()

func (*IsCached) ProtoReflect

func (x *IsCached) ProtoReflect() protoreflect.Message

func (*IsCached) Reset

func (x *IsCached) Reset()

func (*IsCached) String

func (x *IsCached) String() string

type JavaUDF

type JavaUDF struct {

	// (Required) Fully qualified name of Java class
	ClassName string `protobuf:"bytes,1,opt,name=class_name,json=className,proto3" json:"class_name,omitempty"`
	// (Optional) Output type of the Java UDF
	OutputType *DataType `protobuf:"bytes,2,opt,name=output_type,json=outputType,proto3,oneof" json:"output_type,omitempty"`
	// (Required) Indicate if the Java user-defined function is an aggregate function
	Aggregate bool `protobuf:"varint,3,opt,name=aggregate,proto3" json:"aggregate,omitempty"`
	// contains filtered or unexported fields
}

func (*JavaUDF) Descriptor deprecated

func (*JavaUDF) Descriptor() ([]byte, []int)

Deprecated: Use JavaUDF.ProtoReflect.Descriptor instead.

func (*JavaUDF) GetAggregate

func (x *JavaUDF) GetAggregate() bool

func (*JavaUDF) GetClassName

func (x *JavaUDF) GetClassName() string

func (*JavaUDF) GetOutputType

func (x *JavaUDF) GetOutputType() *DataType

func (*JavaUDF) ProtoMessage

func (*JavaUDF) ProtoMessage()

func (*JavaUDF) ProtoReflect

func (x *JavaUDF) ProtoReflect() protoreflect.Message

func (*JavaUDF) Reset

func (x *JavaUDF) Reset()

func (*JavaUDF) String

func (x *JavaUDF) String() string

type Join

type Join struct {

	// (Required) Left input relation for a Join.
	Left *Relation `protobuf:"bytes,1,opt,name=left,proto3" json:"left,omitempty"`
	// (Required) Right input relation for a Join.
	Right *Relation `protobuf:"bytes,2,opt,name=right,proto3" json:"right,omitempty"`
	// (Optional) The join condition. Could be unset when `using_columns` is utilized.
	//
	// This field does not co-exist with using_columns.
	JoinCondition *Expression `protobuf:"bytes,3,opt,name=join_condition,json=joinCondition,proto3" json:"join_condition,omitempty"`
	// (Required) The join type.
	JoinType Join_JoinType `protobuf:"varint,4,opt,name=join_type,json=joinType,proto3,enum=spark.connect.Join_JoinType" json:"join_type,omitempty"`
	// Optional. using_columns provides a list of columns that should present on both sides of
	// the join inputs that this Join will join on. For example A JOIN B USING col_name is
	// equivalent to A JOIN B on A.col_name = B.col_name.
	//
	// This field does not co-exist with join_condition.
	UsingColumns []string `protobuf:"bytes,5,rep,name=using_columns,json=usingColumns,proto3" json:"using_columns,omitempty"`
	// contains filtered or unexported fields
}

Relation of type [Join].

`left` and `right` must be present.

func (*Join) Descriptor deprecated

func (*Join) Descriptor() ([]byte, []int)

Deprecated: Use Join.ProtoReflect.Descriptor instead.

func (*Join) GetJoinCondition

func (x *Join) GetJoinCondition() *Expression

func (*Join) GetJoinType

func (x *Join) GetJoinType() Join_JoinType

func (*Join) GetLeft

func (x *Join) GetLeft() *Relation

func (*Join) GetRight

func (x *Join) GetRight() *Relation

func (*Join) GetUsingColumns

func (x *Join) GetUsingColumns() []string

func (*Join) ProtoMessage

func (*Join) ProtoMessage()

func (*Join) ProtoReflect

func (x *Join) ProtoReflect() protoreflect.Message

func (*Join) Reset

func (x *Join) Reset()

func (*Join) String

func (x *Join) String() string

type Join_JoinType

type Join_JoinType int32
const (
	Join_JOIN_TYPE_UNSPECIFIED Join_JoinType = 0
	Join_JOIN_TYPE_INNER       Join_JoinType = 1
	Join_JOIN_TYPE_FULL_OUTER  Join_JoinType = 2
	Join_JOIN_TYPE_LEFT_OUTER  Join_JoinType = 3
	Join_JOIN_TYPE_RIGHT_OUTER Join_JoinType = 4
	Join_JOIN_TYPE_LEFT_ANTI   Join_JoinType = 5
	Join_JOIN_TYPE_LEFT_SEMI   Join_JoinType = 6
	Join_JOIN_TYPE_CROSS       Join_JoinType = 7
)

func (Join_JoinType) Descriptor

func (Join_JoinType) Enum

func (x Join_JoinType) Enum() *Join_JoinType

func (Join_JoinType) EnumDescriptor deprecated

func (Join_JoinType) EnumDescriptor() ([]byte, []int)

Deprecated: Use Join_JoinType.Descriptor instead.

func (Join_JoinType) Number

func (Join_JoinType) String

func (x Join_JoinType) String() string

func (Join_JoinType) Type

type KeyValue

type KeyValue struct {

	// (Required) The key.
	Key string `protobuf:"bytes,1,opt,name=key,proto3" json:"key,omitempty"`
	// (Optional) The value.
	Value *string `protobuf:"bytes,2,opt,name=value,proto3,oneof" json:"value,omitempty"`
	// contains filtered or unexported fields
}

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

func (*KeyValue) Descriptor deprecated

func (*KeyValue) Descriptor() ([]byte, []int)

Deprecated: Use KeyValue.ProtoReflect.Descriptor instead.

func (*KeyValue) GetKey

func (x *KeyValue) GetKey() string

func (*KeyValue) GetValue

func (x *KeyValue) GetValue() string

func (*KeyValue) ProtoMessage

func (*KeyValue) ProtoMessage()

func (*KeyValue) ProtoReflect

func (x *KeyValue) ProtoReflect() protoreflect.Message

func (*KeyValue) Reset

func (x *KeyValue) Reset()

func (*KeyValue) String

func (x *KeyValue) String() string

type Limit

type Limit struct {

	// (Required) Input relation for a Limit.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) the limit.
	Limit int32 `protobuf:"varint,2,opt,name=limit,proto3" json:"limit,omitempty"`
	// contains filtered or unexported fields
}

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

func (*Limit) Descriptor deprecated

func (*Limit) Descriptor() ([]byte, []int)

Deprecated: Use Limit.ProtoReflect.Descriptor instead.

func (*Limit) GetInput

func (x *Limit) GetInput() *Relation

func (*Limit) GetLimit

func (x *Limit) GetLimit() int32

func (*Limit) ProtoMessage

func (*Limit) ProtoMessage()

func (*Limit) ProtoReflect

func (x *Limit) ProtoReflect() protoreflect.Message

func (*Limit) Reset

func (x *Limit) Reset()

func (*Limit) String

func (x *Limit) String() string

type ListCatalogs

type ListCatalogs struct {

	// (Optional) The pattern that the catalog name needs to match
	Pattern *string `protobuf:"bytes,1,opt,name=pattern,proto3,oneof" json:"pattern,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.listCatalogs`

func (*ListCatalogs) Descriptor deprecated

func (*ListCatalogs) Descriptor() ([]byte, []int)

Deprecated: Use ListCatalogs.ProtoReflect.Descriptor instead.

func (*ListCatalogs) GetPattern

func (x *ListCatalogs) GetPattern() string

func (*ListCatalogs) ProtoMessage

func (*ListCatalogs) ProtoMessage()

func (*ListCatalogs) ProtoReflect

func (x *ListCatalogs) ProtoReflect() protoreflect.Message

func (*ListCatalogs) Reset

func (x *ListCatalogs) Reset()

func (*ListCatalogs) String

func (x *ListCatalogs) String() string

type ListColumns

type ListColumns struct {

	// (Required)
	TableName string `protobuf:"bytes,1,opt,name=table_name,json=tableName,proto3" json:"table_name,omitempty"`
	// (Optional)
	DbName *string `protobuf:"bytes,2,opt,name=db_name,json=dbName,proto3,oneof" json:"db_name,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.listColumns`

func (*ListColumns) Descriptor deprecated

func (*ListColumns) Descriptor() ([]byte, []int)

Deprecated: Use ListColumns.ProtoReflect.Descriptor instead.

func (*ListColumns) GetDbName

func (x *ListColumns) GetDbName() string

func (*ListColumns) GetTableName

func (x *ListColumns) GetTableName() string

func (*ListColumns) ProtoMessage

func (*ListColumns) ProtoMessage()

func (*ListColumns) ProtoReflect

func (x *ListColumns) ProtoReflect() protoreflect.Message

func (*ListColumns) Reset

func (x *ListColumns) Reset()

func (*ListColumns) String

func (x *ListColumns) String() string

type ListDatabases

type ListDatabases struct {
	// contains filtered or unexported fields
}

See `spark.catalog.listDatabases`

func (*ListDatabases) Descriptor deprecated

func (*ListDatabases) Descriptor() ([]byte, []int)

Deprecated: Use ListDatabases.ProtoReflect.Descriptor instead.

func (*ListDatabases) ProtoMessage

func (*ListDatabases) ProtoMessage()

func (*ListDatabases) ProtoReflect

func (x *ListDatabases) ProtoReflect() protoreflect.Message

func (*ListDatabases) Reset

func (x *ListDatabases) Reset()

func (*ListDatabases) String

func (x *ListDatabases) String() string

type ListFunctions

type ListFunctions struct {

	// (Optional)
	DbName *string `protobuf:"bytes,1,opt,name=db_name,json=dbName,proto3,oneof" json:"db_name,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.listFunctions`

func (*ListFunctions) Descriptor deprecated

func (*ListFunctions) Descriptor() ([]byte, []int)

Deprecated: Use ListFunctions.ProtoReflect.Descriptor instead.

func (*ListFunctions) GetDbName

func (x *ListFunctions) GetDbName() string

func (*ListFunctions) ProtoMessage

func (*ListFunctions) ProtoMessage()

func (*ListFunctions) ProtoReflect

func (x *ListFunctions) ProtoReflect() protoreflect.Message

func (*ListFunctions) Reset

func (x *ListFunctions) Reset()

func (*ListFunctions) String

func (x *ListFunctions) String() string

type ListTables

type ListTables struct {

	// (Optional)
	DbName *string `protobuf:"bytes,1,opt,name=db_name,json=dbName,proto3,oneof" json:"db_name,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.listTables`

func (*ListTables) Descriptor deprecated

func (*ListTables) Descriptor() ([]byte, []int)

Deprecated: Use ListTables.ProtoReflect.Descriptor instead.

func (*ListTables) GetDbName

func (x *ListTables) GetDbName() string

func (*ListTables) ProtoMessage

func (*ListTables) ProtoMessage()

func (*ListTables) ProtoReflect

func (x *ListTables) ProtoReflect() protoreflect.Message

func (*ListTables) Reset

func (x *ListTables) Reset()

func (*ListTables) String

func (x *ListTables) String() string

type LocalRelation

type LocalRelation struct {

	// (Optional) Local collection data serialized into Arrow IPC streaming format which contains
	// the schema of the data.
	Data []byte `protobuf:"bytes,1,opt,name=data,proto3,oneof" json:"data,omitempty"`
	// (Optional) The schema of local data.
	// It should be either a DDL-formatted type string or a JSON string.
	//
	// The server side will update the column names and data types according to this schema.
	// If the 'data' is not provided, then this schema will be required.
	Schema *string `protobuf:"bytes,2,opt,name=schema,proto3,oneof" json:"schema,omitempty"`
	// contains filtered or unexported fields
}

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

func (*LocalRelation) Descriptor deprecated

func (*LocalRelation) Descriptor() ([]byte, []int)

Deprecated: Use LocalRelation.ProtoReflect.Descriptor instead.

func (*LocalRelation) GetData

func (x *LocalRelation) GetData() []byte

func (*LocalRelation) GetSchema

func (x *LocalRelation) GetSchema() string

func (*LocalRelation) ProtoMessage

func (*LocalRelation) ProtoMessage()

func (*LocalRelation) ProtoReflect

func (x *LocalRelation) ProtoReflect() protoreflect.Message

func (*LocalRelation) Reset

func (x *LocalRelation) Reset()

func (*LocalRelation) String

func (x *LocalRelation) String() string

type MapPartitions

type MapPartitions struct {

	// (Required) Input relation for a mapPartitions-equivalent API: mapInPandas, mapInArrow.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) Input user-defined function.
	Func *CommonInlineUserDefinedFunction `protobuf:"bytes,2,opt,name=func,proto3" json:"func,omitempty"`
	// (Optional) Whether to use barrier mode execution or not.
	IsBarrier *bool `protobuf:"varint,3,opt,name=is_barrier,json=isBarrier,proto3,oneof" json:"is_barrier,omitempty"`
	// contains filtered or unexported fields
}

func (*MapPartitions) Descriptor deprecated

func (*MapPartitions) Descriptor() ([]byte, []int)

Deprecated: Use MapPartitions.ProtoReflect.Descriptor instead.

func (*MapPartitions) GetFunc

func (*MapPartitions) GetInput

func (x *MapPartitions) GetInput() *Relation

func (*MapPartitions) GetIsBarrier

func (x *MapPartitions) GetIsBarrier() bool

func (*MapPartitions) ProtoMessage

func (*MapPartitions) ProtoMessage()

func (*MapPartitions) ProtoReflect

func (x *MapPartitions) ProtoReflect() protoreflect.Message

func (*MapPartitions) Reset

func (x *MapPartitions) Reset()

func (*MapPartitions) String

func (x *MapPartitions) String() string

type NADrop

type NADrop struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Optional) Optional list of column names to consider.
	//
	// When it is empty, all the columns in the input relation will be considered.
	Cols []string `protobuf:"bytes,2,rep,name=cols,proto3" json:"cols,omitempty"`
	// (Optional) The minimum number of non-null and non-NaN values required to keep.
	//
	// When not set, it is equivalent to the number of considered columns, which means
	// a row will be kept only if all columns are non-null.
	//
	// 'how' options ('all', 'any') can be easily converted to this field:
	//   - 'all' -> set 'min_non_nulls' 1;
	//   - 'any' -> keep 'min_non_nulls' unset;
	MinNonNulls *int32 `protobuf:"varint,3,opt,name=min_non_nulls,json=minNonNulls,proto3,oneof" json:"min_non_nulls,omitempty"`
	// contains filtered or unexported fields
}

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

func (*NADrop) Descriptor deprecated

func (*NADrop) Descriptor() ([]byte, []int)

Deprecated: Use NADrop.ProtoReflect.Descriptor instead.

func (*NADrop) GetCols

func (x *NADrop) GetCols() []string

func (*NADrop) GetInput

func (x *NADrop) GetInput() *Relation

func (*NADrop) GetMinNonNulls

func (x *NADrop) GetMinNonNulls() int32

func (*NADrop) ProtoMessage

func (*NADrop) ProtoMessage()

func (*NADrop) ProtoReflect

func (x *NADrop) ProtoReflect() protoreflect.Message

func (*NADrop) Reset

func (x *NADrop) Reset()

func (*NADrop) String

func (x *NADrop) String() string

type NAFill

type NAFill struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Optional) Optional list of column names to consider.
	Cols []string `protobuf:"bytes,2,rep,name=cols,proto3" json:"cols,omitempty"`
	// (Required) Values to replace null values with.
	//
	// Should contain at least 1 item.
	// Only 4 data types are supported now: bool, long, double, string
	Values []*Expression_Literal `protobuf:"bytes,3,rep,name=values,proto3" json:"values,omitempty"`
	// contains filtered or unexported fields
}

Replaces null values. It will invoke 'Dataset.na.fill' (same as 'DataFrameNaFunctions.fill') to compute the results. Following 3 parameter combinations are supported:

1, 'values' only contains 1 item, 'cols' is empty:
  replaces null values in all type-compatible columns.
2, 'values' only contains 1 item, 'cols' is not empty:
  replaces null values in specified columns.
3, 'values' contains more than 1 items, then 'cols' is required to have the same length:
  replaces each specified column with corresponding value.

func (*NAFill) Descriptor deprecated

func (*NAFill) Descriptor() ([]byte, []int)

Deprecated: Use NAFill.ProtoReflect.Descriptor instead.

func (*NAFill) GetCols

func (x *NAFill) GetCols() []string

func (*NAFill) GetInput

func (x *NAFill) GetInput() *Relation

func (*NAFill) GetValues

func (x *NAFill) GetValues() []*Expression_Literal

func (*NAFill) ProtoMessage

func (*NAFill) ProtoMessage()

func (*NAFill) ProtoReflect

func (x *NAFill) ProtoReflect() protoreflect.Message

func (*NAFill) Reset

func (x *NAFill) Reset()

func (*NAFill) String

func (x *NAFill) String() string

type NAReplace

type NAReplace struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Optional) List of column names to consider.
	//
	// When it is empty, all the type-compatible columns in the input relation will be considered.
	Cols []string `protobuf:"bytes,2,rep,name=cols,proto3" json:"cols,omitempty"`
	// (Optional) The value replacement mapping.
	Replacements []*NAReplace_Replacement `protobuf:"bytes,3,rep,name=replacements,proto3" json:"replacements,omitempty"`
	// contains filtered or unexported fields
}

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

func (*NAReplace) Descriptor deprecated

func (*NAReplace) Descriptor() ([]byte, []int)

Deprecated: Use NAReplace.ProtoReflect.Descriptor instead.

func (*NAReplace) GetCols

func (x *NAReplace) GetCols() []string

func (*NAReplace) GetInput

func (x *NAReplace) GetInput() *Relation

func (*NAReplace) GetReplacements

func (x *NAReplace) GetReplacements() []*NAReplace_Replacement

func (*NAReplace) ProtoMessage

func (*NAReplace) ProtoMessage()

func (*NAReplace) ProtoReflect

func (x *NAReplace) ProtoReflect() protoreflect.Message

func (*NAReplace) Reset

func (x *NAReplace) Reset()

func (*NAReplace) String

func (x *NAReplace) String() string

type NAReplace_Replacement

type NAReplace_Replacement struct {

	// (Required) The old value.
	//
	// Only 4 data types are supported now: null, bool, double, string.
	OldValue *Expression_Literal `protobuf:"bytes,1,opt,name=old_value,json=oldValue,proto3" json:"old_value,omitempty"`
	// (Required) The new value.
	//
	// Should be of the same data type with the old value.
	NewValue *Expression_Literal `protobuf:"bytes,2,opt,name=new_value,json=newValue,proto3" json:"new_value,omitempty"`
	// contains filtered or unexported fields
}

func (*NAReplace_Replacement) Descriptor deprecated

func (*NAReplace_Replacement) Descriptor() ([]byte, []int)

Deprecated: Use NAReplace_Replacement.ProtoReflect.Descriptor instead.

func (*NAReplace_Replacement) GetNewValue

func (x *NAReplace_Replacement) GetNewValue() *Expression_Literal

func (*NAReplace_Replacement) GetOldValue

func (x *NAReplace_Replacement) GetOldValue() *Expression_Literal

func (*NAReplace_Replacement) ProtoMessage

func (*NAReplace_Replacement) ProtoMessage()

func (*NAReplace_Replacement) ProtoReflect

func (x *NAReplace_Replacement) ProtoReflect() protoreflect.Message

func (*NAReplace_Replacement) Reset

func (x *NAReplace_Replacement) Reset()

func (*NAReplace_Replacement) String

func (x *NAReplace_Replacement) String() string

type Offset

type Offset struct {

	// (Required) Input relation for an Offset.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) the limit.
	Offset int32 `protobuf:"varint,2,opt,name=offset,proto3" json:"offset,omitempty"`
	// contains filtered or unexported fields
}

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

func (*Offset) Descriptor deprecated

func (*Offset) Descriptor() ([]byte, []int)

Deprecated: Use Offset.ProtoReflect.Descriptor instead.

func (*Offset) GetInput

func (x *Offset) GetInput() *Relation

func (*Offset) GetOffset

func (x *Offset) GetOffset() int32

func (*Offset) ProtoMessage

func (*Offset) ProtoMessage()

func (*Offset) ProtoReflect

func (x *Offset) ProtoReflect() protoreflect.Message

func (*Offset) Reset

func (x *Offset) Reset()

func (*Offset) String

func (x *Offset) String() string

type Parse

type Parse struct {

	// (Required) Input relation to Parse. The input is expected to have single text column.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) The expected format of the text.
	Format Parse_ParseFormat `protobuf:"varint,2,opt,name=format,proto3,enum=spark.connect.Parse_ParseFormat" json:"format,omitempty"`
	// (Optional) DataType representing the schema. If not set, Spark will infer the schema.
	Schema *DataType `protobuf:"bytes,3,opt,name=schema,proto3,oneof" json:"schema,omitempty"`
	// Options for the csv/json parser. The map key is case insensitive.
	Options map[string]string `` /* 155-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*Parse) Descriptor deprecated

func (*Parse) Descriptor() ([]byte, []int)

Deprecated: Use Parse.ProtoReflect.Descriptor instead.

func (*Parse) GetFormat

func (x *Parse) GetFormat() Parse_ParseFormat

func (*Parse) GetInput

func (x *Parse) GetInput() *Relation

func (*Parse) GetOptions

func (x *Parse) GetOptions() map[string]string

func (*Parse) GetSchema

func (x *Parse) GetSchema() *DataType

func (*Parse) ProtoMessage

func (*Parse) ProtoMessage()

func (*Parse) ProtoReflect

func (x *Parse) ProtoReflect() protoreflect.Message

func (*Parse) Reset

func (x *Parse) Reset()

func (*Parse) String

func (x *Parse) String() string

type Parse_ParseFormat

type Parse_ParseFormat int32
const (
	Parse_PARSE_FORMAT_UNSPECIFIED Parse_ParseFormat = 0
	Parse_PARSE_FORMAT_CSV         Parse_ParseFormat = 1
	Parse_PARSE_FORMAT_JSON        Parse_ParseFormat = 2
)

func (Parse_ParseFormat) Descriptor

func (Parse_ParseFormat) Enum

func (Parse_ParseFormat) EnumDescriptor deprecated

func (Parse_ParseFormat) EnumDescriptor() ([]byte, []int)

Deprecated: Use Parse_ParseFormat.Descriptor instead.

func (Parse_ParseFormat) Number

func (Parse_ParseFormat) String

func (x Parse_ParseFormat) String() string

func (Parse_ParseFormat) Type

type Plan

type Plan struct {

	// Types that are assignable to OpType:
	//
	//	*Plan_Root
	//	*Plan_Command
	OpType isPlan_OpType `protobuf_oneof:"op_type"`
	// contains filtered or unexported fields
}

A [Plan] is the structure that carries the runtime information for the execution from the client to the server. A [Plan] can either be of the type [Relation] which is a reference to the underlying logical plan or it can be of the [Command] type that is used to execute commands on the server.

func (*Plan) Descriptor deprecated

func (*Plan) Descriptor() ([]byte, []int)

Deprecated: Use Plan.ProtoReflect.Descriptor instead.

func (*Plan) GetCommand

func (x *Plan) GetCommand() *Command

func (*Plan) GetOpType

func (m *Plan) GetOpType() isPlan_OpType

func (*Plan) GetRoot

func (x *Plan) GetRoot() *Relation

func (*Plan) ProtoMessage

func (*Plan) ProtoMessage()

func (*Plan) ProtoReflect

func (x *Plan) ProtoReflect() protoreflect.Message

func (*Plan) Reset

func (x *Plan) Reset()

func (*Plan) String

func (x *Plan) String() string

type Plan_Command

type Plan_Command struct {
	Command *Command `protobuf:"bytes,2,opt,name=command,proto3,oneof"`
}

type Plan_Root

type Plan_Root struct {
	Root *Relation `protobuf:"bytes,1,opt,name=root,proto3,oneof"`
}

type Project

type Project struct {

	// (Optional) Input relation is optional for Project.
	//
	// For example, `SELECT ABS(-1)` is valid plan without an input plan.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) A Project requires at least one expression.
	Expressions []*Expression `protobuf:"bytes,3,rep,name=expressions,proto3" json:"expressions,omitempty"`
	// contains filtered or unexported fields
}

Projection of a bag of expressions for a given input relation.

The input relation must be specified. The projected expression can be an arbitrary expression.

func (*Project) Descriptor deprecated

func (*Project) Descriptor() ([]byte, []int)

Deprecated: Use Project.ProtoReflect.Descriptor instead.

func (*Project) GetExpressions

func (x *Project) GetExpressions() []*Expression

func (*Project) GetInput

func (x *Project) GetInput() *Relation

func (*Project) ProtoMessage

func (*Project) ProtoMessage()

func (*Project) ProtoReflect

func (x *Project) ProtoReflect() protoreflect.Message

func (*Project) Reset

func (x *Project) Reset()

func (*Project) String

func (x *Project) String() string

type PythonUDF

type PythonUDF struct {

	// (Required) Output type of the Python UDF
	OutputType *DataType `protobuf:"bytes,1,opt,name=output_type,json=outputType,proto3" json:"output_type,omitempty"`
	// (Required) EvalType of the Python UDF
	EvalType int32 `protobuf:"varint,2,opt,name=eval_type,json=evalType,proto3" json:"eval_type,omitempty"`
	// (Required) The encoded commands of the Python UDF
	Command []byte `protobuf:"bytes,3,opt,name=command,proto3" json:"command,omitempty"`
	// (Required) Python version being used in the client.
	PythonVer string `protobuf:"bytes,4,opt,name=python_ver,json=pythonVer,proto3" json:"python_ver,omitempty"`
	// contains filtered or unexported fields
}

func (*PythonUDF) Descriptor deprecated

func (*PythonUDF) Descriptor() ([]byte, []int)

Deprecated: Use PythonUDF.ProtoReflect.Descriptor instead.

func (*PythonUDF) GetCommand

func (x *PythonUDF) GetCommand() []byte

func (*PythonUDF) GetEvalType

func (x *PythonUDF) GetEvalType() int32

func (*PythonUDF) GetOutputType

func (x *PythonUDF) GetOutputType() *DataType

func (*PythonUDF) GetPythonVer

func (x *PythonUDF) GetPythonVer() string

func (*PythonUDF) ProtoMessage

func (*PythonUDF) ProtoMessage()

func (*PythonUDF) ProtoReflect

func (x *PythonUDF) ProtoReflect() protoreflect.Message

func (*PythonUDF) Reset

func (x *PythonUDF) Reset()

func (*PythonUDF) String

func (x *PythonUDF) String() string

type Range

type Range struct {

	// (Optional) Default value = 0
	Start *int64 `protobuf:"varint,1,opt,name=start,proto3,oneof" json:"start,omitempty"`
	// (Required)
	End int64 `protobuf:"varint,2,opt,name=end,proto3" json:"end,omitempty"`
	// (Required)
	Step int64 `protobuf:"varint,3,opt,name=step,proto3" json:"step,omitempty"`
	// Optional. Default value is assigned by 1) SQL conf "spark.sql.leafNodeDefaultParallelism" if
	// it is set, or 2) spark default parallelism.
	NumPartitions *int32 `protobuf:"varint,4,opt,name=num_partitions,json=numPartitions,proto3,oneof" json:"num_partitions,omitempty"`
	// contains filtered or unexported fields
}

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

func (*Range) Descriptor deprecated

func (*Range) Descriptor() ([]byte, []int)

Deprecated: Use Range.ProtoReflect.Descriptor instead.

func (*Range) GetEnd

func (x *Range) GetEnd() int64

func (*Range) GetNumPartitions

func (x *Range) GetNumPartitions() int32

func (*Range) GetStart

func (x *Range) GetStart() int64

func (*Range) GetStep

func (x *Range) GetStep() int64

func (*Range) ProtoMessage

func (*Range) ProtoMessage()

func (*Range) ProtoReflect

func (x *Range) ProtoReflect() protoreflect.Message

func (*Range) Reset

func (x *Range) Reset()

func (*Range) String

func (x *Range) String() string

type Read

type Read struct {

	// Types that are assignable to ReadType:
	//
	//	*Read_NamedTable_
	//	*Read_DataSource_
	ReadType isRead_ReadType `protobuf_oneof:"read_type"`
	// (Optional) Indicates if this is a streaming read.
	IsStreaming bool `protobuf:"varint,3,opt,name=is_streaming,json=isStreaming,proto3" json:"is_streaming,omitempty"`
	// contains filtered or unexported fields
}

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

func (*Read) Descriptor deprecated

func (*Read) Descriptor() ([]byte, []int)

Deprecated: Use Read.ProtoReflect.Descriptor instead.

func (*Read) GetDataSource

func (x *Read) GetDataSource() *Read_DataSource

func (*Read) GetIsStreaming

func (x *Read) GetIsStreaming() bool

func (*Read) GetNamedTable

func (x *Read) GetNamedTable() *Read_NamedTable

func (*Read) GetReadType

func (m *Read) GetReadType() isRead_ReadType

func (*Read) ProtoMessage

func (*Read) ProtoMessage()

func (*Read) ProtoReflect

func (x *Read) ProtoReflect() protoreflect.Message

func (*Read) Reset

func (x *Read) Reset()

func (*Read) String

func (x *Read) String() string

type Read_DataSource

type Read_DataSource struct {

	// (Optional) Supported formats include: parquet, orc, text, json, parquet, csv, avro.
	//
	// If not set, the value from SQL conf 'spark.sql.sources.default' will be used.
	Format *string `protobuf:"bytes,1,opt,name=format,proto3,oneof" json:"format,omitempty"`
	// (Optional) If not set, Spark will infer the schema.
	//
	// This schema string should be either DDL-formatted or JSON-formatted.
	Schema *string `protobuf:"bytes,2,opt,name=schema,proto3,oneof" json:"schema,omitempty"`
	// Options for the data source. The context of this map varies based on the
	// data source format. This options could be empty for valid data source format.
	// The map key is case insensitive.
	Options map[string]string `` /* 155-byte string literal not displayed */
	// (Optional) A list of path for file-system backed data sources.
	Paths []string `protobuf:"bytes,4,rep,name=paths,proto3" json:"paths,omitempty"`
	// (Optional) Condition in the where clause for each partition.
	//
	// This is only supported by the JDBC data source.
	Predicates []string `protobuf:"bytes,5,rep,name=predicates,proto3" json:"predicates,omitempty"`
	// contains filtered or unexported fields
}

func (*Read_DataSource) Descriptor deprecated

func (*Read_DataSource) Descriptor() ([]byte, []int)

Deprecated: Use Read_DataSource.ProtoReflect.Descriptor instead.

func (*Read_DataSource) GetFormat

func (x *Read_DataSource) GetFormat() string

func (*Read_DataSource) GetOptions

func (x *Read_DataSource) GetOptions() map[string]string

func (*Read_DataSource) GetPaths

func (x *Read_DataSource) GetPaths() []string

func (*Read_DataSource) GetPredicates

func (x *Read_DataSource) GetPredicates() []string

func (*Read_DataSource) GetSchema

func (x *Read_DataSource) GetSchema() string

func (*Read_DataSource) ProtoMessage

func (*Read_DataSource) ProtoMessage()

func (*Read_DataSource) ProtoReflect

func (x *Read_DataSource) ProtoReflect() protoreflect.Message

func (*Read_DataSource) Reset

func (x *Read_DataSource) Reset()

func (*Read_DataSource) String

func (x *Read_DataSource) String() string

type Read_DataSource_

type Read_DataSource_ struct {
	DataSource *Read_DataSource `protobuf:"bytes,2,opt,name=data_source,json=dataSource,proto3,oneof"`
}

type Read_NamedTable

type Read_NamedTable struct {

	// (Required) Unparsed identifier for the table.
	UnparsedIdentifier string `protobuf:"bytes,1,opt,name=unparsed_identifier,json=unparsedIdentifier,proto3" json:"unparsed_identifier,omitempty"`
	// Options for the named table. The map key is case insensitive.
	Options map[string]string `` /* 155-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*Read_NamedTable) Descriptor deprecated

func (*Read_NamedTable) Descriptor() ([]byte, []int)

Deprecated: Use Read_NamedTable.ProtoReflect.Descriptor instead.

func (*Read_NamedTable) GetOptions

func (x *Read_NamedTable) GetOptions() map[string]string

func (*Read_NamedTable) GetUnparsedIdentifier

func (x *Read_NamedTable) GetUnparsedIdentifier() string

func (*Read_NamedTable) ProtoMessage

func (*Read_NamedTable) ProtoMessage()

func (*Read_NamedTable) ProtoReflect

func (x *Read_NamedTable) ProtoReflect() protoreflect.Message

func (*Read_NamedTable) Reset

func (x *Read_NamedTable) Reset()

func (*Read_NamedTable) String

func (x *Read_NamedTable) String() string

type Read_NamedTable_

type Read_NamedTable_ struct {
	NamedTable *Read_NamedTable `protobuf:"bytes,1,opt,name=named_table,json=namedTable,proto3,oneof"`
}

type RecoverPartitions

type RecoverPartitions struct {

	// (Required)
	TableName string `protobuf:"bytes,1,opt,name=table_name,json=tableName,proto3" json:"table_name,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.recoverPartitions`

func (*RecoverPartitions) Descriptor deprecated

func (*RecoverPartitions) Descriptor() ([]byte, []int)

Deprecated: Use RecoverPartitions.ProtoReflect.Descriptor instead.

func (*RecoverPartitions) GetTableName

func (x *RecoverPartitions) GetTableName() string

func (*RecoverPartitions) ProtoMessage

func (*RecoverPartitions) ProtoMessage()

func (*RecoverPartitions) ProtoReflect

func (x *RecoverPartitions) ProtoReflect() protoreflect.Message

func (*RecoverPartitions) Reset

func (x *RecoverPartitions) Reset()

func (*RecoverPartitions) String

func (x *RecoverPartitions) String() string

type RefreshByPath

type RefreshByPath struct {

	// (Required)
	Path string `protobuf:"bytes,1,opt,name=path,proto3" json:"path,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.refreshByPath`

func (*RefreshByPath) Descriptor deprecated

func (*RefreshByPath) Descriptor() ([]byte, []int)

Deprecated: Use RefreshByPath.ProtoReflect.Descriptor instead.

func (*RefreshByPath) GetPath

func (x *RefreshByPath) GetPath() string

func (*RefreshByPath) ProtoMessage

func (*RefreshByPath) ProtoMessage()

func (*RefreshByPath) ProtoReflect

func (x *RefreshByPath) ProtoReflect() protoreflect.Message

func (*RefreshByPath) Reset

func (x *RefreshByPath) Reset()

func (*RefreshByPath) String

func (x *RefreshByPath) String() string

type RefreshTable

type RefreshTable struct {

	// (Required)
	TableName string `protobuf:"bytes,1,opt,name=table_name,json=tableName,proto3" json:"table_name,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.refreshTable`

func (*RefreshTable) Descriptor deprecated

func (*RefreshTable) Descriptor() ([]byte, []int)

Deprecated: Use RefreshTable.ProtoReflect.Descriptor instead.

func (*RefreshTable) GetTableName

func (x *RefreshTable) GetTableName() string

func (*RefreshTable) ProtoMessage

func (*RefreshTable) ProtoMessage()

func (*RefreshTable) ProtoReflect

func (x *RefreshTable) ProtoReflect() protoreflect.Message

func (*RefreshTable) Reset

func (x *RefreshTable) Reset()

func (*RefreshTable) String

func (x *RefreshTable) String() string

type Relation

type Relation struct {
	Common *RelationCommon `protobuf:"bytes,1,opt,name=common,proto3" json:"common,omitempty"`
	// Types that are assignable to RelType:
	//
	//	*Relation_Read
	//	*Relation_Project
	//	*Relation_Filter
	//	*Relation_Join
	//	*Relation_SetOp
	//	*Relation_Sort
	//	*Relation_Limit
	//	*Relation_Aggregate
	//	*Relation_Sql
	//	*Relation_LocalRelation
	//	*Relation_Sample
	//	*Relation_Offset
	//	*Relation_Deduplicate
	//	*Relation_Range
	//	*Relation_SubqueryAlias
	//	*Relation_Repartition
	//	*Relation_ToDf
	//	*Relation_WithColumnsRenamed
	//	*Relation_ShowString
	//	*Relation_Drop
	//	*Relation_Tail
	//	*Relation_WithColumns
	//	*Relation_Hint
	//	*Relation_Unpivot
	//	*Relation_ToSchema
	//	*Relation_RepartitionByExpression
	//	*Relation_MapPartitions
	//	*Relation_CollectMetrics
	//	*Relation_Parse
	//	*Relation_GroupMap
	//	*Relation_CoGroupMap
	//	*Relation_WithWatermark
	//	*Relation_ApplyInPandasWithState
	//	*Relation_HtmlString
	//	*Relation_CachedLocalRelation
	//	*Relation_FillNa
	//	*Relation_DropNa
	//	*Relation_Replace
	//	*Relation_Summary
	//	*Relation_Crosstab
	//	*Relation_Describe
	//	*Relation_Cov
	//	*Relation_Corr
	//	*Relation_ApproxQuantile
	//	*Relation_FreqItems
	//	*Relation_SampleBy
	//	*Relation_Catalog
	//	*Relation_Extension
	//	*Relation_Unknown
	RelType isRelation_RelType `protobuf_oneof:"rel_type"`
	// contains filtered or unexported fields
}

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.

func (*Relation) Descriptor deprecated

func (*Relation) Descriptor() ([]byte, []int)

Deprecated: Use Relation.ProtoReflect.Descriptor instead.

func (*Relation) GetAggregate

func (x *Relation) GetAggregate() *Aggregate

func (*Relation) GetApplyInPandasWithState

func (x *Relation) GetApplyInPandasWithState() *ApplyInPandasWithState

func (*Relation) GetApproxQuantile

func (x *Relation) GetApproxQuantile() *StatApproxQuantile

func (*Relation) GetCachedLocalRelation

func (x *Relation) GetCachedLocalRelation() *CachedLocalRelation

func (*Relation) GetCatalog

func (x *Relation) GetCatalog() *Catalog

func (*Relation) GetCoGroupMap

func (x *Relation) GetCoGroupMap() *CoGroupMap

func (*Relation) GetCollectMetrics

func (x *Relation) GetCollectMetrics() *CollectMetrics

func (*Relation) GetCommon

func (x *Relation) GetCommon() *RelationCommon

func (*Relation) GetCorr

func (x *Relation) GetCorr() *StatCorr

func (*Relation) GetCov

func (x *Relation) GetCov() *StatCov

func (*Relation) GetCrosstab

func (x *Relation) GetCrosstab() *StatCrosstab

func (*Relation) GetDeduplicate

func (x *Relation) GetDeduplicate() *Deduplicate

func (*Relation) GetDescribe

func (x *Relation) GetDescribe() *StatDescribe

func (*Relation) GetDrop

func (x *Relation) GetDrop() *Drop

func (*Relation) GetDropNa

func (x *Relation) GetDropNa() *NADrop

func (*Relation) GetExtension

func (x *Relation) GetExtension() *anypb.Any

func (*Relation) GetFillNa

func (x *Relation) GetFillNa() *NAFill

func (*Relation) GetFilter

func (x *Relation) GetFilter() *Filter

func (*Relation) GetFreqItems

func (x *Relation) GetFreqItems() *StatFreqItems

func (*Relation) GetGroupMap

func (x *Relation) GetGroupMap() *GroupMap

func (*Relation) GetHint

func (x *Relation) GetHint() *Hint

func (*Relation) GetHtmlString

func (x *Relation) GetHtmlString() *HtmlString

func (*Relation) GetJoin

func (x *Relation) GetJoin() *Join

func (*Relation) GetLimit

func (x *Relation) GetLimit() *Limit

func (*Relation) GetLocalRelation

func (x *Relation) GetLocalRelation() *LocalRelation

func (*Relation) GetMapPartitions

func (x *Relation) GetMapPartitions() *MapPartitions

func (*Relation) GetOffset

func (x *Relation) GetOffset() *Offset

func (*Relation) GetParse

func (x *Relation) GetParse() *Parse

func (*Relation) GetProject

func (x *Relation) GetProject() *Project

func (*Relation) GetRange

func (x *Relation) GetRange() *Range

func (*Relation) GetRead

func (x *Relation) GetRead() *Read

func (*Relation) GetRelType

func (m *Relation) GetRelType() isRelation_RelType

func (*Relation) GetRepartition

func (x *Relation) GetRepartition() *Repartition

func (*Relation) GetRepartitionByExpression

func (x *Relation) GetRepartitionByExpression() *RepartitionByExpression

func (*Relation) GetReplace

func (x *Relation) GetReplace() *NAReplace

func (*Relation) GetSample

func (x *Relation) GetSample() *Sample

func (*Relation) GetSampleBy

func (x *Relation) GetSampleBy() *StatSampleBy

func (*Relation) GetSetOp

func (x *Relation) GetSetOp() *SetOperation

func (*Relation) GetShowString

func (x *Relation) GetShowString() *ShowString

func (*Relation) GetSort

func (x *Relation) GetSort() *Sort

func (*Relation) GetSql

func (x *Relation) GetSql() *SQL

func (*Relation) GetSubqueryAlias

func (x *Relation) GetSubqueryAlias() *SubqueryAlias

func (*Relation) GetSummary

func (x *Relation) GetSummary() *StatSummary

func (*Relation) GetTail

func (x *Relation) GetTail() *Tail

func (*Relation) GetToDf

func (x *Relation) GetToDf() *ToDF

func (*Relation) GetToSchema

func (x *Relation) GetToSchema() *ToSchema

func (*Relation) GetUnknown

func (x *Relation) GetUnknown() *Unknown

func (*Relation) GetUnpivot

func (x *Relation) GetUnpivot() *Unpivot

func (*Relation) GetWithColumns

func (x *Relation) GetWithColumns() *WithColumns

func (*Relation) GetWithColumnsRenamed

func (x *Relation) GetWithColumnsRenamed() *WithColumnsRenamed

func (*Relation) GetWithWatermark

func (x *Relation) GetWithWatermark() *WithWatermark

func (*Relation) ProtoMessage

func (*Relation) ProtoMessage()

func (*Relation) ProtoReflect

func (x *Relation) ProtoReflect() protoreflect.Message

func (*Relation) Reset

func (x *Relation) Reset()

func (*Relation) String

func (x *Relation) String() string

type RelationCommon

type RelationCommon struct {

	// (Required) Shared relation metadata.
	SourceInfo string `protobuf:"bytes,1,opt,name=source_info,json=sourceInfo,proto3" json:"source_info,omitempty"`
	// (Optional) A per-client globally unique id for a given connect plan.
	PlanId *int64 `protobuf:"varint,2,opt,name=plan_id,json=planId,proto3,oneof" json:"plan_id,omitempty"`
	// contains filtered or unexported fields
}

Common metadata of all relations.

func (*RelationCommon) Descriptor deprecated

func (*RelationCommon) Descriptor() ([]byte, []int)

Deprecated: Use RelationCommon.ProtoReflect.Descriptor instead.

func (*RelationCommon) GetPlanId

func (x *RelationCommon) GetPlanId() int64

func (*RelationCommon) GetSourceInfo

func (x *RelationCommon) GetSourceInfo() string

func (*RelationCommon) ProtoMessage

func (*RelationCommon) ProtoMessage()

func (*RelationCommon) ProtoReflect

func (x *RelationCommon) ProtoReflect() protoreflect.Message

func (*RelationCommon) Reset

func (x *RelationCommon) Reset()

func (*RelationCommon) String

func (x *RelationCommon) String() string

type Relation_Aggregate

type Relation_Aggregate struct {
	Aggregate *Aggregate `protobuf:"bytes,9,opt,name=aggregate,proto3,oneof"`
}

type Relation_ApplyInPandasWithState

type Relation_ApplyInPandasWithState struct {
	ApplyInPandasWithState *ApplyInPandasWithState `protobuf:"bytes,34,opt,name=apply_in_pandas_with_state,json=applyInPandasWithState,proto3,oneof"`
}

type Relation_ApproxQuantile

type Relation_ApproxQuantile struct {
	ApproxQuantile *StatApproxQuantile `protobuf:"bytes,105,opt,name=approx_quantile,json=approxQuantile,proto3,oneof"`
}

type Relation_CachedLocalRelation

type Relation_CachedLocalRelation struct {
	CachedLocalRelation *CachedLocalRelation `protobuf:"bytes,36,opt,name=cached_local_relation,json=cachedLocalRelation,proto3,oneof"`
}

type Relation_Catalog

type Relation_Catalog struct {
	// Catalog API (experimental / unstable)
	Catalog *Catalog `protobuf:"bytes,200,opt,name=catalog,proto3,oneof"`
}

type Relation_CoGroupMap

type Relation_CoGroupMap struct {
	CoGroupMap *CoGroupMap `protobuf:"bytes,32,opt,name=co_group_map,json=coGroupMap,proto3,oneof"`
}

type Relation_CollectMetrics

type Relation_CollectMetrics struct {
	CollectMetrics *CollectMetrics `protobuf:"bytes,29,opt,name=collect_metrics,json=collectMetrics,proto3,oneof"`
}

type Relation_Corr

type Relation_Corr struct {
	Corr *StatCorr `protobuf:"bytes,104,opt,name=corr,proto3,oneof"`
}

type Relation_Cov

type Relation_Cov struct {
	Cov *StatCov `protobuf:"bytes,103,opt,name=cov,proto3,oneof"`
}

type Relation_Crosstab

type Relation_Crosstab struct {
	Crosstab *StatCrosstab `protobuf:"bytes,101,opt,name=crosstab,proto3,oneof"`
}

type Relation_Deduplicate

type Relation_Deduplicate struct {
	Deduplicate *Deduplicate `protobuf:"bytes,14,opt,name=deduplicate,proto3,oneof"`
}

type Relation_Describe

type Relation_Describe struct {
	Describe *StatDescribe `protobuf:"bytes,102,opt,name=describe,proto3,oneof"`
}

type Relation_Drop

type Relation_Drop struct {
	Drop *Drop `protobuf:"bytes,21,opt,name=drop,proto3,oneof"`
}

type Relation_DropNa

type Relation_DropNa struct {
	DropNa *NADrop `protobuf:"bytes,91,opt,name=drop_na,json=dropNa,proto3,oneof"`
}

type Relation_Extension

type Relation_Extension struct {
	// 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.
	Extension *anypb.Any `protobuf:"bytes,998,opt,name=extension,proto3,oneof"`
}

type Relation_FillNa

type Relation_FillNa struct {
	// NA functions
	FillNa *NAFill `protobuf:"bytes,90,opt,name=fill_na,json=fillNa,proto3,oneof"`
}

type Relation_Filter

type Relation_Filter struct {
	Filter *Filter `protobuf:"bytes,4,opt,name=filter,proto3,oneof"`
}

type Relation_FreqItems

type Relation_FreqItems struct {
	FreqItems *StatFreqItems `protobuf:"bytes,106,opt,name=freq_items,json=freqItems,proto3,oneof"`
}

type Relation_GroupMap

type Relation_GroupMap struct {
	GroupMap *GroupMap `protobuf:"bytes,31,opt,name=group_map,json=groupMap,proto3,oneof"`
}

type Relation_Hint

type Relation_Hint struct {
	Hint *Hint `protobuf:"bytes,24,opt,name=hint,proto3,oneof"`
}

type Relation_HtmlString

type Relation_HtmlString struct {
	HtmlString *HtmlString `protobuf:"bytes,35,opt,name=html_string,json=htmlString,proto3,oneof"`
}

type Relation_Join

type Relation_Join struct {
	Join *Join `protobuf:"bytes,5,opt,name=join,proto3,oneof"`
}

type Relation_Limit

type Relation_Limit struct {
	Limit *Limit `protobuf:"bytes,8,opt,name=limit,proto3,oneof"`
}

type Relation_LocalRelation

type Relation_LocalRelation struct {
	LocalRelation *LocalRelation `protobuf:"bytes,11,opt,name=local_relation,json=localRelation,proto3,oneof"`
}

type Relation_MapPartitions

type Relation_MapPartitions struct {
	MapPartitions *MapPartitions `protobuf:"bytes,28,opt,name=map_partitions,json=mapPartitions,proto3,oneof"`
}

type Relation_Offset

type Relation_Offset struct {
	Offset *Offset `protobuf:"bytes,13,opt,name=offset,proto3,oneof"`
}

type Relation_Parse

type Relation_Parse struct {
	Parse *Parse `protobuf:"bytes,30,opt,name=parse,proto3,oneof"`
}

type Relation_Project

type Relation_Project struct {
	Project *Project `protobuf:"bytes,3,opt,name=project,proto3,oneof"`
}

type Relation_Range

type Relation_Range struct {
	Range *Range `protobuf:"bytes,15,opt,name=range,proto3,oneof"`
}

type Relation_Read

type Relation_Read struct {
	Read *Read `protobuf:"bytes,2,opt,name=read,proto3,oneof"`
}

type Relation_Repartition

type Relation_Repartition struct {
	Repartition *Repartition `protobuf:"bytes,17,opt,name=repartition,proto3,oneof"`
}

type Relation_RepartitionByExpression

type Relation_RepartitionByExpression struct {
	RepartitionByExpression *RepartitionByExpression `protobuf:"bytes,27,opt,name=repartition_by_expression,json=repartitionByExpression,proto3,oneof"`
}

type Relation_Replace

type Relation_Replace struct {
	Replace *NAReplace `protobuf:"bytes,92,opt,name=replace,proto3,oneof"`
}

type Relation_Sample

type Relation_Sample struct {
	Sample *Sample `protobuf:"bytes,12,opt,name=sample,proto3,oneof"`
}

type Relation_SampleBy

type Relation_SampleBy struct {
	SampleBy *StatSampleBy `protobuf:"bytes,107,opt,name=sample_by,json=sampleBy,proto3,oneof"`
}

type Relation_SetOp

type Relation_SetOp struct {
	SetOp *SetOperation `protobuf:"bytes,6,opt,name=set_op,json=setOp,proto3,oneof"`
}

type Relation_ShowString

type Relation_ShowString struct {
	ShowString *ShowString `protobuf:"bytes,20,opt,name=show_string,json=showString,proto3,oneof"`
}

type Relation_Sort

type Relation_Sort struct {
	Sort *Sort `protobuf:"bytes,7,opt,name=sort,proto3,oneof"`
}

type Relation_Sql

type Relation_Sql struct {
	Sql *SQL `protobuf:"bytes,10,opt,name=sql,proto3,oneof"`
}

type Relation_SubqueryAlias

type Relation_SubqueryAlias struct {
	SubqueryAlias *SubqueryAlias `protobuf:"bytes,16,opt,name=subquery_alias,json=subqueryAlias,proto3,oneof"`
}

type Relation_Summary

type Relation_Summary struct {
	// stat functions
	Summary *StatSummary `protobuf:"bytes,100,opt,name=summary,proto3,oneof"`
}

type Relation_Tail

type Relation_Tail struct {
	Tail *Tail `protobuf:"bytes,22,opt,name=tail,proto3,oneof"`
}

type Relation_ToDf

type Relation_ToDf struct {
	ToDf *ToDF `protobuf:"bytes,18,opt,name=to_df,json=toDf,proto3,oneof"`
}

type Relation_ToSchema

type Relation_ToSchema struct {
	ToSchema *ToSchema `protobuf:"bytes,26,opt,name=to_schema,json=toSchema,proto3,oneof"`
}

type Relation_Unknown

type Relation_Unknown struct {
	Unknown *Unknown `protobuf:"bytes,999,opt,name=unknown,proto3,oneof"`
}

type Relation_Unpivot

type Relation_Unpivot struct {
	Unpivot *Unpivot `protobuf:"bytes,25,opt,name=unpivot,proto3,oneof"`
}

type Relation_WithColumns

type Relation_WithColumns struct {
	WithColumns *WithColumns `protobuf:"bytes,23,opt,name=with_columns,json=withColumns,proto3,oneof"`
}

type Relation_WithColumnsRenamed

type Relation_WithColumnsRenamed struct {
	WithColumnsRenamed *WithColumnsRenamed `protobuf:"bytes,19,opt,name=with_columns_renamed,json=withColumnsRenamed,proto3,oneof"`
}

type Relation_WithWatermark

type Relation_WithWatermark struct {
	WithWatermark *WithWatermark `protobuf:"bytes,33,opt,name=with_watermark,json=withWatermark,proto3,oneof"`
}

type Repartition

type Repartition struct {

	// (Required) The input relation of Repartition.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) Must be positive.
	NumPartitions int32 `protobuf:"varint,2,opt,name=num_partitions,json=numPartitions,proto3" json:"num_partitions,omitempty"`
	// (Optional) Default value is false.
	Shuffle *bool `protobuf:"varint,3,opt,name=shuffle,proto3,oneof" json:"shuffle,omitempty"`
	// contains filtered or unexported fields
}

Relation repartition.

func (*Repartition) Descriptor deprecated

func (*Repartition) Descriptor() ([]byte, []int)

Deprecated: Use Repartition.ProtoReflect.Descriptor instead.

func (*Repartition) GetInput

func (x *Repartition) GetInput() *Relation

func (*Repartition) GetNumPartitions

func (x *Repartition) GetNumPartitions() int32

func (*Repartition) GetShuffle

func (x *Repartition) GetShuffle() bool

func (*Repartition) ProtoMessage

func (*Repartition) ProtoMessage()

func (*Repartition) ProtoReflect

func (x *Repartition) ProtoReflect() protoreflect.Message

func (*Repartition) Reset

func (x *Repartition) Reset()

func (*Repartition) String

func (x *Repartition) String() string

type RepartitionByExpression

type RepartitionByExpression struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) The partitioning expressions.
	PartitionExprs []*Expression `protobuf:"bytes,2,rep,name=partition_exprs,json=partitionExprs,proto3" json:"partition_exprs,omitempty"`
	// (Optional) number of partitions, must be positive.
	NumPartitions *int32 `protobuf:"varint,3,opt,name=num_partitions,json=numPartitions,proto3,oneof" json:"num_partitions,omitempty"`
	// contains filtered or unexported fields
}

func (*RepartitionByExpression) Descriptor deprecated

func (*RepartitionByExpression) Descriptor() ([]byte, []int)

Deprecated: Use RepartitionByExpression.ProtoReflect.Descriptor instead.

func (*RepartitionByExpression) GetInput

func (x *RepartitionByExpression) GetInput() *Relation

func (*RepartitionByExpression) GetNumPartitions

func (x *RepartitionByExpression) GetNumPartitions() int32

func (*RepartitionByExpression) GetPartitionExprs

func (x *RepartitionByExpression) GetPartitionExprs() []*Expression

func (*RepartitionByExpression) ProtoMessage

func (*RepartitionByExpression) ProtoMessage()

func (*RepartitionByExpression) ProtoReflect

func (x *RepartitionByExpression) ProtoReflect() protoreflect.Message

func (*RepartitionByExpression) Reset

func (x *RepartitionByExpression) Reset()

func (*RepartitionByExpression) String

func (x *RepartitionByExpression) String() string

type ResourceInformation

type ResourceInformation struct {

	// (Required) The name of the resource
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// (Required) An array of strings describing the addresses of the resource.
	Addresses []string `protobuf:"bytes,2,rep,name=addresses,proto3" json:"addresses,omitempty"`
	// contains filtered or unexported fields
}

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

func (*ResourceInformation) Descriptor deprecated

func (*ResourceInformation) Descriptor() ([]byte, []int)

Deprecated: Use ResourceInformation.ProtoReflect.Descriptor instead.

func (*ResourceInformation) GetAddresses

func (x *ResourceInformation) GetAddresses() []string

func (*ResourceInformation) GetName

func (x *ResourceInformation) GetName() string

func (*ResourceInformation) ProtoMessage

func (*ResourceInformation) ProtoMessage()

func (*ResourceInformation) ProtoReflect

func (x *ResourceInformation) ProtoReflect() protoreflect.Message

func (*ResourceInformation) Reset

func (x *ResourceInformation) Reset()

func (*ResourceInformation) String

func (x *ResourceInformation) String() string

type SQL

type SQL struct {

	// (Required) The SQL query.
	Query string `protobuf:"bytes,1,opt,name=query,proto3" json:"query,omitempty"`
	// (Optional) A map of parameter names to literal expressions.
	Args map[string]*Expression_Literal `` /* 149-byte string literal not displayed */
	// contains filtered or unexported fields
}

Relation that uses a SQL query to generate the output.

func (*SQL) Descriptor deprecated

func (*SQL) Descriptor() ([]byte, []int)

Deprecated: Use SQL.ProtoReflect.Descriptor instead.

func (*SQL) GetArgs

func (x *SQL) GetArgs() map[string]*Expression_Literal

func (*SQL) GetQuery

func (x *SQL) GetQuery() string

func (*SQL) ProtoMessage

func (*SQL) ProtoMessage()

func (*SQL) ProtoReflect

func (x *SQL) ProtoReflect() protoreflect.Message

func (*SQL) Reset

func (x *SQL) Reset()

func (*SQL) String

func (x *SQL) String() string

type Sample

type Sample struct {

	// (Required) Input relation for a Sample.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) lower bound.
	LowerBound float64 `protobuf:"fixed64,2,opt,name=lower_bound,json=lowerBound,proto3" json:"lower_bound,omitempty"`
	// (Required) upper bound.
	UpperBound float64 `protobuf:"fixed64,3,opt,name=upper_bound,json=upperBound,proto3" json:"upper_bound,omitempty"`
	// (Optional) Whether to sample with replacement.
	WithReplacement *bool `protobuf:"varint,4,opt,name=with_replacement,json=withReplacement,proto3,oneof" json:"with_replacement,omitempty"`
	// (Optional) The random seed.
	Seed *int64 `protobuf:"varint,5,opt,name=seed,proto3,oneof" json:"seed,omitempty"`
	// (Required) Explicitly sort the underlying plan to make the ordering deterministic or cache it.
	// This flag is true when invoking `dataframe.randomSplit` to randomly splits DataFrame with the
	// provided weights. Otherwise, it is false.
	DeterministicOrder bool `protobuf:"varint,6,opt,name=deterministic_order,json=deterministicOrder,proto3" json:"deterministic_order,omitempty"`
	// contains filtered or unexported fields
}

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

func (*Sample) Descriptor deprecated

func (*Sample) Descriptor() ([]byte, []int)

Deprecated: Use Sample.ProtoReflect.Descriptor instead.

func (*Sample) GetDeterministicOrder

func (x *Sample) GetDeterministicOrder() bool

func (*Sample) GetInput

func (x *Sample) GetInput() *Relation

func (*Sample) GetLowerBound

func (x *Sample) GetLowerBound() float64

func (*Sample) GetSeed

func (x *Sample) GetSeed() int64

func (*Sample) GetUpperBound

func (x *Sample) GetUpperBound() float64

func (*Sample) GetWithReplacement

func (x *Sample) GetWithReplacement() bool

func (*Sample) ProtoMessage

func (*Sample) ProtoMessage()

func (*Sample) ProtoReflect

func (x *Sample) ProtoReflect() protoreflect.Message

func (*Sample) Reset

func (x *Sample) Reset()

func (*Sample) String

func (x *Sample) String() string

type ScalarScalaUDF

type ScalarScalaUDF struct {

	// (Required) Serialized JVM object containing UDF definition, input encoders and output encoder
	Payload []byte `protobuf:"bytes,1,opt,name=payload,proto3" json:"payload,omitempty"`
	// (Optional) Input type(s) of the UDF
	InputTypes []*DataType `protobuf:"bytes,2,rep,name=inputTypes,proto3" json:"inputTypes,omitempty"`
	// (Required) Output type of the UDF
	OutputType *DataType `protobuf:"bytes,3,opt,name=outputType,proto3" json:"outputType,omitempty"`
	// (Required) True if the UDF can return null value
	Nullable bool `protobuf:"varint,4,opt,name=nullable,proto3" json:"nullable,omitempty"`
	// contains filtered or unexported fields
}

func (*ScalarScalaUDF) Descriptor deprecated

func (*ScalarScalaUDF) Descriptor() ([]byte, []int)

Deprecated: Use ScalarScalaUDF.ProtoReflect.Descriptor instead.

func (*ScalarScalaUDF) GetInputTypes

func (x *ScalarScalaUDF) GetInputTypes() []*DataType

func (*ScalarScalaUDF) GetNullable

func (x *ScalarScalaUDF) GetNullable() bool

func (*ScalarScalaUDF) GetOutputType

func (x *ScalarScalaUDF) GetOutputType() *DataType

func (*ScalarScalaUDF) GetPayload

func (x *ScalarScalaUDF) GetPayload() []byte

func (*ScalarScalaUDF) ProtoMessage

func (*ScalarScalaUDF) ProtoMessage()

func (*ScalarScalaUDF) ProtoReflect

func (x *ScalarScalaUDF) ProtoReflect() protoreflect.Message

func (*ScalarScalaUDF) Reset

func (x *ScalarScalaUDF) Reset()

func (*ScalarScalaUDF) String

func (x *ScalarScalaUDF) String() string

type SetCurrentCatalog

type SetCurrentCatalog struct {

	// (Required)
	CatalogName string `protobuf:"bytes,1,opt,name=catalog_name,json=catalogName,proto3" json:"catalog_name,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.setCurrentCatalog`

func (*SetCurrentCatalog) Descriptor deprecated

func (*SetCurrentCatalog) Descriptor() ([]byte, []int)

Deprecated: Use SetCurrentCatalog.ProtoReflect.Descriptor instead.

func (*SetCurrentCatalog) GetCatalogName

func (x *SetCurrentCatalog) GetCatalogName() string

func (*SetCurrentCatalog) ProtoMessage

func (*SetCurrentCatalog) ProtoMessage()

func (*SetCurrentCatalog) ProtoReflect

func (x *SetCurrentCatalog) ProtoReflect() protoreflect.Message

func (*SetCurrentCatalog) Reset

func (x *SetCurrentCatalog) Reset()

func (*SetCurrentCatalog) String

func (x *SetCurrentCatalog) String() string

type SetCurrentDatabase

type SetCurrentDatabase struct {

	// (Required)
	DbName string `protobuf:"bytes,1,opt,name=db_name,json=dbName,proto3" json:"db_name,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.setCurrentDatabase`

func (*SetCurrentDatabase) Descriptor deprecated

func (*SetCurrentDatabase) Descriptor() ([]byte, []int)

Deprecated: Use SetCurrentDatabase.ProtoReflect.Descriptor instead.

func (*SetCurrentDatabase) GetDbName

func (x *SetCurrentDatabase) GetDbName() string

func (*SetCurrentDatabase) ProtoMessage

func (*SetCurrentDatabase) ProtoMessage()

func (*SetCurrentDatabase) ProtoReflect

func (x *SetCurrentDatabase) ProtoReflect() protoreflect.Message

func (*SetCurrentDatabase) Reset

func (x *SetCurrentDatabase) Reset()

func (*SetCurrentDatabase) String

func (x *SetCurrentDatabase) String() string

type SetOperation

type SetOperation struct {

	// (Required) Left input relation for a Set operation.
	LeftInput *Relation `protobuf:"bytes,1,opt,name=left_input,json=leftInput,proto3" json:"left_input,omitempty"`
	// (Required) Right input relation for a Set operation.
	RightInput *Relation `protobuf:"bytes,2,opt,name=right_input,json=rightInput,proto3" json:"right_input,omitempty"`
	// (Required) The Set operation type.
	SetOpType SetOperation_SetOpType `` /* 133-byte string literal not displayed */
	// (Optional) If to remove duplicate rows.
	//
	// True to preserve all results.
	// False to remove duplicate rows.
	IsAll *bool `protobuf:"varint,4,opt,name=is_all,json=isAll,proto3,oneof" json:"is_all,omitempty"`
	// (Optional) If to perform the Set operation based on name resolution.
	//
	// Only UNION supports this option.
	ByName *bool `protobuf:"varint,5,opt,name=by_name,json=byName,proto3,oneof" json:"by_name,omitempty"`
	// (Optional) If to perform the Set operation and allow missing columns.
	//
	// Only UNION supports this option.
	AllowMissingColumns *bool `` /* 127-byte string literal not displayed */
	// contains filtered or unexported fields
}

Relation of type [SetOperation]

func (*SetOperation) Descriptor deprecated

func (*SetOperation) Descriptor() ([]byte, []int)

Deprecated: Use SetOperation.ProtoReflect.Descriptor instead.

func (*SetOperation) GetAllowMissingColumns

func (x *SetOperation) GetAllowMissingColumns() bool

func (*SetOperation) GetByName

func (x *SetOperation) GetByName() bool

func (*SetOperation) GetIsAll

func (x *SetOperation) GetIsAll() bool

func (*SetOperation) GetLeftInput

func (x *SetOperation) GetLeftInput() *Relation

func (*SetOperation) GetRightInput

func (x *SetOperation) GetRightInput() *Relation

func (*SetOperation) GetSetOpType

func (x *SetOperation) GetSetOpType() SetOperation_SetOpType

func (*SetOperation) ProtoMessage

func (*SetOperation) ProtoMessage()

func (*SetOperation) ProtoReflect

func (x *SetOperation) ProtoReflect() protoreflect.Message

func (*SetOperation) Reset

func (x *SetOperation) Reset()

func (*SetOperation) String

func (x *SetOperation) String() string

type SetOperation_SetOpType

type SetOperation_SetOpType int32
const (
	SetOperation_SET_OP_TYPE_UNSPECIFIED SetOperation_SetOpType = 0
	SetOperation_SET_OP_TYPE_INTERSECT   SetOperation_SetOpType = 1
	SetOperation_SET_OP_TYPE_UNION       SetOperation_SetOpType = 2
	SetOperation_SET_OP_TYPE_EXCEPT      SetOperation_SetOpType = 3
)

func (SetOperation_SetOpType) Descriptor

func (SetOperation_SetOpType) Enum

func (SetOperation_SetOpType) EnumDescriptor deprecated

func (SetOperation_SetOpType) EnumDescriptor() ([]byte, []int)

Deprecated: Use SetOperation_SetOpType.Descriptor instead.

func (SetOperation_SetOpType) Number

func (SetOperation_SetOpType) String

func (x SetOperation_SetOpType) String() string

func (SetOperation_SetOpType) Type

type ShowString

type ShowString struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) Number of rows to show.
	NumRows int32 `protobuf:"varint,2,opt,name=num_rows,json=numRows,proto3" json:"num_rows,omitempty"`
	// (Required) If set to more than 0, truncates strings to
	// `truncate` characters and all cells will be aligned right.
	Truncate int32 `protobuf:"varint,3,opt,name=truncate,proto3" json:"truncate,omitempty"`
	// (Required) If set to true, prints output rows vertically (one line per column value).
	Vertical bool `protobuf:"varint,4,opt,name=vertical,proto3" json:"vertical,omitempty"`
	// contains filtered or unexported fields
}

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

func (*ShowString) Descriptor deprecated

func (*ShowString) Descriptor() ([]byte, []int)

Deprecated: Use ShowString.ProtoReflect.Descriptor instead.

func (*ShowString) GetInput

func (x *ShowString) GetInput() *Relation

func (*ShowString) GetNumRows

func (x *ShowString) GetNumRows() int32

func (*ShowString) GetTruncate

func (x *ShowString) GetTruncate() int32

func (*ShowString) GetVertical

func (x *ShowString) GetVertical() bool

func (*ShowString) ProtoMessage

func (*ShowString) ProtoMessage()

func (*ShowString) ProtoReflect

func (x *ShowString) ProtoReflect() protoreflect.Message

func (*ShowString) Reset

func (x *ShowString) Reset()

func (*ShowString) String

func (x *ShowString) String() string

type Sort

type Sort struct {

	// (Required) Input relation for a Sort.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) The ordering expressions
	Order []*Expression_SortOrder `protobuf:"bytes,2,rep,name=order,proto3" json:"order,omitempty"`
	// (Optional) if this is a global sort.
	IsGlobal *bool `protobuf:"varint,3,opt,name=is_global,json=isGlobal,proto3,oneof" json:"is_global,omitempty"`
	// contains filtered or unexported fields
}

Relation of type [Sort].

func (*Sort) Descriptor deprecated

func (*Sort) Descriptor() ([]byte, []int)

Deprecated: Use Sort.ProtoReflect.Descriptor instead.

func (*Sort) GetInput

func (x *Sort) GetInput() *Relation

func (*Sort) GetIsGlobal

func (x *Sort) GetIsGlobal() bool

func (*Sort) GetOrder

func (x *Sort) GetOrder() []*Expression_SortOrder

func (*Sort) ProtoMessage

func (*Sort) ProtoMessage()

func (*Sort) ProtoReflect

func (x *Sort) ProtoReflect() protoreflect.Message

func (*Sort) Reset

func (x *Sort) Reset()

func (*Sort) String

func (x *Sort) String() string

type SparkConnectServiceClient

type SparkConnectServiceClient interface {
	// Executes a request that contains the query and returns a stream of [[Response]].
	//
	// It is guaranteed that there is at least one ARROW batch returned even if the result set is empty.
	ExecutePlan(ctx context.Context, in *ExecutePlanRequest, opts ...grpc.CallOption) (SparkConnectService_ExecutePlanClient, error)
	// Analyzes a query and returns a [[AnalyzeResponse]] containing metadata about the query.
	AnalyzePlan(ctx context.Context, in *AnalyzePlanRequest, opts ...grpc.CallOption) (*AnalyzePlanResponse, error)
	// Update or fetch the configurations and returns a [[ConfigResponse]] containing the result.
	Config(ctx context.Context, in *ConfigRequest, opts ...grpc.CallOption) (*ConfigResponse, error)
	// Add artifacts to the session and returns a [[AddArtifactsResponse]] containing metadata about
	// the added artifacts.
	AddArtifacts(ctx context.Context, opts ...grpc.CallOption) (SparkConnectService_AddArtifactsClient, error)
	// Check statuses of artifacts in the session and returns them in a [[ArtifactStatusesResponse]]
	ArtifactStatus(ctx context.Context, in *ArtifactStatusesRequest, opts ...grpc.CallOption) (*ArtifactStatusesResponse, error)
	// Interrupts running executions
	Interrupt(ctx context.Context, in *InterruptRequest, opts ...grpc.CallOption) (*InterruptResponse, error)
}

SparkConnectServiceClient is the client API for SparkConnectService service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://pkg.go.dev/google.golang.org/grpc/?tab=doc#ClientConn.NewStream.

type SparkConnectServiceServer

type SparkConnectServiceServer interface {
	// Executes a request that contains the query and returns a stream of [[Response]].
	//
	// It is guaranteed that there is at least one ARROW batch returned even if the result set is empty.
	ExecutePlan(*ExecutePlanRequest, SparkConnectService_ExecutePlanServer) error
	// Analyzes a query and returns a [[AnalyzeResponse]] containing metadata about the query.
	AnalyzePlan(context.Context, *AnalyzePlanRequest) (*AnalyzePlanResponse, error)
	// Update or fetch the configurations and returns a [[ConfigResponse]] containing the result.
	Config(context.Context, *ConfigRequest) (*ConfigResponse, error)
	// Add artifacts to the session and returns a [[AddArtifactsResponse]] containing metadata about
	// the added artifacts.
	AddArtifacts(SparkConnectService_AddArtifactsServer) error
	// Check statuses of artifacts in the session and returns them in a [[ArtifactStatusesResponse]]
	ArtifactStatus(context.Context, *ArtifactStatusesRequest) (*ArtifactStatusesResponse, error)
	// Interrupts running executions
	Interrupt(context.Context, *InterruptRequest) (*InterruptResponse, error)
	// contains filtered or unexported methods
}

SparkConnectServiceServer is the server API for SparkConnectService service. All implementations must embed UnimplementedSparkConnectServiceServer for forward compatibility

type SparkConnectService_AddArtifactsClient

type SparkConnectService_AddArtifactsClient interface {
	Send(*AddArtifactsRequest) error
	CloseAndRecv() (*AddArtifactsResponse, error)
	grpc.ClientStream
}

type SparkConnectService_AddArtifactsServer

type SparkConnectService_AddArtifactsServer interface {
	SendAndClose(*AddArtifactsResponse) error
	Recv() (*AddArtifactsRequest, error)
	grpc.ServerStream
}

type SparkConnectService_ExecutePlanClient

type SparkConnectService_ExecutePlanClient interface {
	Recv() (*ExecutePlanResponse, error)
	grpc.ClientStream
}

type SparkConnectService_ExecutePlanServer

type SparkConnectService_ExecutePlanServer interface {
	Send(*ExecutePlanResponse) error
	grpc.ServerStream
}

type SqlCommand

type SqlCommand struct {

	// (Required) SQL Query.
	Sql string `protobuf:"bytes,1,opt,name=sql,proto3" json:"sql,omitempty"`
	// (Optional) A map of parameter names to literal expressions.
	Args map[string]*Expression_Literal `` /* 149-byte string literal not displayed */
	// contains filtered or unexported fields
}

A SQL Command is used to trigger the eager evaluation of SQL commands in Spark.

When the SQL provide as part of the message is a command it will be immediately evaluated and the result will be collected and returned as part of a LocalRelation. If the result is not a command, the operation will simply return a SQL Relation. This allows the client to be almost oblivious to the server-side behavior.

func (*SqlCommand) Descriptor deprecated

func (*SqlCommand) Descriptor() ([]byte, []int)

Deprecated: Use SqlCommand.ProtoReflect.Descriptor instead.

func (*SqlCommand) GetArgs

func (x *SqlCommand) GetArgs() map[string]*Expression_Literal

func (*SqlCommand) GetSql

func (x *SqlCommand) GetSql() string

func (*SqlCommand) ProtoMessage

func (*SqlCommand) ProtoMessage()

func (*SqlCommand) ProtoReflect

func (x *SqlCommand) ProtoReflect() protoreflect.Message

func (*SqlCommand) Reset

func (x *SqlCommand) Reset()

func (*SqlCommand) String

func (x *SqlCommand) String() string

type StatApproxQuantile

type StatApproxQuantile struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) The names of the numerical columns.
	Cols []string `protobuf:"bytes,2,rep,name=cols,proto3" json:"cols,omitempty"`
	// (Required) A list of quantile probabilities.
	//
	// Each number must belong to [0, 1].
	// For example 0 is the minimum, 0.5 is the median, 1 is the maximum.
	Probabilities []float64 `protobuf:"fixed64,3,rep,packed,name=probabilities,proto3" json:"probabilities,omitempty"`
	// (Required) The relative target precision to achieve (greater than or equal to 0).
	//
	// If set to zero, the exact quantiles are computed, which could be very expensive.
	// Note that values greater than 1 are accepted but give the same result as 1.
	RelativeError float64 `protobuf:"fixed64,4,opt,name=relative_error,json=relativeError,proto3" json:"relative_error,omitempty"`
	// contains filtered or unexported fields
}

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

func (*StatApproxQuantile) Descriptor deprecated

func (*StatApproxQuantile) Descriptor() ([]byte, []int)

Deprecated: Use StatApproxQuantile.ProtoReflect.Descriptor instead.

func (*StatApproxQuantile) GetCols

func (x *StatApproxQuantile) GetCols() []string

func (*StatApproxQuantile) GetInput

func (x *StatApproxQuantile) GetInput() *Relation

func (*StatApproxQuantile) GetProbabilities

func (x *StatApproxQuantile) GetProbabilities() []float64

func (*StatApproxQuantile) GetRelativeError

func (x *StatApproxQuantile) GetRelativeError() float64

func (*StatApproxQuantile) ProtoMessage

func (*StatApproxQuantile) ProtoMessage()

func (*StatApproxQuantile) ProtoReflect

func (x *StatApproxQuantile) ProtoReflect() protoreflect.Message

func (*StatApproxQuantile) Reset

func (x *StatApproxQuantile) Reset()

func (*StatApproxQuantile) String

func (x *StatApproxQuantile) String() string

type StatCorr

type StatCorr struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) The name of the first column.
	Col1 string `protobuf:"bytes,2,opt,name=col1,proto3" json:"col1,omitempty"`
	// (Required) The name of the second column.
	Col2 string `protobuf:"bytes,3,opt,name=col2,proto3" json:"col2,omitempty"`
	// (Optional) Default value is 'pearson'.
	//
	// Currently only supports the Pearson Correlation Coefficient.
	Method *string `protobuf:"bytes,4,opt,name=method,proto3,oneof" json:"method,omitempty"`
	// contains filtered or unexported fields
}

Calculates the correlation of two columns of a DataFrame. Currently only supports the Pearson Correlation Coefficient. It will invoke 'Dataset.stat.corr' (same as 'StatFunctions.pearsonCorrelation') to compute the results.

func (*StatCorr) Descriptor deprecated

func (*StatCorr) Descriptor() ([]byte, []int)

Deprecated: Use StatCorr.ProtoReflect.Descriptor instead.

func (*StatCorr) GetCol1

func (x *StatCorr) GetCol1() string

func (*StatCorr) GetCol2

func (x *StatCorr) GetCol2() string

func (*StatCorr) GetInput

func (x *StatCorr) GetInput() *Relation

func (*StatCorr) GetMethod

func (x *StatCorr) GetMethod() string

func (*StatCorr) ProtoMessage

func (*StatCorr) ProtoMessage()

func (*StatCorr) ProtoReflect

func (x *StatCorr) ProtoReflect() protoreflect.Message

func (*StatCorr) Reset

func (x *StatCorr) Reset()

func (*StatCorr) String

func (x *StatCorr) String() string

type StatCov

type StatCov struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) The name of the first column.
	Col1 string `protobuf:"bytes,2,opt,name=col1,proto3" json:"col1,omitempty"`
	// (Required) The name of the second column.
	Col2 string `protobuf:"bytes,3,opt,name=col2,proto3" json:"col2,omitempty"`
	// contains filtered or unexported fields
}

Calculate the sample covariance of two numerical columns of a DataFrame. It will invoke 'Dataset.stat.cov' (same as 'StatFunctions.calculateCov') to compute the results.

func (*StatCov) Descriptor deprecated

func (*StatCov) Descriptor() ([]byte, []int)

Deprecated: Use StatCov.ProtoReflect.Descriptor instead.

func (*StatCov) GetCol1

func (x *StatCov) GetCol1() string

func (*StatCov) GetCol2

func (x *StatCov) GetCol2() string

func (*StatCov) GetInput

func (x *StatCov) GetInput() *Relation

func (*StatCov) ProtoMessage

func (*StatCov) ProtoMessage()

func (*StatCov) ProtoReflect

func (x *StatCov) ProtoReflect() protoreflect.Message

func (*StatCov) Reset

func (x *StatCov) Reset()

func (*StatCov) String

func (x *StatCov) String() string

type StatCrosstab

type StatCrosstab struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) The name of the first column.
	//
	// Distinct items will make the first item of each row.
	Col1 string `protobuf:"bytes,2,opt,name=col1,proto3" json:"col1,omitempty"`
	// (Required) The name of the second column.
	//
	// Distinct items will make the column names of the DataFrame.
	Col2 string `protobuf:"bytes,3,opt,name=col2,proto3" json:"col2,omitempty"`
	// contains filtered or unexported fields
}

Computes a pair-wise frequency table of the given columns. Also known as a contingency table. It will invoke 'Dataset.stat.crosstab' (same as 'StatFunctions.crossTabulate') to compute the results.

func (*StatCrosstab) Descriptor deprecated

func (*StatCrosstab) Descriptor() ([]byte, []int)

Deprecated: Use StatCrosstab.ProtoReflect.Descriptor instead.

func (*StatCrosstab) GetCol1

func (x *StatCrosstab) GetCol1() string

func (*StatCrosstab) GetCol2

func (x *StatCrosstab) GetCol2() string

func (*StatCrosstab) GetInput

func (x *StatCrosstab) GetInput() *Relation

func (*StatCrosstab) ProtoMessage

func (*StatCrosstab) ProtoMessage()

func (*StatCrosstab) ProtoReflect

func (x *StatCrosstab) ProtoReflect() protoreflect.Message

func (*StatCrosstab) Reset

func (x *StatCrosstab) Reset()

func (*StatCrosstab) String

func (x *StatCrosstab) String() string

type StatDescribe

type StatDescribe struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Optional) Columns to compute statistics on.
	Cols []string `protobuf:"bytes,2,rep,name=cols,proto3" json:"cols,omitempty"`
	// contains filtered or unexported fields
}

Computes basic statistics for numeric and string columns, including count, mean, stddev, min, and max. If no columns are given, this function computes statistics for all numerical or string columns.

func (*StatDescribe) Descriptor deprecated

func (*StatDescribe) Descriptor() ([]byte, []int)

Deprecated: Use StatDescribe.ProtoReflect.Descriptor instead.

func (*StatDescribe) GetCols

func (x *StatDescribe) GetCols() []string

func (*StatDescribe) GetInput

func (x *StatDescribe) GetInput() *Relation

func (*StatDescribe) ProtoMessage

func (*StatDescribe) ProtoMessage()

func (*StatDescribe) ProtoReflect

func (x *StatDescribe) ProtoReflect() protoreflect.Message

func (*StatDescribe) Reset

func (x *StatDescribe) Reset()

func (*StatDescribe) String

func (x *StatDescribe) String() string

type StatFreqItems

type StatFreqItems struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) The names of the columns to search frequent items in.
	Cols []string `protobuf:"bytes,2,rep,name=cols,proto3" json:"cols,omitempty"`
	// (Optional) The minimum frequency for an item to be considered `frequent`.
	// Should be greater than 1e-4.
	Support *float64 `protobuf:"fixed64,3,opt,name=support,proto3,oneof" json:"support,omitempty"`
	// contains filtered or unexported fields
}

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

func (*StatFreqItems) Descriptor deprecated

func (*StatFreqItems) Descriptor() ([]byte, []int)

Deprecated: Use StatFreqItems.ProtoReflect.Descriptor instead.

func (*StatFreqItems) GetCols

func (x *StatFreqItems) GetCols() []string

func (*StatFreqItems) GetInput

func (x *StatFreqItems) GetInput() *Relation

func (*StatFreqItems) GetSupport

func (x *StatFreqItems) GetSupport() float64

func (*StatFreqItems) ProtoMessage

func (*StatFreqItems) ProtoMessage()

func (*StatFreqItems) ProtoReflect

func (x *StatFreqItems) ProtoReflect() protoreflect.Message

func (*StatFreqItems) Reset

func (x *StatFreqItems) Reset()

func (*StatFreqItems) String

func (x *StatFreqItems) String() string

type StatSampleBy

type StatSampleBy struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) The column that defines strata.
	Col *Expression `protobuf:"bytes,2,opt,name=col,proto3" json:"col,omitempty"`
	// (Required) Sampling fraction for each stratum.
	//
	// If a stratum is not specified, we treat its fraction as zero.
	Fractions []*StatSampleBy_Fraction `protobuf:"bytes,3,rep,name=fractions,proto3" json:"fractions,omitempty"`
	// (Optional) The random seed.
	Seed *int64 `protobuf:"varint,5,opt,name=seed,proto3,oneof" json:"seed,omitempty"`
	// contains filtered or unexported fields
}

Returns a stratified sample without replacement based on the fraction given on each stratum. It will invoke 'Dataset.stat.freqItems' (same as 'StatFunctions.freqItems') to compute the results.

func (*StatSampleBy) Descriptor deprecated

func (*StatSampleBy) Descriptor() ([]byte, []int)

Deprecated: Use StatSampleBy.ProtoReflect.Descriptor instead.

func (*StatSampleBy) GetCol

func (x *StatSampleBy) GetCol() *Expression

func (*StatSampleBy) GetFractions

func (x *StatSampleBy) GetFractions() []*StatSampleBy_Fraction

func (*StatSampleBy) GetInput

func (x *StatSampleBy) GetInput() *Relation

func (*StatSampleBy) GetSeed

func (x *StatSampleBy) GetSeed() int64

func (*StatSampleBy) ProtoMessage

func (*StatSampleBy) ProtoMessage()

func (*StatSampleBy) ProtoReflect

func (x *StatSampleBy) ProtoReflect() protoreflect.Message

func (*StatSampleBy) Reset

func (x *StatSampleBy) Reset()

func (*StatSampleBy) String

func (x *StatSampleBy) String() string

type StatSampleBy_Fraction

type StatSampleBy_Fraction struct {

	// (Required) The stratum.
	Stratum *Expression_Literal `protobuf:"bytes,1,opt,name=stratum,proto3" json:"stratum,omitempty"`
	// (Required) The fraction value. Must be in [0, 1].
	Fraction float64 `protobuf:"fixed64,2,opt,name=fraction,proto3" json:"fraction,omitempty"`
	// contains filtered or unexported fields
}

func (*StatSampleBy_Fraction) Descriptor deprecated

func (*StatSampleBy_Fraction) Descriptor() ([]byte, []int)

Deprecated: Use StatSampleBy_Fraction.ProtoReflect.Descriptor instead.

func (*StatSampleBy_Fraction) GetFraction

func (x *StatSampleBy_Fraction) GetFraction() float64

func (*StatSampleBy_Fraction) GetStratum

func (x *StatSampleBy_Fraction) GetStratum() *Expression_Literal

func (*StatSampleBy_Fraction) ProtoMessage

func (*StatSampleBy_Fraction) ProtoMessage()

func (*StatSampleBy_Fraction) ProtoReflect

func (x *StatSampleBy_Fraction) ProtoReflect() protoreflect.Message

func (*StatSampleBy_Fraction) Reset

func (x *StatSampleBy_Fraction) Reset()

func (*StatSampleBy_Fraction) String

func (x *StatSampleBy_Fraction) String() string

type StatSummary

type StatSummary struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Optional) Statistics from to be computed.
	//
	// Available statistics are:
	//
	//	count
	//	mean
	//	stddev
	//	min
	//	max
	//	arbitrary approximate percentiles specified as a percentage (e.g. 75%)
	//	count_distinct
	//	approx_count_distinct
	//
	// If no statistics are given, this function computes 'count', 'mean', 'stddev', 'min',
	// 'approximate quartiles' (percentiles at 25%, 50%, and 75%), and 'max'.
	Statistics []string `protobuf:"bytes,2,rep,name=statistics,proto3" json:"statistics,omitempty"`
	// contains filtered or unexported fields
}

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

func (*StatSummary) Descriptor deprecated

func (*StatSummary) Descriptor() ([]byte, []int)

Deprecated: Use StatSummary.ProtoReflect.Descriptor instead.

func (*StatSummary) GetInput

func (x *StatSummary) GetInput() *Relation

func (*StatSummary) GetStatistics

func (x *StatSummary) GetStatistics() []string

func (*StatSummary) ProtoMessage

func (*StatSummary) ProtoMessage()

func (*StatSummary) ProtoReflect

func (x *StatSummary) ProtoReflect() protoreflect.Message

func (*StatSummary) Reset

func (x *StatSummary) Reset()

func (*StatSummary) String

func (x *StatSummary) String() string

type StorageLevel

type StorageLevel struct {

	// (Required) Whether the cache should use disk or not.
	UseDisk bool `protobuf:"varint,1,opt,name=use_disk,json=useDisk,proto3" json:"use_disk,omitempty"`
	// (Required) Whether the cache should use memory or not.
	UseMemory bool `protobuf:"varint,2,opt,name=use_memory,json=useMemory,proto3" json:"use_memory,omitempty"`
	// (Required) Whether the cache should use off-heap or not.
	UseOffHeap bool `protobuf:"varint,3,opt,name=use_off_heap,json=useOffHeap,proto3" json:"use_off_heap,omitempty"`
	// (Required) Whether the cached data is deserialized or not.
	Deserialized bool `protobuf:"varint,4,opt,name=deserialized,proto3" json:"deserialized,omitempty"`
	// (Required) The number of replicas.
	Replication int32 `protobuf:"varint,5,opt,name=replication,proto3" json:"replication,omitempty"`
	// contains filtered or unexported fields
}

StorageLevel for persisting Datasets/Tables.

func (*StorageLevel) Descriptor deprecated

func (*StorageLevel) Descriptor() ([]byte, []int)

Deprecated: Use StorageLevel.ProtoReflect.Descriptor instead.

func (*StorageLevel) GetDeserialized

func (x *StorageLevel) GetDeserialized() bool

func (*StorageLevel) GetReplication

func (x *StorageLevel) GetReplication() int32

func (*StorageLevel) GetUseDisk

func (x *StorageLevel) GetUseDisk() bool

func (*StorageLevel) GetUseMemory

func (x *StorageLevel) GetUseMemory() bool

func (*StorageLevel) GetUseOffHeap

func (x *StorageLevel) GetUseOffHeap() bool

func (*StorageLevel) ProtoMessage

func (*StorageLevel) ProtoMessage()

func (*StorageLevel) ProtoReflect

func (x *StorageLevel) ProtoReflect() protoreflect.Message

func (*StorageLevel) Reset

func (x *StorageLevel) Reset()

func (*StorageLevel) String

func (x *StorageLevel) String() string

type StreamingForeachWriter

type StreamingForeachWriter struct {

	// Types that are assignable to Writer:
	//
	//	*StreamingForeachWriter_PythonWriter
	Writer isStreamingForeachWriter_Writer `protobuf_oneof:"writer"`
	// contains filtered or unexported fields
}

func (*StreamingForeachWriter) Descriptor deprecated

func (*StreamingForeachWriter) Descriptor() ([]byte, []int)

Deprecated: Use StreamingForeachWriter.ProtoReflect.Descriptor instead.

func (*StreamingForeachWriter) GetPythonWriter

func (x *StreamingForeachWriter) GetPythonWriter() *PythonUDF

func (*StreamingForeachWriter) GetWriter

func (m *StreamingForeachWriter) GetWriter() isStreamingForeachWriter_Writer

func (*StreamingForeachWriter) ProtoMessage

func (*StreamingForeachWriter) ProtoMessage()

func (*StreamingForeachWriter) ProtoReflect

func (x *StreamingForeachWriter) ProtoReflect() protoreflect.Message

func (*StreamingForeachWriter) Reset

func (x *StreamingForeachWriter) Reset()

func (*StreamingForeachWriter) String

func (x *StreamingForeachWriter) String() string

type StreamingForeachWriter_PythonWriter

type StreamingForeachWriter_PythonWriter struct {
	PythonWriter *PythonUDF `protobuf:"bytes,1,opt,name=python_writer,json=pythonWriter,proto3,oneof"`
}

type StreamingQueryCommand

type StreamingQueryCommand struct {

	// (Required) Query instance. See `StreamingQueryInstanceId`.
	QueryId *StreamingQueryInstanceId `protobuf:"bytes,1,opt,name=query_id,json=queryId,proto3" json:"query_id,omitempty"`
	// See documentation for the corresponding API method in StreamingQuery.
	//
	// Types that are assignable to Command:
	//
	//	*StreamingQueryCommand_Status
	//	*StreamingQueryCommand_LastProgress
	//	*StreamingQueryCommand_RecentProgress
	//	*StreamingQueryCommand_Stop
	//	*StreamingQueryCommand_ProcessAllAvailable
	//	*StreamingQueryCommand_Explain
	//	*StreamingQueryCommand_Exception
	//	*StreamingQueryCommand_AwaitTermination
	Command isStreamingQueryCommand_Command `protobuf_oneof:"command"`
	// contains filtered or unexported fields
}

Commands for a streaming query.

func (*StreamingQueryCommand) Descriptor deprecated

func (*StreamingQueryCommand) Descriptor() ([]byte, []int)

Deprecated: Use StreamingQueryCommand.ProtoReflect.Descriptor instead.

func (*StreamingQueryCommand) GetAwaitTermination

func (*StreamingQueryCommand) GetCommand

func (m *StreamingQueryCommand) GetCommand() isStreamingQueryCommand_Command

func (*StreamingQueryCommand) GetException

func (x *StreamingQueryCommand) GetException() bool

func (*StreamingQueryCommand) GetExplain

func (*StreamingQueryCommand) GetLastProgress

func (x *StreamingQueryCommand) GetLastProgress() bool

func (*StreamingQueryCommand) GetProcessAllAvailable

func (x *StreamingQueryCommand) GetProcessAllAvailable() bool

func (*StreamingQueryCommand) GetQueryId

func (*StreamingQueryCommand) GetRecentProgress

func (x *StreamingQueryCommand) GetRecentProgress() bool

func (*StreamingQueryCommand) GetStatus

func (x *StreamingQueryCommand) GetStatus() bool

func (*StreamingQueryCommand) GetStop

func (x *StreamingQueryCommand) GetStop() bool

func (*StreamingQueryCommand) ProtoMessage

func (*StreamingQueryCommand) ProtoMessage()

func (*StreamingQueryCommand) ProtoReflect

func (x *StreamingQueryCommand) ProtoReflect() protoreflect.Message

func (*StreamingQueryCommand) Reset

func (x *StreamingQueryCommand) Reset()

func (*StreamingQueryCommand) String

func (x *StreamingQueryCommand) String() string

type StreamingQueryCommandResult

type StreamingQueryCommandResult struct {

	// (Required) Query instance id. See `StreamingQueryInstanceId`.
	QueryId *StreamingQueryInstanceId `protobuf:"bytes,1,opt,name=query_id,json=queryId,proto3" json:"query_id,omitempty"`
	// Types that are assignable to ResultType:
	//
	//	*StreamingQueryCommandResult_Status
	//	*StreamingQueryCommandResult_RecentProgress
	//	*StreamingQueryCommandResult_Explain
	//	*StreamingQueryCommandResult_Exception
	//	*StreamingQueryCommandResult_AwaitTermination
	ResultType isStreamingQueryCommandResult_ResultType `protobuf_oneof:"result_type"`
	// contains filtered or unexported fields
}

Response for commands on a streaming query.

func (*StreamingQueryCommandResult) Descriptor deprecated

func (*StreamingQueryCommandResult) Descriptor() ([]byte, []int)

Deprecated: Use StreamingQueryCommandResult.ProtoReflect.Descriptor instead.

func (*StreamingQueryCommandResult) GetAwaitTermination

func (*StreamingQueryCommandResult) GetException

func (*StreamingQueryCommandResult) GetExplain

func (*StreamingQueryCommandResult) GetQueryId

func (*StreamingQueryCommandResult) GetRecentProgress

func (*StreamingQueryCommandResult) GetResultType

func (m *StreamingQueryCommandResult) GetResultType() isStreamingQueryCommandResult_ResultType

func (*StreamingQueryCommandResult) GetStatus

func (*StreamingQueryCommandResult) ProtoMessage

func (*StreamingQueryCommandResult) ProtoMessage()

func (*StreamingQueryCommandResult) ProtoReflect

func (*StreamingQueryCommandResult) Reset

func (x *StreamingQueryCommandResult) Reset()

func (*StreamingQueryCommandResult) String

func (x *StreamingQueryCommandResult) String() string

type StreamingQueryCommandResult_AwaitTermination

type StreamingQueryCommandResult_AwaitTermination struct {
	AwaitTermination *StreamingQueryCommandResult_AwaitTerminationResult `protobuf:"bytes,6,opt,name=await_termination,json=awaitTermination,proto3,oneof"`
}

type StreamingQueryCommandResult_AwaitTerminationResult

type StreamingQueryCommandResult_AwaitTerminationResult struct {
	Terminated bool `protobuf:"varint,1,opt,name=terminated,proto3" json:"terminated,omitempty"`
	// contains filtered or unexported fields
}

func (*StreamingQueryCommandResult_AwaitTerminationResult) Descriptor deprecated

Deprecated: Use StreamingQueryCommandResult_AwaitTerminationResult.ProtoReflect.Descriptor instead.

func (*StreamingQueryCommandResult_AwaitTerminationResult) GetTerminated

func (*StreamingQueryCommandResult_AwaitTerminationResult) ProtoMessage

func (*StreamingQueryCommandResult_AwaitTerminationResult) ProtoReflect

func (*StreamingQueryCommandResult_AwaitTerminationResult) Reset

func (*StreamingQueryCommandResult_AwaitTerminationResult) String

type StreamingQueryCommandResult_Exception

type StreamingQueryCommandResult_Exception struct {
	Exception *StreamingQueryCommandResult_ExceptionResult `protobuf:"bytes,5,opt,name=exception,proto3,oneof"`
}

type StreamingQueryCommandResult_ExceptionResult

type StreamingQueryCommandResult_ExceptionResult struct {

	// (Optional) Exception message as string, maps to the return value of original
	// StreamingQueryException's toString method
	ExceptionMessage *string `protobuf:"bytes,1,opt,name=exception_message,json=exceptionMessage,proto3,oneof" json:"exception_message,omitempty"`
	// (Optional) Exception error class as string
	ErrorClass *string `protobuf:"bytes,2,opt,name=error_class,json=errorClass,proto3,oneof" json:"error_class,omitempty"`
	// (Optional) Exception stack trace as string
	StackTrace *string `protobuf:"bytes,3,opt,name=stack_trace,json=stackTrace,proto3,oneof" json:"stack_trace,omitempty"`
	// contains filtered or unexported fields
}

func (*StreamingQueryCommandResult_ExceptionResult) Descriptor deprecated

Deprecated: Use StreamingQueryCommandResult_ExceptionResult.ProtoReflect.Descriptor instead.

func (*StreamingQueryCommandResult_ExceptionResult) GetErrorClass

func (*StreamingQueryCommandResult_ExceptionResult) GetExceptionMessage

func (x *StreamingQueryCommandResult_ExceptionResult) GetExceptionMessage() string

func (*StreamingQueryCommandResult_ExceptionResult) GetStackTrace

func (*StreamingQueryCommandResult_ExceptionResult) ProtoMessage

func (*StreamingQueryCommandResult_ExceptionResult) ProtoReflect

func (*StreamingQueryCommandResult_ExceptionResult) Reset

func (*StreamingQueryCommandResult_ExceptionResult) String

type StreamingQueryCommandResult_Explain

type StreamingQueryCommandResult_Explain struct {
	Explain *StreamingQueryCommandResult_ExplainResult `protobuf:"bytes,4,opt,name=explain,proto3,oneof"`
}

type StreamingQueryCommandResult_ExplainResult

type StreamingQueryCommandResult_ExplainResult struct {

	// Logical and physical plans as string
	Result string `protobuf:"bytes,1,opt,name=result,proto3" json:"result,omitempty"`
	// contains filtered or unexported fields
}

func (*StreamingQueryCommandResult_ExplainResult) Descriptor deprecated

func (*StreamingQueryCommandResult_ExplainResult) Descriptor() ([]byte, []int)

Deprecated: Use StreamingQueryCommandResult_ExplainResult.ProtoReflect.Descriptor instead.

func (*StreamingQueryCommandResult_ExplainResult) GetResult

func (*StreamingQueryCommandResult_ExplainResult) ProtoMessage

func (*StreamingQueryCommandResult_ExplainResult) ProtoReflect

func (*StreamingQueryCommandResult_ExplainResult) Reset

func (*StreamingQueryCommandResult_ExplainResult) String

type StreamingQueryCommandResult_RecentProgress

type StreamingQueryCommandResult_RecentProgress struct {
	RecentProgress *StreamingQueryCommandResult_RecentProgressResult `protobuf:"bytes,3,opt,name=recent_progress,json=recentProgress,proto3,oneof"`
}

type StreamingQueryCommandResult_RecentProgressResult

type StreamingQueryCommandResult_RecentProgressResult struct {

	// Progress reports as an array of json strings.
	RecentProgressJson []string `protobuf:"bytes,5,rep,name=recent_progress_json,json=recentProgressJson,proto3" json:"recent_progress_json,omitempty"`
	// contains filtered or unexported fields
}

func (*StreamingQueryCommandResult_RecentProgressResult) Descriptor deprecated

Deprecated: Use StreamingQueryCommandResult_RecentProgressResult.ProtoReflect.Descriptor instead.

func (*StreamingQueryCommandResult_RecentProgressResult) GetRecentProgressJson

func (x *StreamingQueryCommandResult_RecentProgressResult) GetRecentProgressJson() []string

func (*StreamingQueryCommandResult_RecentProgressResult) ProtoMessage

func (*StreamingQueryCommandResult_RecentProgressResult) ProtoReflect

func (*StreamingQueryCommandResult_RecentProgressResult) Reset

func (*StreamingQueryCommandResult_RecentProgressResult) String

type StreamingQueryCommandResult_Status

type StreamingQueryCommandResult_Status struct {
	Status *StreamingQueryCommandResult_StatusResult `protobuf:"bytes,2,opt,name=status,proto3,oneof"`
}

type StreamingQueryCommandResult_StatusResult

type StreamingQueryCommandResult_StatusResult struct {

	// See documentation for these Scala 'StreamingQueryStatus' struct
	StatusMessage   string `protobuf:"bytes,1,opt,name=status_message,json=statusMessage,proto3" json:"status_message,omitempty"`
	IsDataAvailable bool   `protobuf:"varint,2,opt,name=is_data_available,json=isDataAvailable,proto3" json:"is_data_available,omitempty"`
	IsTriggerActive bool   `protobuf:"varint,3,opt,name=is_trigger_active,json=isTriggerActive,proto3" json:"is_trigger_active,omitempty"`
	IsActive        bool   `protobuf:"varint,4,opt,name=is_active,json=isActive,proto3" json:"is_active,omitempty"`
	// contains filtered or unexported fields
}

func (*StreamingQueryCommandResult_StatusResult) Descriptor deprecated

func (*StreamingQueryCommandResult_StatusResult) Descriptor() ([]byte, []int)

Deprecated: Use StreamingQueryCommandResult_StatusResult.ProtoReflect.Descriptor instead.

func (*StreamingQueryCommandResult_StatusResult) GetIsActive

func (*StreamingQueryCommandResult_StatusResult) GetIsDataAvailable

func (x *StreamingQueryCommandResult_StatusResult) GetIsDataAvailable() bool

func (*StreamingQueryCommandResult_StatusResult) GetIsTriggerActive

func (x *StreamingQueryCommandResult_StatusResult) GetIsTriggerActive() bool

func (*StreamingQueryCommandResult_StatusResult) GetStatusMessage

func (x *StreamingQueryCommandResult_StatusResult) GetStatusMessage() string

func (*StreamingQueryCommandResult_StatusResult) ProtoMessage

func (*StreamingQueryCommandResult_StatusResult) ProtoReflect

func (*StreamingQueryCommandResult_StatusResult) Reset

func (*StreamingQueryCommandResult_StatusResult) String

type StreamingQueryCommand_AwaitTermination

type StreamingQueryCommand_AwaitTermination struct {
	// awaitTermination() API. Waits for the termination of the query.
	AwaitTermination *StreamingQueryCommand_AwaitTerminationCommand `protobuf:"bytes,9,opt,name=await_termination,json=awaitTermination,proto3,oneof"`
}

type StreamingQueryCommand_AwaitTerminationCommand

type StreamingQueryCommand_AwaitTerminationCommand struct {
	TimeoutMs *int64 `protobuf:"varint,2,opt,name=timeout_ms,json=timeoutMs,proto3,oneof" json:"timeout_ms,omitempty"`
	// contains filtered or unexported fields
}

func (*StreamingQueryCommand_AwaitTerminationCommand) Descriptor deprecated

Deprecated: Use StreamingQueryCommand_AwaitTerminationCommand.ProtoReflect.Descriptor instead.

func (*StreamingQueryCommand_AwaitTerminationCommand) GetTimeoutMs

func (*StreamingQueryCommand_AwaitTerminationCommand) ProtoMessage

func (*StreamingQueryCommand_AwaitTerminationCommand) ProtoReflect

func (*StreamingQueryCommand_AwaitTerminationCommand) Reset

func (*StreamingQueryCommand_AwaitTerminationCommand) String

type StreamingQueryCommand_Exception

type StreamingQueryCommand_Exception struct {
	// exception() API. Returns the exception in the query if any.
	Exception bool `protobuf:"varint,8,opt,name=exception,proto3,oneof"`
}

type StreamingQueryCommand_Explain

type StreamingQueryCommand_Explain struct {
	// explain() API. Returns logical and physical plans.
	Explain *StreamingQueryCommand_ExplainCommand `protobuf:"bytes,7,opt,name=explain,proto3,oneof"`
}

type StreamingQueryCommand_ExplainCommand

type StreamingQueryCommand_ExplainCommand struct {

	// TODO: Consider reusing Explain from AnalyzePlanRequest message.
	//
	//	We can not do this right now since it base.proto imports this file.
	Extended bool `protobuf:"varint,1,opt,name=extended,proto3" json:"extended,omitempty"`
	// contains filtered or unexported fields
}

func (*StreamingQueryCommand_ExplainCommand) Descriptor deprecated

func (*StreamingQueryCommand_ExplainCommand) Descriptor() ([]byte, []int)

Deprecated: Use StreamingQueryCommand_ExplainCommand.ProtoReflect.Descriptor instead.

func (*StreamingQueryCommand_ExplainCommand) GetExtended

func (x *StreamingQueryCommand_ExplainCommand) GetExtended() bool

func (*StreamingQueryCommand_ExplainCommand) ProtoMessage

func (*StreamingQueryCommand_ExplainCommand) ProtoMessage()

func (*StreamingQueryCommand_ExplainCommand) ProtoReflect

func (*StreamingQueryCommand_ExplainCommand) Reset

func (*StreamingQueryCommand_ExplainCommand) String

type StreamingQueryCommand_LastProgress

type StreamingQueryCommand_LastProgress struct {
	// lastProgress() API.
	LastProgress bool `protobuf:"varint,3,opt,name=last_progress,json=lastProgress,proto3,oneof"`
}

type StreamingQueryCommand_ProcessAllAvailable

type StreamingQueryCommand_ProcessAllAvailable struct {
	// processAllAvailable() API. Waits till all the available data is processed
	ProcessAllAvailable bool `protobuf:"varint,6,opt,name=process_all_available,json=processAllAvailable,proto3,oneof"`
}

type StreamingQueryCommand_RecentProgress

type StreamingQueryCommand_RecentProgress struct {
	// recentProgress() API.
	RecentProgress bool `protobuf:"varint,4,opt,name=recent_progress,json=recentProgress,proto3,oneof"`
}

type StreamingQueryCommand_Status

type StreamingQueryCommand_Status struct {
	// status() API.
	Status bool `protobuf:"varint,2,opt,name=status,proto3,oneof"`
}

type StreamingQueryCommand_Stop

type StreamingQueryCommand_Stop struct {
	// stop() API. Stops the query.
	Stop bool `protobuf:"varint,5,opt,name=stop,proto3,oneof"`
}

type StreamingQueryInstanceId

type StreamingQueryInstanceId struct {

	// (Required) The unique id of this query that persists across restarts from checkpoint data.
	// That is, this id is generated when a query is started for the first time, and
	// will be the same every time it is restarted from checkpoint data.
	Id string `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`
	// (Required) The unique id of this run of the query. That is, every start/restart of a query
	// will generate a unique run_id. Therefore, every time a query is restarted from
	// checkpoint, it will have the same `id` but different `run_id`s.
	RunId string `protobuf:"bytes,2,opt,name=run_id,json=runId,proto3" json:"run_id,omitempty"`
	// contains filtered or unexported fields
}

A tuple that uniquely identifies an instance of streaming query run. It consists of `id` that persists across the streaming runs and `run_id` that changes between each run of the streaming query that resumes from the checkpoint.

func (*StreamingQueryInstanceId) Descriptor deprecated

func (*StreamingQueryInstanceId) Descriptor() ([]byte, []int)

Deprecated: Use StreamingQueryInstanceId.ProtoReflect.Descriptor instead.

func (*StreamingQueryInstanceId) GetId

func (x *StreamingQueryInstanceId) GetId() string

func (*StreamingQueryInstanceId) GetRunId

func (x *StreamingQueryInstanceId) GetRunId() string

func (*StreamingQueryInstanceId) ProtoMessage

func (*StreamingQueryInstanceId) ProtoMessage()

func (*StreamingQueryInstanceId) ProtoReflect

func (x *StreamingQueryInstanceId) ProtoReflect() protoreflect.Message

func (*StreamingQueryInstanceId) Reset

func (x *StreamingQueryInstanceId) Reset()

func (*StreamingQueryInstanceId) String

func (x *StreamingQueryInstanceId) String() string

type StreamingQueryManagerCommand

type StreamingQueryManagerCommand struct {

	// See documentation for the corresponding API method in StreamingQueryManager.
	//
	// Types that are assignable to Command:
	//
	//	*StreamingQueryManagerCommand_Active
	//	*StreamingQueryManagerCommand_GetQuery
	//	*StreamingQueryManagerCommand_AwaitAnyTermination
	//	*StreamingQueryManagerCommand_ResetTerminated
	Command isStreamingQueryManagerCommand_Command `protobuf_oneof:"command"`
	// contains filtered or unexported fields
}

Commands for the streaming query manager.

func (*StreamingQueryManagerCommand) Descriptor deprecated

func (*StreamingQueryManagerCommand) Descriptor() ([]byte, []int)

Deprecated: Use StreamingQueryManagerCommand.ProtoReflect.Descriptor instead.

func (*StreamingQueryManagerCommand) GetActive

func (x *StreamingQueryManagerCommand) GetActive() bool

func (*StreamingQueryManagerCommand) GetAwaitAnyTermination

func (*StreamingQueryManagerCommand) GetCommand

func (m *StreamingQueryManagerCommand) GetCommand() isStreamingQueryManagerCommand_Command

func (*StreamingQueryManagerCommand) GetGetQuery

func (x *StreamingQueryManagerCommand) GetGetQuery() string

func (*StreamingQueryManagerCommand) GetResetTerminated

func (x *StreamingQueryManagerCommand) GetResetTerminated() bool

func (*StreamingQueryManagerCommand) ProtoMessage

func (*StreamingQueryManagerCommand) ProtoMessage()

func (*StreamingQueryManagerCommand) ProtoReflect

func (*StreamingQueryManagerCommand) Reset

func (x *StreamingQueryManagerCommand) Reset()

func (*StreamingQueryManagerCommand) String

type StreamingQueryManagerCommandResult

type StreamingQueryManagerCommandResult struct {

	// Types that are assignable to ResultType:
	//
	//	*StreamingQueryManagerCommandResult_Active
	//	*StreamingQueryManagerCommandResult_Query
	//	*StreamingQueryManagerCommandResult_AwaitAnyTermination
	//	*StreamingQueryManagerCommandResult_ResetTerminated
	ResultType isStreamingQueryManagerCommandResult_ResultType `protobuf_oneof:"result_type"`
	// contains filtered or unexported fields
}

Response for commands on the streaming query manager.

func (*StreamingQueryManagerCommandResult) Descriptor deprecated

func (*StreamingQueryManagerCommandResult) Descriptor() ([]byte, []int)

Deprecated: Use StreamingQueryManagerCommandResult.ProtoReflect.Descriptor instead.

func (*StreamingQueryManagerCommandResult) GetActive

func (*StreamingQueryManagerCommandResult) GetAwaitAnyTermination

func (*StreamingQueryManagerCommandResult) GetQuery

func (*StreamingQueryManagerCommandResult) GetResetTerminated

func (x *StreamingQueryManagerCommandResult) GetResetTerminated() bool

func (*StreamingQueryManagerCommandResult) GetResultType

func (m *StreamingQueryManagerCommandResult) GetResultType() isStreamingQueryManagerCommandResult_ResultType

func (*StreamingQueryManagerCommandResult) ProtoMessage

func (*StreamingQueryManagerCommandResult) ProtoMessage()

func (*StreamingQueryManagerCommandResult) ProtoReflect

func (*StreamingQueryManagerCommandResult) Reset

func (*StreamingQueryManagerCommandResult) String

type StreamingQueryManagerCommandResult_Active

type StreamingQueryManagerCommandResult_Active struct {
	Active *StreamingQueryManagerCommandResult_ActiveResult `protobuf:"bytes,1,opt,name=active,proto3,oneof"`
}

type StreamingQueryManagerCommandResult_ActiveResult

type StreamingQueryManagerCommandResult_ActiveResult struct {
	ActiveQueries []*StreamingQueryManagerCommandResult_StreamingQueryInstance `protobuf:"bytes,1,rep,name=active_queries,json=activeQueries,proto3" json:"active_queries,omitempty"`
	// contains filtered or unexported fields
}

func (*StreamingQueryManagerCommandResult_ActiveResult) Descriptor deprecated

Deprecated: Use StreamingQueryManagerCommandResult_ActiveResult.ProtoReflect.Descriptor instead.

func (*StreamingQueryManagerCommandResult_ActiveResult) GetActiveQueries

func (*StreamingQueryManagerCommandResult_ActiveResult) ProtoMessage

func (*StreamingQueryManagerCommandResult_ActiveResult) ProtoReflect

func (*StreamingQueryManagerCommandResult_ActiveResult) Reset

func (*StreamingQueryManagerCommandResult_ActiveResult) String

type StreamingQueryManagerCommandResult_AwaitAnyTermination

type StreamingQueryManagerCommandResult_AwaitAnyTermination struct {
	AwaitAnyTermination *StreamingQueryManagerCommandResult_AwaitAnyTerminationResult `protobuf:"bytes,3,opt,name=await_any_termination,json=awaitAnyTermination,proto3,oneof"`
}

type StreamingQueryManagerCommandResult_AwaitAnyTerminationResult

type StreamingQueryManagerCommandResult_AwaitAnyTerminationResult struct {
	Terminated bool `protobuf:"varint,1,opt,name=terminated,proto3" json:"terminated,omitempty"`
	// contains filtered or unexported fields
}

func (*StreamingQueryManagerCommandResult_AwaitAnyTerminationResult) Descriptor deprecated

Deprecated: Use StreamingQueryManagerCommandResult_AwaitAnyTerminationResult.ProtoReflect.Descriptor instead.

func (*StreamingQueryManagerCommandResult_AwaitAnyTerminationResult) GetTerminated

func (*StreamingQueryManagerCommandResult_AwaitAnyTerminationResult) ProtoMessage

func (*StreamingQueryManagerCommandResult_AwaitAnyTerminationResult) ProtoReflect

func (*StreamingQueryManagerCommandResult_AwaitAnyTerminationResult) Reset

func (*StreamingQueryManagerCommandResult_AwaitAnyTerminationResult) String

type StreamingQueryManagerCommandResult_Query

type StreamingQueryManagerCommandResult_Query struct {
	Query *StreamingQueryManagerCommandResult_StreamingQueryInstance `protobuf:"bytes,2,opt,name=query,proto3,oneof"`
}

type StreamingQueryManagerCommandResult_ResetTerminated

type StreamingQueryManagerCommandResult_ResetTerminated struct {
	ResetTerminated bool `protobuf:"varint,4,opt,name=reset_terminated,json=resetTerminated,proto3,oneof"`
}

type StreamingQueryManagerCommandResult_StreamingQueryInstance

type StreamingQueryManagerCommandResult_StreamingQueryInstance struct {

	// (Required) The id and runId of this query.
	Id *StreamingQueryInstanceId `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`
	// (Optional) The name of this query.
	Name *string `protobuf:"bytes,2,opt,name=name,proto3,oneof" json:"name,omitempty"`
	// contains filtered or unexported fields
}

func (*StreamingQueryManagerCommandResult_StreamingQueryInstance) Descriptor deprecated

Deprecated: Use StreamingQueryManagerCommandResult_StreamingQueryInstance.ProtoReflect.Descriptor instead.

func (*StreamingQueryManagerCommandResult_StreamingQueryInstance) GetId

func (*StreamingQueryManagerCommandResult_StreamingQueryInstance) GetName

func (*StreamingQueryManagerCommandResult_StreamingQueryInstance) ProtoMessage

func (*StreamingQueryManagerCommandResult_StreamingQueryInstance) ProtoReflect

func (*StreamingQueryManagerCommandResult_StreamingQueryInstance) Reset

func (*StreamingQueryManagerCommandResult_StreamingQueryInstance) String

type StreamingQueryManagerCommand_Active

type StreamingQueryManagerCommand_Active struct {
	// active() API, returns a list of active queries.
	Active bool `protobuf:"varint,1,opt,name=active,proto3,oneof"`
}

type StreamingQueryManagerCommand_AwaitAnyTermination

type StreamingQueryManagerCommand_AwaitAnyTermination struct {
	// awaitAnyTermination() API, wait until any query terminates or timeout.
	AwaitAnyTermination *StreamingQueryManagerCommand_AwaitAnyTerminationCommand `protobuf:"bytes,3,opt,name=await_any_termination,json=awaitAnyTermination,proto3,oneof"`
}

type StreamingQueryManagerCommand_AwaitAnyTerminationCommand

type StreamingQueryManagerCommand_AwaitAnyTerminationCommand struct {

	// (Optional) The waiting time in milliseconds to wait for any query to terminate.
	TimeoutMs *int64 `protobuf:"varint,1,opt,name=timeout_ms,json=timeoutMs,proto3,oneof" json:"timeout_ms,omitempty"`
	// contains filtered or unexported fields
}

func (*StreamingQueryManagerCommand_AwaitAnyTerminationCommand) Descriptor deprecated

Deprecated: Use StreamingQueryManagerCommand_AwaitAnyTerminationCommand.ProtoReflect.Descriptor instead.

func (*StreamingQueryManagerCommand_AwaitAnyTerminationCommand) GetTimeoutMs

func (*StreamingQueryManagerCommand_AwaitAnyTerminationCommand) ProtoMessage

func (*StreamingQueryManagerCommand_AwaitAnyTerminationCommand) ProtoReflect

func (*StreamingQueryManagerCommand_AwaitAnyTerminationCommand) Reset

func (*StreamingQueryManagerCommand_AwaitAnyTerminationCommand) String

type StreamingQueryManagerCommand_GetQuery

type StreamingQueryManagerCommand_GetQuery struct {
	// get() API, returns the StreamingQuery identified by id.
	GetQuery string `protobuf:"bytes,2,opt,name=get_query,json=getQuery,proto3,oneof"`
}

type StreamingQueryManagerCommand_ResetTerminated

type StreamingQueryManagerCommand_ResetTerminated struct {
	// resetTerminated() API.
	ResetTerminated bool `protobuf:"varint,4,opt,name=reset_terminated,json=resetTerminated,proto3,oneof"`
}

type SubqueryAlias

type SubqueryAlias struct {

	// (Required) The input relation of SubqueryAlias.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) The alias.
	Alias string `protobuf:"bytes,2,opt,name=alias,proto3" json:"alias,omitempty"`
	// (Optional) Qualifier of the alias.
	Qualifier []string `protobuf:"bytes,3,rep,name=qualifier,proto3" json:"qualifier,omitempty"`
	// contains filtered or unexported fields
}

Relation alias.

func (*SubqueryAlias) Descriptor deprecated

func (*SubqueryAlias) Descriptor() ([]byte, []int)

Deprecated: Use SubqueryAlias.ProtoReflect.Descriptor instead.

func (*SubqueryAlias) GetAlias

func (x *SubqueryAlias) GetAlias() string

func (*SubqueryAlias) GetInput

func (x *SubqueryAlias) GetInput() *Relation

func (*SubqueryAlias) GetQualifier

func (x *SubqueryAlias) GetQualifier() []string

func (*SubqueryAlias) ProtoMessage

func (*SubqueryAlias) ProtoMessage()

func (*SubqueryAlias) ProtoReflect

func (x *SubqueryAlias) ProtoReflect() protoreflect.Message

func (*SubqueryAlias) Reset

func (x *SubqueryAlias) Reset()

func (*SubqueryAlias) String

func (x *SubqueryAlias) String() string

type TableExists

type TableExists struct {

	// (Required)
	TableName string `protobuf:"bytes,1,opt,name=table_name,json=tableName,proto3" json:"table_name,omitempty"`
	// (Optional)
	DbName *string `protobuf:"bytes,2,opt,name=db_name,json=dbName,proto3,oneof" json:"db_name,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.tableExists`

func (*TableExists) Descriptor deprecated

func (*TableExists) Descriptor() ([]byte, []int)

Deprecated: Use TableExists.ProtoReflect.Descriptor instead.

func (*TableExists) GetDbName

func (x *TableExists) GetDbName() string

func (*TableExists) GetTableName

func (x *TableExists) GetTableName() string

func (*TableExists) ProtoMessage

func (*TableExists) ProtoMessage()

func (*TableExists) ProtoReflect

func (x *TableExists) ProtoReflect() protoreflect.Message

func (*TableExists) Reset

func (x *TableExists) Reset()

func (*TableExists) String

func (x *TableExists) String() string

type Tail

type Tail struct {

	// (Required) Input relation for an Tail.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) the limit.
	Limit int32 `protobuf:"varint,2,opt,name=limit,proto3" json:"limit,omitempty"`
	// contains filtered or unexported fields
}

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

func (*Tail) Descriptor deprecated

func (*Tail) Descriptor() ([]byte, []int)

Deprecated: Use Tail.ProtoReflect.Descriptor instead.

func (*Tail) GetInput

func (x *Tail) GetInput() *Relation

func (*Tail) GetLimit

func (x *Tail) GetLimit() int32

func (*Tail) ProtoMessage

func (*Tail) ProtoMessage()

func (*Tail) ProtoReflect

func (x *Tail) ProtoReflect() protoreflect.Message

func (*Tail) Reset

func (x *Tail) Reset()

func (*Tail) String

func (x *Tail) String() string

type ToDF

type ToDF struct {

	// (Required) The input relation of RenameColumnsBySameLengthNames.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required)
	//
	// The number of columns of the input relation must be equal to the length
	// of this field. If this is not true, an exception will be returned.
	ColumnNames []string `protobuf:"bytes,2,rep,name=column_names,json=columnNames,proto3" json:"column_names,omitempty"`
	// contains filtered or unexported fields
}

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

func (*ToDF) Descriptor deprecated

func (*ToDF) Descriptor() ([]byte, []int)

Deprecated: Use ToDF.ProtoReflect.Descriptor instead.

func (*ToDF) GetColumnNames

func (x *ToDF) GetColumnNames() []string

func (*ToDF) GetInput

func (x *ToDF) GetInput() *Relation

func (*ToDF) ProtoMessage

func (*ToDF) ProtoMessage()

func (*ToDF) ProtoReflect

func (x *ToDF) ProtoReflect() protoreflect.Message

func (*ToDF) Reset

func (x *ToDF) Reset()

func (*ToDF) String

func (x *ToDF) String() string

type ToSchema

type ToSchema struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) The user provided schema.
	//
	// The Sever side will update the dataframe with this schema.
	Schema *DataType `protobuf:"bytes,2,opt,name=schema,proto3" json:"schema,omitempty"`
	// contains filtered or unexported fields
}

func (*ToSchema) Descriptor deprecated

func (*ToSchema) Descriptor() ([]byte, []int)

Deprecated: Use ToSchema.ProtoReflect.Descriptor instead.

func (*ToSchema) GetInput

func (x *ToSchema) GetInput() *Relation

func (*ToSchema) GetSchema

func (x *ToSchema) GetSchema() *DataType

func (*ToSchema) ProtoMessage

func (*ToSchema) ProtoMessage()

func (*ToSchema) ProtoReflect

func (x *ToSchema) ProtoReflect() protoreflect.Message

func (*ToSchema) Reset

func (x *ToSchema) Reset()

func (*ToSchema) String

func (x *ToSchema) String() string

type UncacheTable

type UncacheTable struct {

	// (Required)
	TableName string `protobuf:"bytes,1,opt,name=table_name,json=tableName,proto3" json:"table_name,omitempty"`
	// contains filtered or unexported fields
}

See `spark.catalog.uncacheTable`

func (*UncacheTable) Descriptor deprecated

func (*UncacheTable) Descriptor() ([]byte, []int)

Deprecated: Use UncacheTable.ProtoReflect.Descriptor instead.

func (*UncacheTable) GetTableName

func (x *UncacheTable) GetTableName() string

func (*UncacheTable) ProtoMessage

func (*UncacheTable) ProtoMessage()

func (*UncacheTable) ProtoReflect

func (x *UncacheTable) ProtoReflect() protoreflect.Message

func (*UncacheTable) Reset

func (x *UncacheTable) Reset()

func (*UncacheTable) String

func (x *UncacheTable) String() string

type UnimplementedSparkConnectServiceServer

type UnimplementedSparkConnectServiceServer struct {
}

UnimplementedSparkConnectServiceServer must be embedded to have forward compatible implementations.

func (UnimplementedSparkConnectServiceServer) AddArtifacts

func (UnimplementedSparkConnectServiceServer) AnalyzePlan

func (UnimplementedSparkConnectServiceServer) ArtifactStatus

func (UnimplementedSparkConnectServiceServer) Config

func (UnimplementedSparkConnectServiceServer) ExecutePlan

func (UnimplementedSparkConnectServiceServer) Interrupt

type Unknown

type Unknown struct {
	// contains filtered or unexported fields
}

Used for testing purposes only.

func (*Unknown) Descriptor deprecated

func (*Unknown) Descriptor() ([]byte, []int)

Deprecated: Use Unknown.ProtoReflect.Descriptor instead.

func (*Unknown) ProtoMessage

func (*Unknown) ProtoMessage()

func (*Unknown) ProtoReflect

func (x *Unknown) ProtoReflect() protoreflect.Message

func (*Unknown) Reset

func (x *Unknown) Reset()

func (*Unknown) String

func (x *Unknown) String() string

type Unpivot

type Unpivot struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) Id columns.
	Ids []*Expression `protobuf:"bytes,2,rep,name=ids,proto3" json:"ids,omitempty"`
	// (Optional) Value columns to unpivot.
	Values *Unpivot_Values `protobuf:"bytes,3,opt,name=values,proto3,oneof" json:"values,omitempty"`
	// (Required) Name of the variable column.
	VariableColumnName string `protobuf:"bytes,4,opt,name=variable_column_name,json=variableColumnName,proto3" json:"variable_column_name,omitempty"`
	// (Required) Name of the value column.
	ValueColumnName string `protobuf:"bytes,5,opt,name=value_column_name,json=valueColumnName,proto3" json:"value_column_name,omitempty"`
	// contains filtered or unexported fields
}

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

func (*Unpivot) Descriptor deprecated

func (*Unpivot) Descriptor() ([]byte, []int)

Deprecated: Use Unpivot.ProtoReflect.Descriptor instead.

func (*Unpivot) GetIds

func (x *Unpivot) GetIds() []*Expression

func (*Unpivot) GetInput

func (x *Unpivot) GetInput() *Relation

func (*Unpivot) GetValueColumnName

func (x *Unpivot) GetValueColumnName() string

func (*Unpivot) GetValues

func (x *Unpivot) GetValues() *Unpivot_Values

func (*Unpivot) GetVariableColumnName

func (x *Unpivot) GetVariableColumnName() string

func (*Unpivot) ProtoMessage

func (*Unpivot) ProtoMessage()

func (*Unpivot) ProtoReflect

func (x *Unpivot) ProtoReflect() protoreflect.Message

func (*Unpivot) Reset

func (x *Unpivot) Reset()

func (*Unpivot) String

func (x *Unpivot) String() string

type Unpivot_Values

type Unpivot_Values struct {
	Values []*Expression `protobuf:"bytes,1,rep,name=values,proto3" json:"values,omitempty"`
	// contains filtered or unexported fields
}

func (*Unpivot_Values) Descriptor deprecated

func (*Unpivot_Values) Descriptor() ([]byte, []int)

Deprecated: Use Unpivot_Values.ProtoReflect.Descriptor instead.

func (*Unpivot_Values) GetValues

func (x *Unpivot_Values) GetValues() []*Expression

func (*Unpivot_Values) ProtoMessage

func (*Unpivot_Values) ProtoMessage()

func (*Unpivot_Values) ProtoReflect

func (x *Unpivot_Values) ProtoReflect() protoreflect.Message

func (*Unpivot_Values) Reset

func (x *Unpivot_Values) Reset()

func (*Unpivot_Values) String

func (x *Unpivot_Values) String() string

type UnsafeSparkConnectServiceServer

type UnsafeSparkConnectServiceServer interface {
	// contains filtered or unexported methods
}

UnsafeSparkConnectServiceServer may be embedded to opt out of forward compatibility for this service. Use of this interface is not recommended, as added methods to SparkConnectServiceServer will result in compilation errors.

type UserContext

type UserContext struct {
	UserId   string `protobuf:"bytes,1,opt,name=user_id,json=userId,proto3" json:"user_id,omitempty"`
	UserName string `protobuf:"bytes,2,opt,name=user_name,json=userName,proto3" json:"user_name,omitempty"`
	// To extend the existing user context message that is used to identify incoming requests,
	// Spark Connect leverages the Any protobuf type that can be used to inject arbitrary other
	// messages into this message. Extensions are stored as a `repeated` type to be able to
	// handle multiple active extensions.
	Extensions []*anypb.Any `protobuf:"bytes,999,rep,name=extensions,proto3" json:"extensions,omitempty"`
	// contains filtered or unexported fields
}

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

func (*UserContext) Descriptor deprecated

func (*UserContext) Descriptor() ([]byte, []int)

Deprecated: Use UserContext.ProtoReflect.Descriptor instead.

func (*UserContext) GetExtensions

func (x *UserContext) GetExtensions() []*anypb.Any

func (*UserContext) GetUserId

func (x *UserContext) GetUserId() string

func (*UserContext) GetUserName

func (x *UserContext) GetUserName() string

func (*UserContext) ProtoMessage

func (*UserContext) ProtoMessage()

func (*UserContext) ProtoReflect

func (x *UserContext) ProtoReflect() protoreflect.Message

func (*UserContext) Reset

func (x *UserContext) Reset()

func (*UserContext) String

func (x *UserContext) String() string

type WithColumns

type WithColumns struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required)
	//
	// Given a column name, apply the corresponding expression on the column. If column
	// name exists in the input relation, then replace the column. If the column name
	// does not exist in the input relation, then adds it as a new column.
	//
	// Only one name part is expected from each Expression.Alias.
	//
	// An exception is thrown when duplicated names are present in the mapping.
	Aliases []*Expression_Alias `protobuf:"bytes,2,rep,name=aliases,proto3" json:"aliases,omitempty"`
	// contains filtered or unexported fields
}

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

func (*WithColumns) Descriptor deprecated

func (*WithColumns) Descriptor() ([]byte, []int)

Deprecated: Use WithColumns.ProtoReflect.Descriptor instead.

func (*WithColumns) GetAliases

func (x *WithColumns) GetAliases() []*Expression_Alias

func (*WithColumns) GetInput

func (x *WithColumns) GetInput() *Relation

func (*WithColumns) ProtoMessage

func (*WithColumns) ProtoMessage()

func (*WithColumns) ProtoReflect

func (x *WithColumns) ProtoReflect() protoreflect.Message

func (*WithColumns) Reset

func (x *WithColumns) Reset()

func (*WithColumns) String

func (x *WithColumns) String() string

type WithColumnsRenamed

type WithColumnsRenamed struct {

	// (Required) The input relation.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required)
	//
	// Renaming column names of input relation from A to B where A is the map key
	// and B is the map value. This is a no-op if schema doesn't contain any A. It
	// does not require that all input relation column names to present as keys.
	// duplicated B are not allowed.
	RenameColumnsMap map[string]string `` /* 199-byte string literal not displayed */
	// contains filtered or unexported fields
}

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

func (*WithColumnsRenamed) Descriptor deprecated

func (*WithColumnsRenamed) Descriptor() ([]byte, []int)

Deprecated: Use WithColumnsRenamed.ProtoReflect.Descriptor instead.

func (*WithColumnsRenamed) GetInput

func (x *WithColumnsRenamed) GetInput() *Relation

func (*WithColumnsRenamed) GetRenameColumnsMap

func (x *WithColumnsRenamed) GetRenameColumnsMap() map[string]string

func (*WithColumnsRenamed) ProtoMessage

func (*WithColumnsRenamed) ProtoMessage()

func (*WithColumnsRenamed) ProtoReflect

func (x *WithColumnsRenamed) ProtoReflect() protoreflect.Message

func (*WithColumnsRenamed) Reset

func (x *WithColumnsRenamed) Reset()

func (*WithColumnsRenamed) String

func (x *WithColumnsRenamed) String() string

type WithWatermark

type WithWatermark struct {

	// (Required) The input relation
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) Name of the column containing event time.
	EventTime string `protobuf:"bytes,2,opt,name=event_time,json=eventTime,proto3" json:"event_time,omitempty"`
	// (Required)
	DelayThreshold string `protobuf:"bytes,3,opt,name=delay_threshold,json=delayThreshold,proto3" json:"delay_threshold,omitempty"`
	// contains filtered or unexported fields
}

func (*WithWatermark) Descriptor deprecated

func (*WithWatermark) Descriptor() ([]byte, []int)

Deprecated: Use WithWatermark.ProtoReflect.Descriptor instead.

func (*WithWatermark) GetDelayThreshold

func (x *WithWatermark) GetDelayThreshold() string

func (*WithWatermark) GetEventTime

func (x *WithWatermark) GetEventTime() string

func (*WithWatermark) GetInput

func (x *WithWatermark) GetInput() *Relation

func (*WithWatermark) ProtoMessage

func (*WithWatermark) ProtoMessage()

func (*WithWatermark) ProtoReflect

func (x *WithWatermark) ProtoReflect() protoreflect.Message

func (*WithWatermark) Reset

func (x *WithWatermark) Reset()

func (*WithWatermark) String

func (x *WithWatermark) String() string

type WriteOperation

type WriteOperation struct {

	// (Required) The output of the `input` relation will be persisted according to the options.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Optional) Format value according to the Spark documentation. Examples are: text, parquet, delta.
	Source *string `protobuf:"bytes,2,opt,name=source,proto3,oneof" json:"source,omitempty"`
	// (Optional)
	//
	// The destination of the write operation can be either a path or a table.
	// If the destination is neither a path nor a table, such as jdbc and noop,
	// the `save_type` should not be set.
	//
	// Types that are assignable to SaveType:
	//
	//	*WriteOperation_Path
	//	*WriteOperation_Table
	SaveType isWriteOperation_SaveType `protobuf_oneof:"save_type"`
	// (Required) the save mode.
	Mode WriteOperation_SaveMode `protobuf:"varint,5,opt,name=mode,proto3,enum=spark.connect.WriteOperation_SaveMode" json:"mode,omitempty"`
	// (Optional) List of columns to sort the output by.
	SortColumnNames []string `protobuf:"bytes,6,rep,name=sort_column_names,json=sortColumnNames,proto3" json:"sort_column_names,omitempty"`
	// (Optional) List of columns for partitioning.
	PartitioningColumns []string `protobuf:"bytes,7,rep,name=partitioning_columns,json=partitioningColumns,proto3" json:"partitioning_columns,omitempty"`
	// (Optional) Bucketing specification. Bucketing must set the number of buckets and the columns
	// to bucket by.
	BucketBy *WriteOperation_BucketBy `protobuf:"bytes,8,opt,name=bucket_by,json=bucketBy,proto3" json:"bucket_by,omitempty"`
	// (Optional) A list of configuration options.
	Options map[string]string `` /* 155-byte string literal not displayed */
	// contains filtered or unexported fields
}

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

func (*WriteOperation) Descriptor deprecated

func (*WriteOperation) Descriptor() ([]byte, []int)

Deprecated: Use WriteOperation.ProtoReflect.Descriptor instead.

func (*WriteOperation) GetBucketBy

func (x *WriteOperation) GetBucketBy() *WriteOperation_BucketBy

func (*WriteOperation) GetInput

func (x *WriteOperation) GetInput() *Relation

func (*WriteOperation) GetMode

func (*WriteOperation) GetOptions

func (x *WriteOperation) GetOptions() map[string]string

func (*WriteOperation) GetPartitioningColumns

func (x *WriteOperation) GetPartitioningColumns() []string

func (*WriteOperation) GetPath

func (x *WriteOperation) GetPath() string

func (*WriteOperation) GetSaveType

func (m *WriteOperation) GetSaveType() isWriteOperation_SaveType

func (*WriteOperation) GetSortColumnNames

func (x *WriteOperation) GetSortColumnNames() []string

func (*WriteOperation) GetSource

func (x *WriteOperation) GetSource() string

func (*WriteOperation) GetTable

func (*WriteOperation) ProtoMessage

func (*WriteOperation) ProtoMessage()

func (*WriteOperation) ProtoReflect

func (x *WriteOperation) ProtoReflect() protoreflect.Message

func (*WriteOperation) Reset

func (x *WriteOperation) Reset()

func (*WriteOperation) String

func (x *WriteOperation) String() string

type WriteOperationV2

type WriteOperationV2 struct {

	// (Required) The output of the `input` relation will be persisted according to the options.
	Input *Relation `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	// (Required) The destination of the write operation must be either a path or a table.
	TableName string `protobuf:"bytes,2,opt,name=table_name,json=tableName,proto3" json:"table_name,omitempty"`
	// (Optional) A provider for the underlying output data source. Spark's default catalog supports
	// "parquet", "json", etc.
	Provider *string `protobuf:"bytes,3,opt,name=provider,proto3,oneof" json:"provider,omitempty"`
	// (Optional) List of columns for partitioning for output table created by `create`,
	// `createOrReplace`, or `replace`
	PartitioningColumns []*Expression `protobuf:"bytes,4,rep,name=partitioning_columns,json=partitioningColumns,proto3" json:"partitioning_columns,omitempty"`
	// (Optional) A list of configuration options.
	Options map[string]string `` /* 155-byte string literal not displayed */
	// (Optional) A list of table properties.
	TableProperties map[string]string `` /* 194-byte string literal not displayed */
	// (Required) Write mode.
	Mode WriteOperationV2_Mode `protobuf:"varint,7,opt,name=mode,proto3,enum=spark.connect.WriteOperationV2_Mode" json:"mode,omitempty"`
	// (Optional) A condition for overwrite saving mode
	OverwriteCondition *Expression `protobuf:"bytes,8,opt,name=overwrite_condition,json=overwriteCondition,proto3" json:"overwrite_condition,omitempty"`
	// contains filtered or unexported fields
}

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

func (*WriteOperationV2) Descriptor deprecated

func (*WriteOperationV2) Descriptor() ([]byte, []int)

Deprecated: Use WriteOperationV2.ProtoReflect.Descriptor instead.

func (*WriteOperationV2) GetInput

func (x *WriteOperationV2) GetInput() *Relation

func (*WriteOperationV2) GetMode

func (*WriteOperationV2) GetOptions

func (x *WriteOperationV2) GetOptions() map[string]string

func (*WriteOperationV2) GetOverwriteCondition

func (x *WriteOperationV2) GetOverwriteCondition() *Expression

func (*WriteOperationV2) GetPartitioningColumns

func (x *WriteOperationV2) GetPartitioningColumns() []*Expression

func (*WriteOperationV2) GetProvider

func (x *WriteOperationV2) GetProvider() string

func (*WriteOperationV2) GetTableName

func (x *WriteOperationV2) GetTableName() string

func (*WriteOperationV2) GetTableProperties

func (x *WriteOperationV2) GetTableProperties() map[string]string

func (*WriteOperationV2) ProtoMessage

func (*WriteOperationV2) ProtoMessage()

func (*WriteOperationV2) ProtoReflect

func (x *WriteOperationV2) ProtoReflect() protoreflect.Message

func (*WriteOperationV2) Reset

func (x *WriteOperationV2) Reset()

func (*WriteOperationV2) String

func (x *WriteOperationV2) String() string

type WriteOperationV2_Mode

type WriteOperationV2_Mode int32
const (
	WriteOperationV2_MODE_UNSPECIFIED          WriteOperationV2_Mode = 0
	WriteOperationV2_MODE_CREATE               WriteOperationV2_Mode = 1
	WriteOperationV2_MODE_OVERWRITE            WriteOperationV2_Mode = 2
	WriteOperationV2_MODE_OVERWRITE_PARTITIONS WriteOperationV2_Mode = 3
	WriteOperationV2_MODE_APPEND               WriteOperationV2_Mode = 4
	WriteOperationV2_MODE_REPLACE              WriteOperationV2_Mode = 5
	WriteOperationV2_MODE_CREATE_OR_REPLACE    WriteOperationV2_Mode = 6
)

func (WriteOperationV2_Mode) Descriptor

func (WriteOperationV2_Mode) Enum

func (WriteOperationV2_Mode) EnumDescriptor deprecated

func (WriteOperationV2_Mode) EnumDescriptor() ([]byte, []int)

Deprecated: Use WriteOperationV2_Mode.Descriptor instead.

func (WriteOperationV2_Mode) Number

func (WriteOperationV2_Mode) String

func (x WriteOperationV2_Mode) String() string

func (WriteOperationV2_Mode) Type

type WriteOperation_BucketBy

type WriteOperation_BucketBy struct {
	BucketColumnNames []string `protobuf:"bytes,1,rep,name=bucket_column_names,json=bucketColumnNames,proto3" json:"bucket_column_names,omitempty"`
	NumBuckets        int32    `protobuf:"varint,2,opt,name=num_buckets,json=numBuckets,proto3" json:"num_buckets,omitempty"`
	// contains filtered or unexported fields
}

func (*WriteOperation_BucketBy) Descriptor deprecated

func (*WriteOperation_BucketBy) Descriptor() ([]byte, []int)

Deprecated: Use WriteOperation_BucketBy.ProtoReflect.Descriptor instead.

func (*WriteOperation_BucketBy) GetBucketColumnNames

func (x *WriteOperation_BucketBy) GetBucketColumnNames() []string

func (*WriteOperation_BucketBy) GetNumBuckets

func (x *WriteOperation_BucketBy) GetNumBuckets() int32

func (*WriteOperation_BucketBy) ProtoMessage

func (*WriteOperation_BucketBy) ProtoMessage()

func (*WriteOperation_BucketBy) ProtoReflect

func (x *WriteOperation_BucketBy) ProtoReflect() protoreflect.Message

func (*WriteOperation_BucketBy) Reset

func (x *WriteOperation_BucketBy) Reset()

func (*WriteOperation_BucketBy) String

func (x *WriteOperation_BucketBy) String() string

type WriteOperation_Path

type WriteOperation_Path struct {
	Path string `protobuf:"bytes,3,opt,name=path,proto3,oneof"`
}

type WriteOperation_SaveMode

type WriteOperation_SaveMode int32
const (
	WriteOperation_SAVE_MODE_UNSPECIFIED     WriteOperation_SaveMode = 0
	WriteOperation_SAVE_MODE_APPEND          WriteOperation_SaveMode = 1
	WriteOperation_SAVE_MODE_OVERWRITE       WriteOperation_SaveMode = 2
	WriteOperation_SAVE_MODE_ERROR_IF_EXISTS WriteOperation_SaveMode = 3
	WriteOperation_SAVE_MODE_IGNORE          WriteOperation_SaveMode = 4
)

func (WriteOperation_SaveMode) Descriptor

func (WriteOperation_SaveMode) Enum

func (WriteOperation_SaveMode) EnumDescriptor deprecated

func (WriteOperation_SaveMode) EnumDescriptor() ([]byte, []int)

Deprecated: Use WriteOperation_SaveMode.Descriptor instead.

func (WriteOperation_SaveMode) Number

func (WriteOperation_SaveMode) String

func (x WriteOperation_SaveMode) String() string

func (WriteOperation_SaveMode) Type

type WriteOperation_SaveTable

type WriteOperation_SaveTable struct {

	// (Required) The table name.
	TableName string `protobuf:"bytes,1,opt,name=table_name,json=tableName,proto3" json:"table_name,omitempty"`
	// (Required) The method to be called to write to the table.
	SaveMethod WriteOperation_SaveTable_TableSaveMethod `` /* 152-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*WriteOperation_SaveTable) Descriptor deprecated

func (*WriteOperation_SaveTable) Descriptor() ([]byte, []int)

Deprecated: Use WriteOperation_SaveTable.ProtoReflect.Descriptor instead.

func (*WriteOperation_SaveTable) GetSaveMethod

func (*WriteOperation_SaveTable) GetTableName

func (x *WriteOperation_SaveTable) GetTableName() string

func (*WriteOperation_SaveTable) ProtoMessage

func (*WriteOperation_SaveTable) ProtoMessage()

func (*WriteOperation_SaveTable) ProtoReflect

func (x *WriteOperation_SaveTable) ProtoReflect() protoreflect.Message

func (*WriteOperation_SaveTable) Reset

func (x *WriteOperation_SaveTable) Reset()

func (*WriteOperation_SaveTable) String

func (x *WriteOperation_SaveTable) String() string

type WriteOperation_SaveTable_TableSaveMethod

type WriteOperation_SaveTable_TableSaveMethod int32
const (
	WriteOperation_SaveTable_TABLE_SAVE_METHOD_UNSPECIFIED   WriteOperation_SaveTable_TableSaveMethod = 0
	WriteOperation_SaveTable_TABLE_SAVE_METHOD_SAVE_AS_TABLE WriteOperation_SaveTable_TableSaveMethod = 1
	WriteOperation_SaveTable_TABLE_SAVE_METHOD_INSERT_INTO   WriteOperation_SaveTable_TableSaveMethod = 2
)

func (WriteOperation_SaveTable_TableSaveMethod) Descriptor

func (WriteOperation_SaveTable_TableSaveMethod) Enum

func (WriteOperation_SaveTable_TableSaveMethod) EnumDescriptor deprecated

func (WriteOperation_SaveTable_TableSaveMethod) EnumDescriptor() ([]byte, []int)

Deprecated: Use WriteOperation_SaveTable_TableSaveMethod.Descriptor instead.

func (WriteOperation_SaveTable_TableSaveMethod) Number

func (WriteOperation_SaveTable_TableSaveMethod) String

func (WriteOperation_SaveTable_TableSaveMethod) Type

type WriteOperation_Table

type WriteOperation_Table struct {
	Table *WriteOperation_SaveTable `protobuf:"bytes,4,opt,name=table,proto3,oneof"`
}

type WriteStreamOperationStart

type WriteStreamOperationStart struct {

	// (Required) The output of the `input` streaming relation will be written.
	Input                   *Relation         `protobuf:"bytes,1,opt,name=input,proto3" json:"input,omitempty"`
	Format                  string            `protobuf:"bytes,2,opt,name=format,proto3" json:"format,omitempty"`
	Options                 map[string]string `` /* 155-byte string literal not displayed */
	PartitioningColumnNames []string          `` /* 132-byte string literal not displayed */
	// Types that are assignable to Trigger:
	//
	//	*WriteStreamOperationStart_ProcessingTimeInterval
	//	*WriteStreamOperationStart_AvailableNow
	//	*WriteStreamOperationStart_Once
	//	*WriteStreamOperationStart_ContinuousCheckpointInterval
	Trigger    isWriteStreamOperationStart_Trigger `protobuf_oneof:"trigger"`
	OutputMode string                              `protobuf:"bytes,9,opt,name=output_mode,json=outputMode,proto3" json:"output_mode,omitempty"`
	QueryName  string                              `protobuf:"bytes,10,opt,name=query_name,json=queryName,proto3" json:"query_name,omitempty"`
	// The destination is optional. When set, it can be a path or a table name.
	//
	// Types that are assignable to SinkDestination:
	//
	//	*WriteStreamOperationStart_Path
	//	*WriteStreamOperationStart_TableName
	SinkDestination isWriteStreamOperationStart_SinkDestination `protobuf_oneof:"sink_destination"`
	ForeachWriter   *StreamingForeachWriter                     `protobuf:"bytes,13,opt,name=foreach_writer,json=foreachWriter,proto3" json:"foreach_writer,omitempty"`
	// contains filtered or unexported fields
}

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

func (*WriteStreamOperationStart) Descriptor deprecated

func (*WriteStreamOperationStart) Descriptor() ([]byte, []int)

Deprecated: Use WriteStreamOperationStart.ProtoReflect.Descriptor instead.

func (*WriteStreamOperationStart) GetAvailableNow

func (x *WriteStreamOperationStart) GetAvailableNow() bool

func (*WriteStreamOperationStart) GetContinuousCheckpointInterval

func (x *WriteStreamOperationStart) GetContinuousCheckpointInterval() string

func (*WriteStreamOperationStart) GetForeachWriter

func (x *WriteStreamOperationStart) GetForeachWriter() *StreamingForeachWriter

func (*WriteStreamOperationStart) GetFormat

func (x *WriteStreamOperationStart) GetFormat() string

func (*WriteStreamOperationStart) GetInput

func (x *WriteStreamOperationStart) GetInput() *Relation

func (*WriteStreamOperationStart) GetOnce

func (x *WriteStreamOperationStart) GetOnce() bool

func (*WriteStreamOperationStart) GetOptions

func (x *WriteStreamOperationStart) GetOptions() map[string]string

func (*WriteStreamOperationStart) GetOutputMode

func (x *WriteStreamOperationStart) GetOutputMode() string

func (*WriteStreamOperationStart) GetPartitioningColumnNames

func (x *WriteStreamOperationStart) GetPartitioningColumnNames() []string

func (*WriteStreamOperationStart) GetPath

func (x *WriteStreamOperationStart) GetPath() string

func (*WriteStreamOperationStart) GetProcessingTimeInterval

func (x *WriteStreamOperationStart) GetProcessingTimeInterval() string

func (*WriteStreamOperationStart) GetQueryName

func (x *WriteStreamOperationStart) GetQueryName() string

func (*WriteStreamOperationStart) GetSinkDestination

func (m *WriteStreamOperationStart) GetSinkDestination() isWriteStreamOperationStart_SinkDestination

func (*WriteStreamOperationStart) GetTableName

func (x *WriteStreamOperationStart) GetTableName() string

func (*WriteStreamOperationStart) GetTrigger

func (m *WriteStreamOperationStart) GetTrigger() isWriteStreamOperationStart_Trigger

func (*WriteStreamOperationStart) ProtoMessage

func (*WriteStreamOperationStart) ProtoMessage()

func (*WriteStreamOperationStart) ProtoReflect

func (*WriteStreamOperationStart) Reset

func (x *WriteStreamOperationStart) Reset()

func (*WriteStreamOperationStart) String

func (x *WriteStreamOperationStart) String() string

type WriteStreamOperationStartResult

type WriteStreamOperationStartResult struct {

	// (Required) Query instance. See `StreamingQueryInstanceId`.
	QueryId *StreamingQueryInstanceId `protobuf:"bytes,1,opt,name=query_id,json=queryId,proto3" json:"query_id,omitempty"`
	// An optional query name.
	Name string `protobuf:"bytes,2,opt,name=name,proto3" json:"name,omitempty"`
	// contains filtered or unexported fields
}

func (*WriteStreamOperationStartResult) Descriptor deprecated

func (*WriteStreamOperationStartResult) Descriptor() ([]byte, []int)

Deprecated: Use WriteStreamOperationStartResult.ProtoReflect.Descriptor instead.

func (*WriteStreamOperationStartResult) GetName

func (*WriteStreamOperationStartResult) GetQueryId

func (*WriteStreamOperationStartResult) ProtoMessage

func (*WriteStreamOperationStartResult) ProtoMessage()

func (*WriteStreamOperationStartResult) ProtoReflect

func (*WriteStreamOperationStartResult) Reset

func (*WriteStreamOperationStartResult) String

type WriteStreamOperationStart_AvailableNow

type WriteStreamOperationStart_AvailableNow struct {
	AvailableNow bool `protobuf:"varint,6,opt,name=available_now,json=availableNow,proto3,oneof"`
}

type WriteStreamOperationStart_ContinuousCheckpointInterval

type WriteStreamOperationStart_ContinuousCheckpointInterval struct {
	ContinuousCheckpointInterval string `protobuf:"bytes,8,opt,name=continuous_checkpoint_interval,json=continuousCheckpointInterval,proto3,oneof"`
}

type WriteStreamOperationStart_Once

type WriteStreamOperationStart_Once struct {
	Once bool `protobuf:"varint,7,opt,name=once,proto3,oneof"`
}

type WriteStreamOperationStart_Path

type WriteStreamOperationStart_Path struct {
	Path string `protobuf:"bytes,11,opt,name=path,proto3,oneof"`
}

type WriteStreamOperationStart_ProcessingTimeInterval

type WriteStreamOperationStart_ProcessingTimeInterval struct {
	ProcessingTimeInterval string `protobuf:"bytes,5,opt,name=processing_time_interval,json=processingTimeInterval,proto3,oneof"`
}

type WriteStreamOperationStart_TableName

type WriteStreamOperationStart_TableName struct {
	TableName string `protobuf:"bytes,12,opt,name=table_name,json=tableName,proto3,oneof"`
}

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL