data:image/s3,"s3://crabby-images/02ace/02ace956f9868cf2a1a780bd2c0a517cd3a46077" alt="JAR search and dependency download from the Maven repository"
sparksoniq.spark.iterator.flowr.CountClauseSparkIterator Maven / Gradle / Ivy
/*
* Licensed to the Apache Software Foundation (ASF) under one or more
* contributor license agreements. See the NOTICE file distributed with
* this work for additional information regarding copyright ownership.
* The ASF licenses this file to You under the Apache License, Version 2.0
* (the "License"); you may not use this file except in compliance with
* the License. You may obtain a copy of the License at
*
* http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*
* Authors: Stefan Irimescu, Can Berker Cikis
*
*/
package sparksoniq.spark.iterator.flowr;
import org.apache.spark.api.java.JavaRDD;
import org.apache.spark.sql.Dataset;
import org.apache.spark.sql.Row;
import org.apache.spark.sql.types.DataTypes;
import org.apache.spark.sql.types.StructType;
import org.rumbledb.api.Item;
import sparksoniq.exceptions.IteratorFlowException;
import sparksoniq.exceptions.SparksoniqRuntimeException;
import sparksoniq.jsoniq.item.ItemFactory;
import sparksoniq.jsoniq.runtime.iterator.RuntimeIterator;
import sparksoniq.jsoniq.runtime.iterator.primary.VariableReferenceIterator;
import sparksoniq.jsoniq.runtime.metadata.IteratorMetadata;
import sparksoniq.jsoniq.runtime.tupleiterator.RuntimeTupleIterator;
import sparksoniq.jsoniq.runtime.tupleiterator.SparkRuntimeTupleIterator;
import sparksoniq.jsoniq.tuple.FlworTuple;
import sparksoniq.semantics.DynamicContext;
import sparksoniq.spark.DataFrameUtils;
import sparksoniq.spark.closures.CountClauseClosure;
import sparksoniq.spark.udf.CountClauseSerializeUDF;
import java.util.ArrayList;
import java.util.Arrays;
import java.util.HashSet;
import java.util.List;
import java.util.Map;
import java.util.Set;
import java.util.TreeMap;
public class CountClauseSparkIterator extends SparkRuntimeTupleIterator {
private static final long serialVersionUID = 1L;
private String _variableName;
private FlworTuple _nextLocalTupleResult;
private int _currentCountIndex;
public CountClauseSparkIterator(RuntimeTupleIterator child, RuntimeIterator variableReference, IteratorMetadata iteratorMetadata) {
super(child, iteratorMetadata);
_variableName = ((VariableReferenceIterator) variableReference).getVariableName();
_currentCountIndex = 1; // indices start at 1 in JSONiq
}
@Override
public boolean isRDD() {
return _child.isRDD();
}
@Override
public boolean isDataFrame() {
return _child.isDataFrame();
}
@Override
public void open(DynamicContext context) {
super.open(context);
// isRDD checks omitted, as open is used for non-RDD(local) operations
if (this._child != null) {
_child.open(_currentDynamicContext);
setNextLocalTupleResult();
} else {
throw new SparksoniqRuntimeException("Invalid count clause.");
}
}
@Override
public void close() {
super.close();
_currentCountIndex = 1;
}
@Override
public FlworTuple next() {
if (_hasNext == true) {
FlworTuple result = _nextLocalTupleResult; // save the result to be returned
setNextLocalTupleResult(); // calculate and store the next result
return result;
}
throw new IteratorFlowException("Invalid next() call in count flwor clause", getMetadata());
}
private void setNextLocalTupleResult() {
if (_child.hasNext()) {
FlworTuple inputTuple = _child.next();
List- results = new ArrayList<>();
results.add(ItemFactory.getInstance().createIntegerItem(_currentCountIndex++));
FlworTuple newTuple = new FlworTuple(inputTuple, _variableName, results);
_nextLocalTupleResult = newTuple;
this._hasNext = true;
} else {
_child.close();
this._hasNext = false;
}
}
@Override
public JavaRDD
getRDD(DynamicContext context) {
String variableName = _variableName;
// zipWithIndex starts from 0, increment indices by 1 for jsoniq convention
return _child.getRDD(context).zipWithIndex()
.mapValues(index -> index + 1)
.map(new CountClauseClosure(variableName));
}
@Override
public Dataset getDataFrame(DynamicContext context, Map parentProjection)
{
if (this._child == null) {
throw new SparksoniqRuntimeException("Invalid count clause.");
}
Dataset df = _child.getDataFrame(context, getProjection(parentProjection));
StructType inputSchema = df.schema();
int duplicateVariableIndex = Arrays.asList(inputSchema.fieldNames()).indexOf(_variableName);
List allColumns = DataFrameUtils.getColumnNames(inputSchema, duplicateVariableIndex, null);
String selectSQL = DataFrameUtils.getSQL(allColumns, true);
Dataset dfWithIndex = DataFrameUtils.zipWithIndex(df, new Long(1), _variableName);
df.sparkSession().udf().register("serializeCountIndex",
new CountClauseSerializeUDF(), DataTypes.BinaryType);
dfWithIndex.createOrReplaceTempView("input");
dfWithIndex = dfWithIndex.sparkSession().sql(
String.format("select %s serializeCountIndex(`%s`) as `%s` from input",
selectSQL, _variableName, _variableName)
);
return dfWithIndex;
}
public Map getVariableDependencies()
{
Map result = new TreeMap();
result.putAll(_child.getVariableDependencies());
return result;
}
public Set getVariablesBoundInCurrentFLWORExpression()
{
Set result = new HashSet();
result.addAll(_child.getVariablesBoundInCurrentFLWORExpression());
result.add(_variableName);
return result;
}
public void print(StringBuffer buffer, int indent)
{
super.print(buffer, indent);
for (int i = 0; i < indent + 1; ++i)
{
buffer.append(" ");
}
buffer.append("Variable " + _variableName);
buffer.append("\n");
}
public Map getProjection(Map parentProjection)
{
// start with an empty projection.
Map projection = new TreeMap();
// copy over the projection needed by the parent clause.
projection.putAll(parentProjection);
// remove the variable that this clause binds.
projection.remove(_variableName);
return projection;
}
}
© 2015 - 2025 Weber Informatics LLC | Privacy Policy