Packages

c

org.apache.flink.api.scala.operators

ScalaCsvOutputFormat

class ScalaCsvOutputFormat[T <: Product] extends FileOutputFormat[T] with InputTypeConfigurable

This is an OutputFormat to serialize Scala Tuples to text. The output is structured by record delimiters and field delimiters as common in CSV files. Record delimiter separate records from each other ('\n' is common). Field delimiters separate fields within a record.

Deprecated

All Flink Scala APIs are deprecated and will be removed in a future Flink major version. You can still build your application in Scala, but you should move to the Java version of either the DataStream and/or Table API.

See also

FLIP-265 Deprecate and remove Scala API support

Linear Supertypes
InputTypeConfigurable, FileOutputFormat[T], CleanupWhenUnsuccessful, InitializeOnMaster, RichOutputFormat[T], OutputFormat[T], Serializable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ScalaCsvOutputFormat
  2. InputTypeConfigurable
  3. FileOutputFormat
  4. CleanupWhenUnsuccessful
  5. InitializeOnMaster
  6. RichOutputFormat
  7. OutputFormat
  8. Serializable
  9. AnyRef
  10. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new ScalaCsvOutputFormat(outputPath: Path, recordDelimiter: String, fieldDelimiter: String)

    Creates an instance of CsvOutputFormat.

    Creates an instance of CsvOutputFormat.

    outputPath

    The path where the CSV file is written.

    recordDelimiter

    The delimiter that is used to separate the tuples.

    fieldDelimiter

    The delimiter that is used to separate fields in a tuple.

  2. new ScalaCsvOutputFormat(outputPath: Path, fieldDelimiter: String)

    Creates an instance of CsvOutputFormat.

    Creates an instance of CsvOutputFormat. Lines are separated by the newline character '\n', fields by the given field delimiter.

    outputPath

    The path where the CSV file is written.

    fieldDelimiter

    The delimiter that is used to separate fields in a tuple.

  3. new ScalaCsvOutputFormat(outputPath: Path)

    Deprecated

    All Flink Scala APIs are deprecated and will be removed in a future Flink major version. You can still build your application in Scala, but you should move to the Java version of either the DataStream and/or Table API.

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[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @native() @throws( ... )
  6. def close(): Unit
    Definition Classes
    ScalaCsvOutputFormat → FileOutputFormat → OutputFormat
  7. def configure(arg0: Configuration): Unit
    Definition Classes
    FileOutputFormat → OutputFormat
  8. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  9. def equals(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  10. def finalize(): Unit
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  11. final def getClass(): Class[_]
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  12. def getDirectoryFileName(arg0: Int): String
    Attributes
    protected[org.apache.flink.api.common.io]
    Definition Classes
    FileOutputFormat
  13. def getOutputDirectoryMode(): OutputDirectoryMode
    Definition Classes
    FileOutputFormat
  14. def getOutputFilePath(): Path
    Definition Classes
    FileOutputFormat
  15. def getRuntimeContext(): RuntimeContext
    Definition Classes
    RichOutputFormat
  16. def getWriteMode(): WriteMode
    Definition Classes
    FileOutputFormat
  17. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  18. def initializeGlobal(arg0: Int): Unit
    Definition Classes
    FileOutputFormat → InitializeOnMaster
    Annotations
    @throws( classOf[java.io.IOException] )
  19. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  20. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  21. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  22. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  23. def open(taskNumber: Int, numTasks: Int): Unit
    Definition Classes
    ScalaCsvOutputFormat → FileOutputFormat → OutputFormat
  24. def open(arg0: InitializationContext): Unit
    Definition Classes
    OutputFormat
    Annotations
    @throws( classOf[java.io.IOException] )
  25. def setAllowNullValues(allowNulls: Boolean): Unit

    Configures the format to either allow null values (writing an empty field), or to throw an exception when encountering a null field.

    Configures the format to either allow null values (writing an empty field), or to throw an exception when encountering a null field.

    By default, null values are allowed.

    allowNulls

    Flag to indicate whether the output format should accept null values.

  26. def setCharsetName(charsetName: String): Unit

    Sets the charset with which the CSV strings are written to the file.

    Sets the charset with which the CSV strings are written to the file. If not specified, the output format uses the systems default character encoding.

    charsetName

    The name of charset to use for encoding the output.

  27. def setInputType(type: TypeInformation[_], executionConfig: ExecutionConfig): Unit

    The purpose of this method is solely to check whether the data type to be processed is in fact a tuple type.

    The purpose of this method is solely to check whether the data type to be processed is in fact a tuple type.

    Definition Classes
    ScalaCsvOutputFormat → InputTypeConfigurable
  28. def setOutputDirectoryMode(arg0: OutputDirectoryMode): Unit
    Definition Classes
    FileOutputFormat
  29. def setOutputFilePath(arg0: Path): Unit
    Definition Classes
    FileOutputFormat
  30. def setQuoteStrings(quoteStrings: Boolean): Unit

    Configures whether the output format should quote string values.

    Configures whether the output format should quote string values. String values are fields of type String and org.apache.flink.types.StringValue, as well as all subclasses of the latter.

    By default, strings are not quoted.

    quoteStrings

    Flag indicating whether string fields should be quoted.

  31. def setRuntimeContext(arg0: RuntimeContext): Unit
    Definition Classes
    RichOutputFormat
  32. def setWriteMode(arg0: WriteMode): Unit
    Definition Classes
    FileOutputFormat
  33. final def synchronized[T0](arg0: ⇒ T0): T0
    Definition Classes
    AnyRef
  34. def toString(): String
    Definition Classes
    ScalaCsvOutputFormat → AnyRef → Any
  35. def tryCleanupOnError(): Unit
    Definition Classes
    FileOutputFormat → CleanupWhenUnsuccessful
  36. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  37. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  38. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @throws( ... )
  39. def writeRecord(element: T): Unit
    Definition Classes
    ScalaCsvOutputFormat → OutputFormat

Inherited from InputTypeConfigurable

Inherited from FileOutputFormat[T]

Inherited from CleanupWhenUnsuccessful

Inherited from InitializeOnMaster

Inherited from RichOutputFormat[T]

Inherited from OutputFormat[T]

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped