forked from D-Net/dnet-hadoop
code formatting
This commit is contained in:
parent
0515d81c7c
commit
bf35280ea6
|
@ -226,19 +226,19 @@ public class GraphCleaningFunctions extends CleaningFunctions {
|
||||||
|
|
||||||
public static <T extends Oaf> boolean filter(T value) {
|
public static <T extends Oaf> boolean filter(T value) {
|
||||||
if (!(value instanceof Relation) && (Boolean.TRUE
|
if (!(value instanceof Relation) && (Boolean.TRUE
|
||||||
.equals(
|
.equals(
|
||||||
Optional
|
Optional
|
||||||
.ofNullable(value)
|
.ofNullable(value)
|
||||||
.map(
|
.map(
|
||||||
o -> Optional
|
o -> Optional
|
||||||
.ofNullable(o.getDataInfo())
|
.ofNullable(o.getDataInfo())
|
||||||
.map(
|
.map(
|
||||||
d -> Optional
|
d -> Optional
|
||||||
.ofNullable(d.getInvisible())
|
.ofNullable(d.getInvisible())
|
||||||
.orElse(true))
|
.orElse(true))
|
||||||
.orElse(false))
|
.orElse(false))
|
||||||
.orElse(true)))) {
|
.orElse(true)))) {
|
||||||
return true;
|
return true;
|
||||||
}
|
}
|
||||||
|
|
||||||
if (value instanceof Datasource) {
|
if (value instanceof Datasource) {
|
||||||
|
@ -292,9 +292,10 @@ public class GraphCleaningFunctions extends CleaningFunctions {
|
||||||
} else if (value instanceof Result) {
|
} else if (value instanceof Result) {
|
||||||
Result r = (Result) value;
|
Result r = (Result) value;
|
||||||
|
|
||||||
if (Objects.nonNull(r.getFulltext()) && (ModelConstants.SOFTWARE_RESULTTYPE_CLASSID.equals(r.getResulttype().getClassid()) ||
|
if (Objects.nonNull(r.getFulltext())
|
||||||
ModelConstants.DATASET_RESULTTYPE_CLASSID.equals(r.getResulttype().getClassid()))) {
|
&& (ModelConstants.SOFTWARE_RESULTTYPE_CLASSID.equals(r.getResulttype().getClassid()) ||
|
||||||
r.setFulltext(null);
|
ModelConstants.DATASET_RESULTTYPE_CLASSID.equals(r.getResulttype().getClassid()))) {
|
||||||
|
r.setFulltext(null);
|
||||||
|
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@ -326,10 +327,13 @@ public class GraphCleaningFunctions extends CleaningFunctions {
|
||||||
if (StringUtils.isBlank(r.getPublisher().getValue())) {
|
if (StringUtils.isBlank(r.getPublisher().getValue())) {
|
||||||
r.setPublisher(null);
|
r.setPublisher(null);
|
||||||
} else {
|
} else {
|
||||||
r.getPublisher().setValue(
|
r
|
||||||
r.getPublisher().getValue()
|
.getPublisher()
|
||||||
.replaceAll(NAME_CLEANING_REGEX, " ")
|
.setValue(
|
||||||
);
|
r
|
||||||
|
.getPublisher()
|
||||||
|
.getValue()
|
||||||
|
.replaceAll(NAME_CLEANING_REGEX, " "));
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
if (Objects.isNull(r.getLanguage()) || StringUtils.isBlank(r.getLanguage().getClassid())) {
|
if (Objects.isNull(r.getLanguage()) || StringUtils.isBlank(r.getLanguage().getClassid())) {
|
||||||
|
@ -498,8 +502,8 @@ public class GraphCleaningFunctions extends CleaningFunctions {
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
if (StringUtils.isNotBlank(i.getFulltext()) &&
|
if (StringUtils.isNotBlank(i.getFulltext()) &&
|
||||||
(ModelConstants.SOFTWARE_RESULTTYPE_CLASSID.equals(r.getResulttype().getClassid()) ||
|
(ModelConstants.SOFTWARE_RESULTTYPE_CLASSID.equals(r.getResulttype().getClassid()) ||
|
||||||
ModelConstants.DATASET_RESULTTYPE_CLASSID.equals(r.getResulttype().getClassid()))) {
|
ModelConstants.DATASET_RESULTTYPE_CLASSID.equals(r.getResulttype().getClassid()))) {
|
||||||
i.setFulltext(null);
|
i.setFulltext(null);
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
@ -623,25 +627,28 @@ public class GraphCleaningFunctions extends CleaningFunctions {
|
||||||
|
|
||||||
private static Author cleanupAuthor(Author author) {
|
private static Author cleanupAuthor(Author author) {
|
||||||
if (StringUtils.isNotBlank(author.getFullname())) {
|
if (StringUtils.isNotBlank(author.getFullname())) {
|
||||||
author.setFullname(
|
author
|
||||||
author.getFullname()
|
.setFullname(
|
||||||
.replaceAll(NAME_CLEANING_REGEX, " ")
|
author
|
||||||
.replace("\"", "\\\"")
|
.getFullname()
|
||||||
);
|
.replaceAll(NAME_CLEANING_REGEX, " ")
|
||||||
|
.replace("\"", "\\\""));
|
||||||
}
|
}
|
||||||
if (StringUtils.isNotBlank(author.getName())) {
|
if (StringUtils.isNotBlank(author.getName())) {
|
||||||
author.setName(
|
author
|
||||||
author.getName()
|
.setName(
|
||||||
.replaceAll(NAME_CLEANING_REGEX, " ")
|
author
|
||||||
.replace("\"", "\\\"")
|
.getName()
|
||||||
);
|
.replaceAll(NAME_CLEANING_REGEX, " ")
|
||||||
|
.replace("\"", "\\\""));
|
||||||
}
|
}
|
||||||
if (StringUtils.isNotBlank(author.getSurname())) {
|
if (StringUtils.isNotBlank(author.getSurname())) {
|
||||||
author.setSurname(
|
author
|
||||||
author.getSurname()
|
.setSurname(
|
||||||
.replaceAll(NAME_CLEANING_REGEX, " ")
|
author
|
||||||
.replace("\"", "\\\"")
|
.getSurname()
|
||||||
);
|
.replaceAll(NAME_CLEANING_REGEX, " ")
|
||||||
|
.replace("\"", "\\\""));
|
||||||
}
|
}
|
||||||
|
|
||||||
return author;
|
return author;
|
||||||
|
|
|
@ -18,7 +18,6 @@ package eu.dnetlib.pace.util;
|
||||||
* See the License for the specific language governing permissions and
|
* See the License for the specific language governing permissions and
|
||||||
* limitations under the License.
|
* limitations under the License.
|
||||||
*/
|
*/
|
||||||
|
|
||||||
import java.io.UnsupportedEncodingException;
|
import java.io.UnsupportedEncodingException;
|
||||||
import java.net.URLDecoder;
|
import java.net.URLDecoder;
|
||||||
import java.net.URLEncoder;
|
import java.net.URLEncoder;
|
||||||
|
|
|
@ -1,13 +1,13 @@
|
||||||
|
|
||||||
package eu.dnetlib.dhp.oa.dedup;
|
package eu.dnetlib.dhp.oa.dedup;
|
||||||
|
|
||||||
import eu.dnetlib.dhp.application.ArgumentApplicationParser;
|
import static org.apache.spark.sql.functions.col;
|
||||||
import eu.dnetlib.dhp.schema.common.ModelConstants;
|
|
||||||
import eu.dnetlib.dhp.schema.common.ModelSupport;
|
import java.util.Arrays;
|
||||||
import eu.dnetlib.dhp.schema.oaf.DataInfo;
|
import java.util.Collections;
|
||||||
import eu.dnetlib.dhp.schema.oaf.Relation;
|
import java.util.Iterator;
|
||||||
import eu.dnetlib.dhp.utils.ISLookupClientFactory;
|
import java.util.Objects;
|
||||||
import eu.dnetlib.enabling.is.lookup.rmi.ISLookUpService;
|
|
||||||
import org.apache.commons.beanutils.BeanUtils;
|
import org.apache.commons.beanutils.BeanUtils;
|
||||||
import org.apache.commons.io.IOUtils;
|
import org.apache.commons.io.IOUtils;
|
||||||
import org.apache.commons.lang3.StringUtils;
|
import org.apache.commons.lang3.StringUtils;
|
||||||
|
@ -18,139 +18,141 @@ import org.apache.spark.api.java.function.ReduceFunction;
|
||||||
import org.apache.spark.sql.*;
|
import org.apache.spark.sql.*;
|
||||||
import org.slf4j.Logger;
|
import org.slf4j.Logger;
|
||||||
import org.slf4j.LoggerFactory;
|
import org.slf4j.LoggerFactory;
|
||||||
|
|
||||||
|
import eu.dnetlib.dhp.application.ArgumentApplicationParser;
|
||||||
|
import eu.dnetlib.dhp.schema.common.ModelConstants;
|
||||||
|
import eu.dnetlib.dhp.schema.common.ModelSupport;
|
||||||
|
import eu.dnetlib.dhp.schema.oaf.DataInfo;
|
||||||
|
import eu.dnetlib.dhp.schema.oaf.Relation;
|
||||||
|
import eu.dnetlib.dhp.utils.ISLookupClientFactory;
|
||||||
|
import eu.dnetlib.enabling.is.lookup.rmi.ISLookUpService;
|
||||||
import scala.Tuple2;
|
import scala.Tuple2;
|
||||||
import scala.Tuple3;
|
import scala.Tuple3;
|
||||||
|
|
||||||
import java.util.Arrays;
|
|
||||||
import java.util.Collections;
|
|
||||||
import java.util.Iterator;
|
|
||||||
import java.util.Objects;
|
|
||||||
|
|
||||||
import static org.apache.spark.sql.functions.col;
|
|
||||||
|
|
||||||
public class SparkPropagateRelation extends AbstractSparkAction {
|
public class SparkPropagateRelation extends AbstractSparkAction {
|
||||||
|
|
||||||
private static final Logger log = LoggerFactory.getLogger(SparkPropagateRelation.class);
|
private static final Logger log = LoggerFactory.getLogger(SparkPropagateRelation.class);
|
||||||
|
|
||||||
private static Encoder<Relation> REL_BEAN_ENC = Encoders.bean(Relation.class);
|
private static Encoder<Relation> REL_BEAN_ENC = Encoders.bean(Relation.class);
|
||||||
|
|
||||||
private static Encoder<Relation> REL_KRYO_ENC = Encoders.kryo(Relation.class);
|
private static Encoder<Relation> REL_KRYO_ENC = Encoders.kryo(Relation.class);
|
||||||
|
|
||||||
public SparkPropagateRelation(ArgumentApplicationParser parser, SparkSession spark) {
|
public SparkPropagateRelation(ArgumentApplicationParser parser, SparkSession spark) {
|
||||||
super(parser, spark);
|
super(parser, spark);
|
||||||
}
|
}
|
||||||
|
|
||||||
public static void main(String[] args) throws Exception {
|
public static void main(String[] args) throws Exception {
|
||||||
ArgumentApplicationParser parser = new ArgumentApplicationParser(
|
ArgumentApplicationParser parser = new ArgumentApplicationParser(
|
||||||
IOUtils
|
IOUtils
|
||||||
.toString(
|
.toString(
|
||||||
SparkPropagateRelation.class
|
SparkPropagateRelation.class
|
||||||
.getResourceAsStream(
|
.getResourceAsStream(
|
||||||
"/eu/dnetlib/dhp/oa/dedup/propagateRelation_parameters.json")));
|
"/eu/dnetlib/dhp/oa/dedup/propagateRelation_parameters.json")));
|
||||||
|
|
||||||
parser.parseArgument(args);
|
parser.parseArgument(args);
|
||||||
|
|
||||||
SparkConf conf = new SparkConf();
|
SparkConf conf = new SparkConf();
|
||||||
conf.set("spark.serializer", "org.apache.spark.serializer.KryoSerializer");
|
conf.set("spark.serializer", "org.apache.spark.serializer.KryoSerializer");
|
||||||
conf.registerKryoClasses(ModelSupport.getOafModelClasses());
|
conf.registerKryoClasses(ModelSupport.getOafModelClasses());
|
||||||
|
|
||||||
new SparkPropagateRelation(parser, getSparkSession(conf))
|
new SparkPropagateRelation(parser, getSparkSession(conf))
|
||||||
.run(ISLookupClientFactory.getLookUpService(parser.get("isLookUpUrl")));
|
.run(ISLookupClientFactory.getLookUpService(parser.get("isLookUpUrl")));
|
||||||
}
|
}
|
||||||
|
|
||||||
@Override
|
@Override
|
||||||
public void run(ISLookUpService isLookUpService) {
|
public void run(ISLookUpService isLookUpService) {
|
||||||
|
|
||||||
final String graphBasePath = parser.get("graphBasePath");
|
final String graphBasePath = parser.get("graphBasePath");
|
||||||
final String workingPath = parser.get("workingPath");
|
final String workingPath = parser.get("workingPath");
|
||||||
final String graphOutputPath = parser.get("graphOutputPath");
|
final String graphOutputPath = parser.get("graphOutputPath");
|
||||||
|
|
||||||
log.info("graphBasePath: '{}'", graphBasePath);
|
log.info("graphBasePath: '{}'", graphBasePath);
|
||||||
log.info("workingPath: '{}'", workingPath);
|
log.info("workingPath: '{}'", workingPath);
|
||||||
log.info("graphOutputPath: '{}'", graphOutputPath);
|
log.info("graphOutputPath: '{}'", graphOutputPath);
|
||||||
|
|
||||||
final String outputRelationPath = DedupUtility.createEntityPath(graphOutputPath, "relation");
|
final String outputRelationPath = DedupUtility.createEntityPath(graphOutputPath, "relation");
|
||||||
removeOutputDir(spark, outputRelationPath);
|
removeOutputDir(spark, outputRelationPath);
|
||||||
|
|
||||||
Dataset<Relation> mergeRels = spark
|
Dataset<Relation> mergeRels = spark
|
||||||
.read()
|
.read()
|
||||||
.load(DedupUtility.createMergeRelPath(workingPath, "*", "*"))
|
.load(DedupUtility.createMergeRelPath(workingPath, "*", "*"))
|
||||||
.as(REL_BEAN_ENC);
|
.as(REL_BEAN_ENC);
|
||||||
|
|
||||||
// <mergedObjectID, dedupID>
|
// <mergedObjectID, dedupID>
|
||||||
Dataset<Row> mergedIds = mergeRels
|
Dataset<Row> mergedIds = mergeRels
|
||||||
.where(col("relClass").equalTo(ModelConstants.MERGES))
|
.where(col("relClass").equalTo(ModelConstants.MERGES))
|
||||||
.select(col("source").as("dedupID"), col("target").as("mergedObjectID"))
|
.select(col("source").as("dedupID"), col("target").as("mergedObjectID"))
|
||||||
.distinct()
|
.distinct()
|
||||||
.cache();
|
.cache();
|
||||||
|
|
||||||
Dataset<Row> allRels = spark.read()
|
Dataset<Row> allRels = spark
|
||||||
.schema(REL_BEAN_ENC.schema())
|
.read()
|
||||||
.json(DedupUtility.createEntityPath(graphBasePath, "relation"));
|
.schema(REL_BEAN_ENC.schema())
|
||||||
|
.json(DedupUtility.createEntityPath(graphBasePath, "relation"));
|
||||||
|
|
||||||
Dataset<Relation> dedupedRels = allRels
|
Dataset<Relation> dedupedRels = allRels
|
||||||
.joinWith(mergedIds, allRels.col("source").equalTo(mergedIds.col("mergedObjectID")), "left_outer")
|
.joinWith(mergedIds, allRels.col("source").equalTo(mergedIds.col("mergedObjectID")), "left_outer")
|
||||||
.joinWith(mergedIds, col("_1.target").equalTo(mergedIds.col("mergedObjectID")), "left_outer")
|
.joinWith(mergedIds, col("_1.target").equalTo(mergedIds.col("mergedObjectID")), "left_outer")
|
||||||
.select("_1._1", "_1._2.dedupID", "_2.dedupID")
|
.select("_1._1", "_1._2.dedupID", "_2.dedupID")
|
||||||
.as(Encoders.tuple(REL_BEAN_ENC, Encoders.STRING(), Encoders.STRING()))
|
.as(Encoders.tuple(REL_BEAN_ENC, Encoders.STRING(), Encoders.STRING()))
|
||||||
.flatMap(SparkPropagateRelation::addInferredRelations, REL_KRYO_ENC);
|
.flatMap(SparkPropagateRelation::addInferredRelations, REL_KRYO_ENC);
|
||||||
|
|
||||||
Dataset<Relation> processedRelations = distinctRelations(dedupedRels.union(mergeRels.map((MapFunction<Relation, Relation>) r -> r, REL_KRYO_ENC)))
|
Dataset<Relation> processedRelations = distinctRelations(
|
||||||
.filter((FilterFunction<Relation>) r -> !Objects.equals(r.getSource(), r.getTarget()));
|
dedupedRels.union(mergeRels.map((MapFunction<Relation, Relation>) r -> r, REL_KRYO_ENC)))
|
||||||
|
.filter((FilterFunction<Relation>) r -> !Objects.equals(r.getSource(), r.getTarget()));
|
||||||
|
|
||||||
save(processedRelations, outputRelationPath, SaveMode.Overwrite);
|
save(processedRelations, outputRelationPath, SaveMode.Overwrite);
|
||||||
}
|
}
|
||||||
|
|
||||||
private static Iterator<Relation> addInferredRelations(Tuple3<Relation, String, String> t) throws Exception {
|
private static Iterator<Relation> addInferredRelations(Tuple3<Relation, String, String> t) throws Exception {
|
||||||
Relation existingRel = t._1();
|
Relation existingRel = t._1();
|
||||||
String newSource = t._2();
|
String newSource = t._2();
|
||||||
String newTarget = t._3();
|
String newTarget = t._3();
|
||||||
|
|
||||||
if (newSource == null && newTarget == null) {
|
if (newSource == null && newTarget == null) {
|
||||||
return Collections.singleton(t._1()).iterator();
|
return Collections.singleton(t._1()).iterator();
|
||||||
}
|
}
|
||||||
|
|
||||||
// update existing relation
|
// update existing relation
|
||||||
if (existingRel.getDataInfo() == null) {
|
if (existingRel.getDataInfo() == null) {
|
||||||
existingRel.setDataInfo(new DataInfo());
|
existingRel.setDataInfo(new DataInfo());
|
||||||
}
|
}
|
||||||
existingRel.getDataInfo().setDeletedbyinference(true);
|
existingRel.getDataInfo().setDeletedbyinference(true);
|
||||||
|
|
||||||
// Create new relation inferred by dedupIDs
|
// Create new relation inferred by dedupIDs
|
||||||
Relation inferredRel = (Relation) BeanUtils.cloneBean(existingRel);
|
Relation inferredRel = (Relation) BeanUtils.cloneBean(existingRel);
|
||||||
|
|
||||||
inferredRel.setDataInfo((DataInfo) BeanUtils.cloneBean(existingRel.getDataInfo()));
|
inferredRel.setDataInfo((DataInfo) BeanUtils.cloneBean(existingRel.getDataInfo()));
|
||||||
inferredRel.getDataInfo().setDeletedbyinference(false);
|
inferredRel.getDataInfo().setDeletedbyinference(false);
|
||||||
|
|
||||||
if (newSource != null)
|
if (newSource != null)
|
||||||
inferredRel.setSource(newSource);
|
inferredRel.setSource(newSource);
|
||||||
|
|
||||||
if (newTarget != null)
|
if (newTarget != null)
|
||||||
inferredRel.setTarget(newTarget);
|
inferredRel.setTarget(newTarget);
|
||||||
|
|
||||||
return Arrays.asList(existingRel, inferredRel).iterator();
|
return Arrays.asList(existingRel, inferredRel).iterator();
|
||||||
}
|
}
|
||||||
|
|
||||||
private Dataset<Relation> distinctRelations(Dataset<Relation> rels) {
|
private Dataset<Relation> distinctRelations(Dataset<Relation> rels) {
|
||||||
return rels
|
return rels
|
||||||
.filter(getRelationFilterFunction())
|
.filter(getRelationFilterFunction())
|
||||||
.groupByKey(
|
.groupByKey(
|
||||||
(MapFunction<Relation, String>) r -> String
|
(MapFunction<Relation, String>) r -> String
|
||||||
.join(" ", r.getSource(), r.getTarget(), r.getRelType(), r.getSubRelType(), r.getRelClass()),
|
.join(" ", r.getSource(), r.getTarget(), r.getRelType(), r.getSubRelType(), r.getRelClass()),
|
||||||
Encoders.STRING())
|
Encoders.STRING())
|
||||||
.reduceGroups((ReduceFunction<Relation>) (b, a) -> {
|
.reduceGroups((ReduceFunction<Relation>) (b, a) -> {
|
||||||
b.mergeFrom(a);
|
b.mergeFrom(a);
|
||||||
return b;
|
return b;
|
||||||
}
|
})
|
||||||
)
|
.map((MapFunction<Tuple2<String, Relation>, Relation>) Tuple2::_2, REL_BEAN_ENC);
|
||||||
.map((MapFunction<Tuple2<String, Relation>, Relation>) Tuple2::_2, REL_BEAN_ENC);
|
}
|
||||||
}
|
|
||||||
|
|
||||||
private FilterFunction<Relation> getRelationFilterFunction() {
|
private FilterFunction<Relation> getRelationFilterFunction() {
|
||||||
return r -> StringUtils.isNotBlank(r.getSource()) ||
|
return r -> StringUtils.isNotBlank(r.getSource()) ||
|
||||||
StringUtils.isNotBlank(r.getTarget()) ||
|
StringUtils.isNotBlank(r.getTarget()) ||
|
||||||
StringUtils.isNotBlank(r.getRelType()) ||
|
StringUtils.isNotBlank(r.getRelType()) ||
|
||||||
StringUtils.isNotBlank(r.getSubRelType()) ||
|
StringUtils.isNotBlank(r.getSubRelType()) ||
|
||||||
StringUtils.isNotBlank(r.getRelClass());
|
StringUtils.isNotBlank(r.getRelClass());
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
|
@ -371,7 +371,7 @@ public class GraphCleaningFunctionsTest {
|
||||||
@Test
|
@Test
|
||||||
public void testFilterProject() throws IOException {
|
public void testFilterProject() throws IOException {
|
||||||
String json = IOUtils
|
String json = IOUtils
|
||||||
.toString(getClass().getResourceAsStream("/eu/dnetlib/dhp/oa/graph/clean/project.json"));
|
.toString(getClass().getResourceAsStream("/eu/dnetlib/dhp/oa/graph/clean/project.json"));
|
||||||
Project p_in = MAPPER.readValue(json, Project.class);
|
Project p_in = MAPPER.readValue(json, Project.class);
|
||||||
|
|
||||||
Assertions.assertEquals(false, GraphCleaningFunctions.filter(p_in));
|
Assertions.assertEquals(false, GraphCleaningFunctions.filter(p_in));
|
||||||
|
|
|
@ -1,14 +1,14 @@
|
||||||
|
|
||||||
package eu.dnetlib.dhp.oa.graph.group;
|
package eu.dnetlib.dhp.oa.graph.group;
|
||||||
|
|
||||||
import com.fasterxml.jackson.databind.DeserializationFeature;
|
import static org.junit.jupiter.api.Assertions.assertEquals;
|
||||||
import com.fasterxml.jackson.databind.ObjectMapper;
|
|
||||||
import eu.dnetlib.dhp.common.HdfsSupport;
|
import java.io.IOException;
|
||||||
import eu.dnetlib.dhp.oa.merge.DispatchEntitiesSparkJob;
|
import java.net.URISyntaxException;
|
||||||
import eu.dnetlib.dhp.oa.merge.GroupEntitiesSparkJob;
|
import java.nio.file.Files;
|
||||||
import eu.dnetlib.dhp.schema.common.ModelSupport;
|
import java.nio.file.Path;
|
||||||
import eu.dnetlib.dhp.schema.oaf.Result;
|
import java.nio.file.Paths;
|
||||||
import eu.dnetlib.dhp.utils.DHPUtils;
|
|
||||||
import org.apache.commons.io.FileUtils;
|
import org.apache.commons.io.FileUtils;
|
||||||
import org.apache.commons.lang3.StringUtils;
|
import org.apache.commons.lang3.StringUtils;
|
||||||
import org.apache.spark.SparkConf;
|
import org.apache.spark.SparkConf;
|
||||||
|
@ -19,13 +19,15 @@ import org.apache.spark.sql.Encoders;
|
||||||
import org.apache.spark.sql.SparkSession;
|
import org.apache.spark.sql.SparkSession;
|
||||||
import org.junit.jupiter.api.*;
|
import org.junit.jupiter.api.*;
|
||||||
|
|
||||||
import java.io.IOException;
|
import com.fasterxml.jackson.databind.DeserializationFeature;
|
||||||
import java.net.URISyntaxException;
|
import com.fasterxml.jackson.databind.ObjectMapper;
|
||||||
import java.nio.file.Files;
|
|
||||||
import java.nio.file.Path;
|
|
||||||
import java.nio.file.Paths;
|
|
||||||
|
|
||||||
import static org.junit.jupiter.api.Assertions.assertEquals;
|
import eu.dnetlib.dhp.common.HdfsSupport;
|
||||||
|
import eu.dnetlib.dhp.oa.merge.DispatchEntitiesSparkJob;
|
||||||
|
import eu.dnetlib.dhp.oa.merge.GroupEntitiesSparkJob;
|
||||||
|
import eu.dnetlib.dhp.schema.common.ModelSupport;
|
||||||
|
import eu.dnetlib.dhp.schema.oaf.Result;
|
||||||
|
import eu.dnetlib.dhp.utils.DHPUtils;
|
||||||
|
|
||||||
@TestMethodOrder(MethodOrderer.OrderAnnotation.class)
|
@TestMethodOrder(MethodOrderer.OrderAnnotation.class)
|
||||||
public class GroupEntitiesSparkJobTest {
|
public class GroupEntitiesSparkJobTest {
|
||||||
|
|
Loading…
Reference in New Issue