Packages

t

org.apache.spark.connect.proto

ExecutePlanResponseOrBuilder

trait ExecutePlanResponseOrBuilder extends MessageOrBuilder

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

Abstract Value Members

  1. abstract def findInitializationErrors(): List[String]
    Definition Classes
    MessageOrBuilder
  2. abstract def getAllFields(): Map[FieldDescriptor, AnyRef]
    Definition Classes
    MessageOrBuilder
  3. abstract def getArrowBatch(): ArrowBatch

    .spark.connect.ExecutePlanResponse.ArrowBatch arrow_batch = 2;

    .spark.connect.ExecutePlanResponse.ArrowBatch arrow_batch = 2;

    returns

    The arrowBatch.

  4. abstract def getArrowBatchOrBuilder(): ArrowBatchOrBuilder

    .spark.connect.ExecutePlanResponse.ArrowBatch arrow_batch = 2;

  5. abstract def getCheckpointCommandResult(): CheckpointCommandResult

    Response for command that checkpoints a DataFrame.
    

    Response for command that checkpoints a DataFrame.
    

    .spark.connect.CheckpointCommandResult checkpoint_command_result = 19;

    returns

    The checkpointCommandResult.

  6. abstract def getCheckpointCommandResultOrBuilder(): CheckpointCommandResultOrBuilder

    Response for command that checkpoints a DataFrame.
    

    Response for command that checkpoints a DataFrame.
    

    .spark.connect.CheckpointCommandResult checkpoint_command_result = 19;

  7. abstract def getCreateResourceProfileCommandResult(): CreateResourceProfileCommandResult

    Response for command that creates ResourceProfile.
    

    Response for command that creates ResourceProfile.
    

    .spark.connect.CreateResourceProfileCommandResult create_resource_profile_command_result = 17;

    returns

    The createResourceProfileCommandResult.

  8. abstract def getCreateResourceProfileCommandResultOrBuilder(): CreateResourceProfileCommandResultOrBuilder

    Response for command that creates ResourceProfile.
    

    Response for command that creates ResourceProfile.
    

    .spark.connect.CreateResourceProfileCommandResult create_resource_profile_command_result = 17;

  9. abstract def getDefaultInstanceForType(): Message
    Definition Classes
    MessageOrBuilder → MessageLiteOrBuilder
  10. abstract def getDescriptorForType(): Descriptor
    Definition Classes
    MessageOrBuilder
  11. abstract def getExecutionProgress(): ExecutionProgress

    (Optional) Intermediate query progress reports.
    

    (Optional) Intermediate query progress reports.
    

    .spark.connect.ExecutePlanResponse.ExecutionProgress execution_progress = 18;

    returns

    The executionProgress.

  12. abstract def getExecutionProgressOrBuilder(): ExecutionProgressOrBuilder

    (Optional) Intermediate query progress reports.
    

    (Optional) Intermediate query progress reports.
    

    .spark.connect.ExecutePlanResponse.ExecutionProgress execution_progress = 18;

  13. abstract def getExtension(): Any

    Support arbitrary result objects.
    

    Support arbitrary result objects.
    

    .google.protobuf.Any extension = 999;

    returns

    The extension.

  14. abstract def getExtensionOrBuilder(): AnyOrBuilder

    Support arbitrary result objects.
    

    Support arbitrary result objects.
    

    .google.protobuf.Any extension = 999;

  15. abstract def getField(field: FieldDescriptor): AnyRef
    Definition Classes
    MessageOrBuilder
  16. abstract def getGetResourcesCommandResult(): GetResourcesCommandResult

    Response for 'SparkContext.resources'.
    

    Response for 'SparkContext.resources'.
    

    .spark.connect.GetResourcesCommandResult get_resources_command_result = 10;

    returns

    The getResourcesCommandResult.

  17. abstract def getGetResourcesCommandResultOrBuilder(): GetResourcesCommandResultOrBuilder

    Response for 'SparkContext.resources'.
    

    Response for 'SparkContext.resources'.
    

    .spark.connect.GetResourcesCommandResult get_resources_command_result = 10;

  18. abstract def getInitializationErrorString(): String
    Definition Classes
    MessageOrBuilder
  19. abstract def getMetrics(): Metrics

    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 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.
    

    .spark.connect.ExecutePlanResponse.Metrics metrics = 4;

    returns

    The metrics.

  20. abstract def getMetricsOrBuilder(): MetricsOrBuilder

    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 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.
    

    .spark.connect.ExecutePlanResponse.Metrics metrics = 4;

  21. abstract def getMlCommandResult(): MlCommandResult

    ML command response
    

    ML command response
    

    .spark.connect.MlCommandResult ml_command_result = 20;

    returns

    The mlCommandResult.

  22. abstract def getMlCommandResultOrBuilder(): MlCommandResultOrBuilder

    ML command response
    

    ML command response
    

    .spark.connect.MlCommandResult ml_command_result = 20;

  23. abstract def getObservedMetrics(index: Int): ObservedMetrics

    The metrics observed during the execution of the query plan.
    

    The metrics observed during the execution of the query plan.
    

    repeated .spark.connect.ExecutePlanResponse.ObservedMetrics observed_metrics = 6;

  24. abstract def getObservedMetricsCount(): Int

    The metrics observed during the execution of the query plan.
    

    The metrics observed during the execution of the query plan.
    

    repeated .spark.connect.ExecutePlanResponse.ObservedMetrics observed_metrics = 6;

  25. abstract def getObservedMetricsList(): List[ObservedMetrics]

    The metrics observed during the execution of the query plan.
    

    The metrics observed during the execution of the query plan.
    

    repeated .spark.connect.ExecutePlanResponse.ObservedMetrics observed_metrics = 6;

  26. abstract def getObservedMetricsOrBuilder(index: Int): ObservedMetricsOrBuilder

    The metrics observed during the execution of the query plan.
    

    The metrics observed during the execution of the query plan.
    

    repeated .spark.connect.ExecutePlanResponse.ObservedMetrics observed_metrics = 6;

  27. abstract def getObservedMetricsOrBuilderList(): List[_ <: ObservedMetricsOrBuilder]

    The metrics observed during the execution of the query plan.
    

    The metrics observed during the execution of the query plan.
    

    repeated .spark.connect.ExecutePlanResponse.ObservedMetrics observed_metrics = 6;

  28. abstract def getOneofFieldDescriptor(oneof: OneofDescriptor): FieldDescriptor
    Definition Classes
    MessageOrBuilder
  29. abstract def getOperationId(): String

    Identifies the ExecutePlan execution.
    If set by the client in ExecutePlanRequest.operationId, that value is returned.
    Otherwise generated by the server.
    It is an UUID string of the format `00112233-4455-6677-8899-aabbccddeeff`
    

    Identifies the ExecutePlan execution.
    If set by the client in ExecutePlanRequest.operationId, that value is returned.
    Otherwise generated by the server.
    It is an UUID string of the format `00112233-4455-6677-8899-aabbccddeeff`
    

    string operation_id = 12;

    returns

    The operationId.

  30. abstract def getOperationIdBytes(): ByteString

    Identifies the ExecutePlan execution.
    If set by the client in ExecutePlanRequest.operationId, that value is returned.
    Otherwise generated by the server.
    It is an UUID string of the format `00112233-4455-6677-8899-aabbccddeeff`
    

    Identifies the ExecutePlan execution.
    If set by the client in ExecutePlanRequest.operationId, that value is returned.
    Otherwise generated by the server.
    It is an UUID string of the format `00112233-4455-6677-8899-aabbccddeeff`
    

    string operation_id = 12;

    returns

    The bytes for operationId.

  31. abstract def getRepeatedField(field: FieldDescriptor, index: Int): AnyRef
    Definition Classes
    MessageOrBuilder
  32. abstract def getRepeatedFieldCount(field: FieldDescriptor): Int
    Definition Classes
    MessageOrBuilder
  33. abstract def getResponseId(): String

    Identified the response in the stream.
    The id is an UUID string of the format `00112233-4455-6677-8899-aabbccddeeff`
    

    Identified the response in the stream.
    The id is an UUID string of the format `00112233-4455-6677-8899-aabbccddeeff`
    

    string response_id = 13;

    returns

    The responseId.

  34. abstract def getResponseIdBytes(): ByteString

    Identified the response in the stream.
    The id is an UUID string of the format `00112233-4455-6677-8899-aabbccddeeff`
    

    Identified the response in the stream.
    The id is an UUID string of the format `00112233-4455-6677-8899-aabbccddeeff`
    

    string response_id = 13;

    returns

    The bytes for responseId.

  35. abstract def getResponseTypeCase(): ResponseTypeCase
  36. abstract def getResultComplete(): ResultComplete

    Response type informing if the stream is complete in reattachable execution.
    

    Response type informing if the stream is complete in reattachable execution.
    

    .spark.connect.ExecutePlanResponse.ResultComplete result_complete = 14;

    returns

    The resultComplete.

  37. abstract def getResultCompleteOrBuilder(): ResultCompleteOrBuilder

    Response type informing if the stream is complete in reattachable execution.
    

    Response type informing if the stream is complete in reattachable execution.
    

    .spark.connect.ExecutePlanResponse.ResultComplete result_complete = 14;

  38. abstract def getSchema(): DataType

    (Optional) The Spark schema. This field is available when `collect` is called.
    

    (Optional) The Spark schema. This field is available when `collect` is called.
    

    .spark.connect.DataType schema = 7;

    returns

    The schema.

  39. abstract def getSchemaOrBuilder(): DataTypeOrBuilder

    (Optional) The Spark schema. This field is available when `collect` is called.
    

    (Optional) The Spark schema. This field is available when `collect` is called.
    

    .spark.connect.DataType schema = 7;

  40. abstract def getServerSideSessionId(): String

    Server-side generated idempotency key that the client can use to assert that the server side
    session has not changed.
    

    Server-side generated idempotency key that the client can use to assert that the server side
    session has not changed.
    

    string server_side_session_id = 15;

    returns

    The serverSideSessionId.

  41. abstract def getServerSideSessionIdBytes(): ByteString

    Server-side generated idempotency key that the client can use to assert that the server side
    session has not changed.
    

    Server-side generated idempotency key that the client can use to assert that the server side
    session has not changed.
    

    string server_side_session_id = 15;

    returns

    The bytes for serverSideSessionId.

  42. abstract def getSessionId(): String

    string session_id = 1;

    string session_id = 1;

    returns

    The sessionId.

  43. abstract def getSessionIdBytes(): ByteString

    string session_id = 1;

    string session_id = 1;

    returns

    The bytes for sessionId.

  44. abstract def getSqlCommandResult(): SqlCommandResult

    Special case for executing SQL commands.
    

    Special case for executing SQL commands.
    

    .spark.connect.ExecutePlanResponse.SqlCommandResult sql_command_result = 5;

    returns

    The sqlCommandResult.

  45. abstract def getSqlCommandResultOrBuilder(): SqlCommandResultOrBuilder

    Special case for executing SQL commands.
    

    Special case for executing SQL commands.
    

    .spark.connect.ExecutePlanResponse.SqlCommandResult sql_command_result = 5;

  46. abstract def getStreamingQueryCommandResult(): StreamingQueryCommandResult

    Response for commands on a streaming query.
    

    Response for commands on a streaming query.
    

    .spark.connect.StreamingQueryCommandResult streaming_query_command_result = 9;

    returns

    The streamingQueryCommandResult.

  47. abstract def getStreamingQueryCommandResultOrBuilder(): StreamingQueryCommandResultOrBuilder

    Response for commands on a streaming query.
    

    Response for commands on a streaming query.
    

    .spark.connect.StreamingQueryCommandResult streaming_query_command_result = 9;

  48. abstract def getStreamingQueryListenerEventsResult(): StreamingQueryListenerEventsResult

    Response for commands on the client side streaming query listener.
    

    Response for commands on the client side streaming query listener.
    

    .spark.connect.StreamingQueryListenerEventsResult streaming_query_listener_events_result = 16;

    returns

    The streamingQueryListenerEventsResult.

  49. abstract def getStreamingQueryListenerEventsResultOrBuilder(): StreamingQueryListenerEventsResultOrBuilder

    Response for commands on the client side streaming query listener.
    

    Response for commands on the client side streaming query listener.
    

    .spark.connect.StreamingQueryListenerEventsResult streaming_query_listener_events_result = 16;

  50. abstract def getStreamingQueryManagerCommandResult(): StreamingQueryManagerCommandResult

    Response for commands on the streaming query manager.
    

    Response for commands on the streaming query manager.
    

    .spark.connect.StreamingQueryManagerCommandResult streaming_query_manager_command_result = 11;

    returns

    The streamingQueryManagerCommandResult.

  51. abstract def getStreamingQueryManagerCommandResultOrBuilder(): StreamingQueryManagerCommandResultOrBuilder

    Response for commands on the streaming query manager.
    

    Response for commands on the streaming query manager.
    

    .spark.connect.StreamingQueryManagerCommandResult streaming_query_manager_command_result = 11;

  52. abstract def getUnknownFields(): UnknownFieldSet
    Definition Classes
    MessageOrBuilder
  53. abstract def getWriteStreamOperationStartResult(): WriteStreamOperationStartResult

    Response for a streaming query.
    

    Response for a streaming query.
    

    .spark.connect.WriteStreamOperationStartResult write_stream_operation_start_result = 8;

    returns

    The writeStreamOperationStartResult.

  54. abstract def getWriteStreamOperationStartResultOrBuilder(): WriteStreamOperationStartResultOrBuilder

    Response for a streaming query.
    

    Response for a streaming query.
    

    .spark.connect.WriteStreamOperationStartResult write_stream_operation_start_result = 8;

  55. abstract def hasArrowBatch(): Boolean

    .spark.connect.ExecutePlanResponse.ArrowBatch arrow_batch = 2;

    .spark.connect.ExecutePlanResponse.ArrowBatch arrow_batch = 2;

    returns

    Whether the arrowBatch field is set.

  56. abstract def hasCheckpointCommandResult(): Boolean

    Response for command that checkpoints a DataFrame.
    

    Response for command that checkpoints a DataFrame.
    

    .spark.connect.CheckpointCommandResult checkpoint_command_result = 19;

    returns

    Whether the checkpointCommandResult field is set.

  57. abstract def hasCreateResourceProfileCommandResult(): Boolean

    Response for command that creates ResourceProfile.
    

    Response for command that creates ResourceProfile.
    

    .spark.connect.CreateResourceProfileCommandResult create_resource_profile_command_result = 17;

    returns

    Whether the createResourceProfileCommandResult field is set.

  58. abstract def hasExecutionProgress(): Boolean

    (Optional) Intermediate query progress reports.
    

    (Optional) Intermediate query progress reports.
    

    .spark.connect.ExecutePlanResponse.ExecutionProgress execution_progress = 18;

    returns

    Whether the executionProgress field is set.

  59. abstract def hasExtension(): Boolean

    Support arbitrary result objects.
    

    Support arbitrary result objects.
    

    .google.protobuf.Any extension = 999;

    returns

    Whether the extension field is set.

  60. abstract def hasField(field: FieldDescriptor): Boolean
    Definition Classes
    MessageOrBuilder
  61. abstract def hasGetResourcesCommandResult(): Boolean

    Response for 'SparkContext.resources'.
    

    Response for 'SparkContext.resources'.
    

    .spark.connect.GetResourcesCommandResult get_resources_command_result = 10;

    returns

    Whether the getResourcesCommandResult field is set.

  62. abstract def hasMetrics(): Boolean

    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 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.
    

    .spark.connect.ExecutePlanResponse.Metrics metrics = 4;

    returns

    Whether the metrics field is set.

  63. abstract def hasMlCommandResult(): Boolean

    ML command response
    

    ML command response
    

    .spark.connect.MlCommandResult ml_command_result = 20;

    returns

    Whether the mlCommandResult field is set.

  64. abstract def hasOneof(oneof: OneofDescriptor): Boolean
    Definition Classes
    MessageOrBuilder
  65. abstract def hasResultComplete(): Boolean

    Response type informing if the stream is complete in reattachable execution.
    

    Response type informing if the stream is complete in reattachable execution.
    

    .spark.connect.ExecutePlanResponse.ResultComplete result_complete = 14;

    returns

    Whether the resultComplete field is set.

  66. abstract def hasSchema(): Boolean

    (Optional) The Spark schema. This field is available when `collect` is called.
    

    (Optional) The Spark schema. This field is available when `collect` is called.
    

    .spark.connect.DataType schema = 7;

    returns

    Whether the schema field is set.

  67. abstract def hasSqlCommandResult(): Boolean

    Special case for executing SQL commands.
    

    Special case for executing SQL commands.
    

    .spark.connect.ExecutePlanResponse.SqlCommandResult sql_command_result = 5;

    returns

    Whether the sqlCommandResult field is set.

  68. abstract def hasStreamingQueryCommandResult(): Boolean

    Response for commands on a streaming query.
    

    Response for commands on a streaming query.
    

    .spark.connect.StreamingQueryCommandResult streaming_query_command_result = 9;

    returns

    Whether the streamingQueryCommandResult field is set.

  69. abstract def hasStreamingQueryListenerEventsResult(): Boolean

    Response for commands on the client side streaming query listener.
    

    Response for commands on the client side streaming query listener.
    

    .spark.connect.StreamingQueryListenerEventsResult streaming_query_listener_events_result = 16;

    returns

    Whether the streamingQueryListenerEventsResult field is set.

  70. abstract def hasStreamingQueryManagerCommandResult(): Boolean

    Response for commands on the streaming query manager.
    

    Response for commands on the streaming query manager.
    

    .spark.connect.StreamingQueryManagerCommandResult streaming_query_manager_command_result = 11;

    returns

    Whether the streamingQueryManagerCommandResult field is set.

  71. abstract def hasWriteStreamOperationStartResult(): Boolean

    Response for a streaming query.
    

    Response for a streaming query.
    

    .spark.connect.WriteStreamOperationStartResult write_stream_operation_start_result = 8;

    returns

    Whether the writeStreamOperationStartResult field is set.

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

Concrete Value Members

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

Deprecated Value Members

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

    (Since version 9)

Inherited from MessageOrBuilder

Inherited from MessageLiteOrBuilder

Inherited from AnyRef

Inherited from Any

Ungrouped