org.apache.spark.ml
Class UnaryTransformer<IN,OUT,T extends UnaryTransformer<IN,OUT,T>>

Object
  extended by org.apache.spark.ml.PipelineStage
      extended by org.apache.spark.ml.Transformer
          extended by org.apache.spark.ml.UnaryTransformer<IN,OUT,T>
All Implemented Interfaces:
java.io.Serializable, Logging, Params
Direct Known Subclasses:
ElementwiseProduct, Normalizer, PolynomialExpansion, RegexTokenizer, Tokenizer

public abstract class UnaryTransformer<IN,OUT,T extends UnaryTransformer<IN,OUT,T>>
extends Transformer
implements Logging

:: DeveloperApi :: Abstract class for transformers that take one input column, apply transformation, and output the result as a new column.

See Also:
Serialized Form

Constructor Summary
UnaryTransformer()
           
 
Method Summary
 T copy(ParamMap extra)
          Creates a copy of this instance with the same UID and some extra params.
 T setInputCol(String value)
           
 T setOutputCol(String value)
           
 DataFrame transform(DataFrame dataset)
          Transforms the input dataset.
 StructType transformSchema(StructType schema)
          :: DeveloperApi ::
 
Methods inherited from class org.apache.spark.ml.Transformer
transform, transform, transform
 
Methods inherited from class Object
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
 
Methods inherited from interface org.apache.spark.Logging
initializeIfNecessary, initializeLogging, isTraceEnabled, log_, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning
 
Methods inherited from interface org.apache.spark.ml.param.Params
clear, copyValues, defaultCopy, defaultParamMap, explainParam, explainParams, extractParamMap, extractParamMap, get, getDefault, getOrDefault, getParam, hasDefault, hasParam, isDefined, isSet, paramMap, params, set, set, set, setDefault, setDefault, setDefault, shouldOwn, validateParams
 

Constructor Detail

UnaryTransformer

public UnaryTransformer()
Method Detail

setInputCol

public T setInputCol(String value)

setOutputCol

public T setOutputCol(String value)

transformSchema

public StructType transformSchema(StructType schema)
Description copied from class: PipelineStage
:: DeveloperApi ::

Derives the output schema from the input schema.

Specified by:
transformSchema in class PipelineStage
Parameters:
schema - (undocumented)
Returns:
(undocumented)

transform

public DataFrame transform(DataFrame dataset)
Description copied from class: Transformer
Transforms the input dataset.

Specified by:
transform in class Transformer
Parameters:
dataset - (undocumented)
Returns:
(undocumented)

copy

public T copy(ParamMap extra)
Description copied from interface: Params
Creates a copy of this instance with the same UID and some extra params. Subclasses should implement this method and set the return type properly.

Specified by:
copy in interface Params
Specified by:
copy in class Transformer
Parameters:
extra - (undocumented)
Returns:
(undocumented)
See Also:
defaultCopy()