org.apache.spark.ml.odkl.texts

FreqStatsTransformer

class FreqStatsTransformer extends Transformer with Params with HasInputCol

Created by eugeny.malyutin on 06.05.16.

Transformer to count Term - Freq for text corpus distinct per document ([T1 T1 T2],[T2] -> {T1 -> 1/3 ,T2 -> 2/3})

Linear Supertypes
HasInputCol, Transformer, PipelineStage, Logging, Params, Serializable, Serializable, Identifiable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. FreqStatsTransformer
  2. HasInputCol
  3. Transformer
  4. PipelineStage
  5. Logging
  6. Params
  7. Serializable
  8. Serializable
  9. Identifiable
  10. AnyRef
  11. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Instance Constructors

  1. new FreqStatsTransformer()

  2. new FreqStatsTransformer(uid: String)

Value Members

  1. final def !=(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

    Definition Classes
    AnyRef → Any
  4. final def $[T](param: Param[T]): T

    Attributes
    protected
    Definition Classes
    Params
  5. final def ==(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  6. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  7. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  8. final def clear(param: Param[_]): FreqStatsTransformer.this.type

    Definition Classes
    Params
  9. def clone(): AnyRef

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  10. def copy(extra: ParamMap): Transformer

    Definition Classes
    FreqStatsTransformer → Transformer → PipelineStage → Params
  11. def copyValues[T <: Params](to: T, extra: ParamMap): T

    Attributes
    protected
    Definition Classes
    Params
  12. val corpusLen: Param[Long]

  13. def dayToTermStat(preprocedDF: DataFrame): DataFrame

  14. final def defaultCopy[T <: Params](extra: ParamMap): T

    Attributes
    protected
    Definition Classes
    Params
  15. val delimeter: Param[String]

  16. val distinct: UserDefinedFunction

  17. final def eq(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  18. def equals(arg0: Any): Boolean

    Definition Classes
    AnyRef → Any
  19. def explainParam(param: Param[_]): String

    Definition Classes
    Params
  20. def explainParams(): String

    Definition Classes
    Params
  21. final def extractParamMap(): ParamMap

    Definition Classes
    Params
  22. final def extractParamMap(extra: ParamMap): ParamMap

    Definition Classes
    Params
  23. def finalize(): Unit

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  24. val freqTreshArr: DoubleArrayParam

  25. final def get[T](param: Param[T]): Option[T]

    Definition Classes
    Params
  26. final def getClass(): Class[_]

    Definition Classes
    AnyRef → Any
  27. final def getDefault[T](param: Param[T]): Option[T]

    Definition Classes
    Params
  28. final def getInputCol: String

    Definition Classes
    HasInputCol
  29. def getInputDataCol: String

  30. final def getOrDefault[T](param: Param[T]): T

    Definition Classes
    Params
  31. def getOutputColFreq: String

  32. def getOutputColTerm: String

  33. def getParam(paramName: String): Param[Any]

    Definition Classes
    Params
  34. final def hasDefault[T](param: Param[T]): Boolean

    Definition Classes
    Params
  35. def hasParam(paramName: String): Boolean

    Definition Classes
    Params
  36. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  37. final val inputCol: Param[String]

    Definition Classes
    HasInputCol
  38. final def isDefined(param: Param[_]): Boolean

    Definition Classes
    Params
  39. final def isInstanceOf[T0]: Boolean

    Definition Classes
    Any
  40. final def isSet(param: Param[_]): Boolean

    Definition Classes
    Params
  41. def isTraceEnabled(): Boolean

    Attributes
    protected
    Definition Classes
    Logging
  42. def isValid(term: Column, freq: Column): Column

  43. def log: Logger

    Attributes
    protected
    Definition Classes
    Logging
  44. def logDebug(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  45. def logDebug(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  46. def logError(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  47. def logError(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  48. def logInfo(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  49. def logInfo(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  50. def logName: String

    Attributes
    protected
    Definition Classes
    Logging
  51. def logTrace(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  52. def logTrace(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  53. def logWarning(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  54. def logWarning(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  55. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  56. final def notify(): Unit

    Definition Classes
    AnyRef
  57. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  58. val outputColFreq: Param[String]

  59. val outputColTerm: Param[String]

  60. lazy val params: Array[Param[_]]

    Definition Classes
    Params
  61. final def set(paramPair: ParamPair[_]): FreqStatsTransformer.this.type

    Attributes
    protected
    Definition Classes
    Params
  62. final def set(param: String, value: Any): FreqStatsTransformer.this.type

    Attributes
    protected
    Definition Classes
    Params
  63. final def set[T](param: Param[T], value: T): FreqStatsTransformer.this.type

    Definition Classes
    Params
  64. def setCorpusLength(value: Long): FreqStatsTransformer.this.type

  65. final def setDefault(paramPairs: ParamPair[_]*): FreqStatsTransformer.this.type

    Attributes
    protected
    Definition Classes
    Params
  66. final def setDefault[T](param: Param[T], value: T): FreqStatsTransformer.this.type

    Attributes
    protected
    Definition Classes
    Params
  67. def setDelimiter(value: String): FreqStatsTransformer.this.type

  68. def setInputDataCol(value: String): FreqStatsTransformer.this.type

  69. def setOutputColFreq(value: String): FreqStatsTransformer.this.type

  70. def setOutputColTerm(value: String): FreqStatsTransformer.this.type

  71. def setTimestampColumnName(value: String): FreqStatsTransformer.this.type

  72. def setTresholdArr(value: Array[Double]): FreqStatsTransformer.this.type

  73. def setWithTimestamp(value: Boolean): FreqStatsTransformer.this.type

  74. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  75. val timetstampColumnName: Param[String]

  76. def toString(): String

    Definition Classes
    Identifiable → AnyRef → Any
  77. def transform(dataset: DataFrame): DataFrame

    Definition Classes
    FreqStatsTransformer → Transformer
  78. def transform(dataset: DataFrame, paramMap: ParamMap): DataFrame

    Definition Classes
    Transformer
  79. def transform(dataset: DataFrame, firstParamPair: ParamPair[_], otherParamPairs: ParamPair[_]*): DataFrame

    Definition Classes
    Transformer
    Annotations
    @varargs()
  80. def transformSchema(schema: StructType): StructType

    Definition Classes
    FreqStatsTransformer → PipelineStage
    Annotations
    @DeveloperApi()
  81. def transformSchema(schema: StructType, logging: Boolean): StructType

    Attributes
    protected
    Definition Classes
    PipelineStage
    Annotations
    @DeveloperApi()
  82. val uid: String

    Definition Classes
    FreqStatsTransformer → Identifiable
  83. def validateParams(): Unit

    Definition Classes
    Params
  84. final def wait(): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  85. final def wait(arg0: Long, arg1: Int): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  86. final def wait(arg0: Long): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  87. val withTimestamp: BooleanParam

Inherited from HasInputCol

Inherited from Transformer

Inherited from PipelineStage

Inherited from Logging

Inherited from Params

Inherited from Serializable

Inherited from Serializable

Inherited from Identifiable

Inherited from AnyRef

Inherited from Any

getParam

setParam

Ungrouped