org.apache.hadoop.hive.dynamodb.shims.Hive2SerDeParametersShim Maven / Gradle / Ivy
Go to download
Show more of this group Show more artifacts with this name
Show all versions of hive2-shims Show documentation
Show all versions of hive2-shims Show documentation
Shims for Hive-2.x compatibility
The newest version!
package org.apache.hadoop.hive.dynamodb.shims;
import java.util.List;
import java.util.Properties;
import org.apache.hadoop.conf.Configuration;
import org.apache.hadoop.hive.serde2.SerDeException;
import org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters;
import org.apache.hadoop.hive.serde2.typeinfo.TypeInfo;
class Hive2SerDeParametersShim implements SerDeParametersShim {
private final LazySerDeParameters realSerDeParameters;
Hive2SerDeParametersShim(Configuration configuration, Properties properties, String serDeName)
throws SerDeException {
this.realSerDeParameters = new LazySerDeParameters(configuration, properties, serDeName);
}
@Override
public List getColumnNames() {
return this.realSerDeParameters.getColumnNames();
}
@Override
public List getColumnTypes() {
return this.realSerDeParameters.getColumnTypes();
}
@Override
public byte[] getSeparators() {
return this.realSerDeParameters.getSeparators();
}
}