Packages

t

org.apache.spark.connect.proto

WriteStreamOperationStartOrBuilder

trait WriteStreamOperationStartOrBuilder extends MessageOrBuilder

Linear Supertypes
MessageOrBuilder, MessageLiteOrBuilder, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. WriteStreamOperationStartOrBuilder
  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 containsOptions(key: String): Boolean

    map<string, string> options = 3;

  2. abstract def findInitializationErrors(): List[String]
    Definition Classes
    MessageOrBuilder
  3. abstract def getAllFields(): Map[FieldDescriptor, AnyRef]
    Definition Classes
    MessageOrBuilder
  4. abstract def getAvailableNow(): Boolean

    bool available_now = 6;

    bool available_now = 6;

    returns

    The availableNow.

  5. abstract def getClusteringColumnNames(index: Int): String

    (Optional) Columns used for clustering the table.
    

    (Optional) Columns used for clustering the table.
    

    repeated string clustering_column_names = 15;

    index

    The index of the element to return.

    returns

    The clusteringColumnNames at the given index.

  6. abstract def getClusteringColumnNamesBytes(index: Int): ByteString

    (Optional) Columns used for clustering the table.
    

    (Optional) Columns used for clustering the table.
    

    repeated string clustering_column_names = 15;

    index

    The index of the value to return.

    returns

    The bytes of the clusteringColumnNames at the given index.

  7. abstract def getClusteringColumnNamesCount(): Int

    (Optional) Columns used for clustering the table.
    

    (Optional) Columns used for clustering the table.
    

    repeated string clustering_column_names = 15;

    returns

    The count of clusteringColumnNames.

  8. abstract def getClusteringColumnNamesList(): List[String]

    (Optional) Columns used for clustering the table.
    

    (Optional) Columns used for clustering the table.
    

    repeated string clustering_column_names = 15;

    returns

    A list containing the clusteringColumnNames.

  9. abstract def getContinuousCheckpointInterval(): String

    string continuous_checkpoint_interval = 8;

    string continuous_checkpoint_interval = 8;

    returns

    The continuousCheckpointInterval.

  10. abstract def getContinuousCheckpointIntervalBytes(): ByteString

    string continuous_checkpoint_interval = 8;

    string continuous_checkpoint_interval = 8;

    returns

    The bytes for continuousCheckpointInterval.

  11. abstract def getDefaultInstanceForType(): Message
    Definition Classes
    MessageOrBuilder → MessageLiteOrBuilder
  12. abstract def getDescriptorForType(): Descriptor
    Definition Classes
    MessageOrBuilder
  13. abstract def getField(field: FieldDescriptor): AnyRef
    Definition Classes
    MessageOrBuilder
  14. abstract def getForeachBatch(): StreamingForeachFunction

    .spark.connect.StreamingForeachFunction foreach_batch = 14;

    .spark.connect.StreamingForeachFunction foreach_batch = 14;

    returns

    The foreachBatch.

  15. abstract def getForeachBatchOrBuilder(): StreamingForeachFunctionOrBuilder

    .spark.connect.StreamingForeachFunction foreach_batch = 14;

  16. abstract def getForeachWriter(): StreamingForeachFunction

    .spark.connect.StreamingForeachFunction foreach_writer = 13;

    .spark.connect.StreamingForeachFunction foreach_writer = 13;

    returns

    The foreachWriter.

  17. abstract def getForeachWriterOrBuilder(): StreamingForeachFunctionOrBuilder

    .spark.connect.StreamingForeachFunction foreach_writer = 13;

  18. abstract def getFormat(): String

    string format = 2;

    string format = 2;

    returns

    The format.

  19. abstract def getFormatBytes(): ByteString

    string format = 2;

    string format = 2;

    returns

    The bytes for format.

  20. abstract def getInitializationErrorString(): String
    Definition Classes
    MessageOrBuilder
  21. abstract def getInput(): Relation

    (Required) The output of the `input` streaming relation will be written.
    

    (Required) The output of the `input` streaming relation will be written.
    

    .spark.connect.Relation input = 1;

    returns

    The input.

  22. abstract def getInputOrBuilder(): RelationOrBuilder

    (Required) The output of the `input` streaming relation will be written.
    

    (Required) The output of the `input` streaming relation will be written.
    

    .spark.connect.Relation input = 1;

  23. abstract def getOnce(): Boolean

    bool once = 7;

    bool once = 7;

    returns

    The once.

  24. abstract def getOneofFieldDescriptor(oneof: OneofDescriptor): FieldDescriptor
    Definition Classes
    MessageOrBuilder
  25. abstract def getOptionsCount(): Int

    map<string, string> options = 3;

  26. abstract def getOptionsMap(): Map[String, String]

    map<string, string> options = 3;

  27. abstract def getOptionsOrDefault(key: String, defaultValue: String): String

    map<string, string> options = 3;

  28. abstract def getOptionsOrThrow(key: String): String

    map<string, string> options = 3;

  29. abstract def getOutputMode(): String

    string output_mode = 9;

    string output_mode = 9;

    returns

    The outputMode.

  30. abstract def getOutputModeBytes(): ByteString

    string output_mode = 9;

    string output_mode = 9;

    returns

    The bytes for outputMode.

  31. abstract def getPartitioningColumnNames(index: Int): String

    repeated string partitioning_column_names = 4;

    repeated string partitioning_column_names = 4;

    index

    The index of the element to return.

    returns

    The partitioningColumnNames at the given index.

  32. abstract def getPartitioningColumnNamesBytes(index: Int): ByteString

    repeated string partitioning_column_names = 4;

    repeated string partitioning_column_names = 4;

    index

    The index of the value to return.

    returns

    The bytes of the partitioningColumnNames at the given index.

  33. abstract def getPartitioningColumnNamesCount(): Int

    repeated string partitioning_column_names = 4;

    repeated string partitioning_column_names = 4;

    returns

    The count of partitioningColumnNames.

  34. abstract def getPartitioningColumnNamesList(): List[String]

    repeated string partitioning_column_names = 4;

    repeated string partitioning_column_names = 4;

    returns

    A list containing the partitioningColumnNames.

  35. abstract def getPath(): String

    string path = 11;

    string path = 11;

    returns

    The path.

  36. abstract def getPathBytes(): ByteString

    string path = 11;

    string path = 11;

    returns

    The bytes for path.

  37. abstract def getProcessingTimeInterval(): String

    string processing_time_interval = 5;

    string processing_time_interval = 5;

    returns

    The processingTimeInterval.

  38. abstract def getProcessingTimeIntervalBytes(): ByteString

    string processing_time_interval = 5;

    string processing_time_interval = 5;

    returns

    The bytes for processingTimeInterval.

  39. abstract def getQueryName(): String

    string query_name = 10;

    string query_name = 10;

    returns

    The queryName.

  40. abstract def getQueryNameBytes(): ByteString

    string query_name = 10;

    string query_name = 10;

    returns

    The bytes for queryName.

  41. abstract def getRepeatedField(field: FieldDescriptor, index: Int): AnyRef
    Definition Classes
    MessageOrBuilder
  42. abstract def getRepeatedFieldCount(field: FieldDescriptor): Int
    Definition Classes
    MessageOrBuilder
  43. abstract def getSinkDestinationCase(): SinkDestinationCase
  44. abstract def getTableName(): String

    string table_name = 12;

    string table_name = 12;

    returns

    The tableName.

  45. abstract def getTableNameBytes(): ByteString

    string table_name = 12;

    string table_name = 12;

    returns

    The bytes for tableName.

  46. abstract def getTriggerCase(): TriggerCase
  47. abstract def getUnknownFields(): UnknownFieldSet
    Definition Classes
    MessageOrBuilder
  48. abstract def hasAvailableNow(): Boolean

    bool available_now = 6;

    bool available_now = 6;

    returns

    Whether the availableNow field is set.

  49. abstract def hasContinuousCheckpointInterval(): Boolean

    string continuous_checkpoint_interval = 8;

    string continuous_checkpoint_interval = 8;

    returns

    Whether the continuousCheckpointInterval field is set.

  50. abstract def hasField(field: FieldDescriptor): Boolean
    Definition Classes
    MessageOrBuilder
  51. abstract def hasForeachBatch(): Boolean

    .spark.connect.StreamingForeachFunction foreach_batch = 14;

    .spark.connect.StreamingForeachFunction foreach_batch = 14;

    returns

    Whether the foreachBatch field is set.

  52. abstract def hasForeachWriter(): Boolean

    .spark.connect.StreamingForeachFunction foreach_writer = 13;

    .spark.connect.StreamingForeachFunction foreach_writer = 13;

    returns

    Whether the foreachWriter field is set.

  53. abstract def hasInput(): Boolean

    (Required) The output of the `input` streaming relation will be written.
    

    (Required) The output of the `input` streaming relation will be written.
    

    .spark.connect.Relation input = 1;

    returns

    Whether the input field is set.

  54. abstract def hasOnce(): Boolean

    bool once = 7;

    bool once = 7;

    returns

    Whether the once field is set.

  55. abstract def hasOneof(oneof: OneofDescriptor): Boolean
    Definition Classes
    MessageOrBuilder
  56. abstract def hasPath(): Boolean

    string path = 11;

    string path = 11;

    returns

    Whether the path field is set.

  57. abstract def hasProcessingTimeInterval(): Boolean

    string processing_time_interval = 5;

    string processing_time_interval = 5;

    returns

    Whether the processingTimeInterval field is set.

  58. abstract def hasTableName(): Boolean

    string table_name = 12;

    string table_name = 12;

    returns

    Whether the tableName field is set.

  59. abstract def isInitialized(): Boolean
    Definition Classes
    MessageLiteOrBuilder
  60. abstract def getOptions(): Map[String, String]

    Use #getOptionsMap() instead.

    Use #getOptionsMap() instead.

    Annotations
    @Deprecated
    Deprecated

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