Package com.facebook.presto.split

Examples of com.facebook.presto.split.MappedRecordSet$MappedRecordCursor


                public RecordSet apply(RecordSet recordSet)
                {
                    if (!overlappingFieldSets.isEmpty()) {
                        recordSet = new FieldSetFilteringRecordSet(recordSet, overlappingFieldSets);
                    }
                    return new MappedRecordSet(recordSet, remappedProbeKeyChannels);
                }
            };

            // Declare the input and output schemas for the index and acquire the actual Index
            List<ColumnHandle> lookupSchema = Lists.transform(lookupSymbolSchema, Functions.forMap(node.getAssignments()));
View Full Code Here


                public RecordSet apply(RecordSet recordSet)
                {
                    if (!overlappingFieldSets.isEmpty()) {
                        recordSet = new FieldSetFilteringRecordSet(recordSet, overlappingFieldSets);
                    }
                    return new MappedRecordSet(recordSet, remappedProbeKeyChannels);
                }
            };

            // Declare the input and output schemas for the index and acquire the actual Index
            List<ColumnHandle> lookupSchema = Lists.transform(lookupSymbolSchema, Functions.forMap(node.getAssignments()));
View Full Code Here

        checkState(getSource() == null, "Index source split already set");

        IndexSplit indexSplit = (IndexSplit) split.getConnectorSplit();

        // Remap the record set into the format the index is expecting
        RecordSet recordSet = new MappedRecordSet(indexSplit.getKeyRecordSet(), probeKeyRemap);
        RecordSet result = index.lookup(recordSet);
        source = new RecordProjectOperator(operatorContext, result);

        operatorContext.setInfoSupplier(Suppliers.ofInstance(split.getInfo()));
    }
View Full Code Here

            checkArgument(columnMetadata != null, "Column %s.%s does not exist", tableName, columnName);

            userToSystemFieldIndex.add(columnMetadata.getOrdinalPosition());
        }

        return new MappedRecordSet(systemTable, userToSystemFieldIndex.build());
    }
View Full Code Here

                public RecordSet apply(RecordSet recordSet)
                {
                    if (!overlappingFieldSets.isEmpty()) {
                        recordSet = new FieldSetFilteringRecordSet(recordSet, overlappingFieldSets);
                    }
                    return new MappedRecordSet(recordSet, remappedProbeKeyChannels);
                }
            };

            // Declare the input and output schemas for the index and acquire the actual Index
            List<ColumnHandle> lookupSchema = Lists.transform(lookupSymbolSchema, Functions.forMap(node.getAssignments()));
View Full Code Here

                public RecordSet apply(RecordSet recordSet)
                {
                    if (!overlappingFieldSets.isEmpty()) {
                        recordSet = new FieldSetFilteringRecordSet(recordSet, overlappingFieldSets);
                    }
                    return new MappedRecordSet(recordSet, remappedProbeKeyChannels);
                }
            };

            // Declare the input and output schemas for the index and acquire the actual Index
            List<ColumnHandle> lookupSchema = Lists.transform(lookupSymbolSchema, Functions.forMap(node.getAssignments()));
View Full Code Here

            checkArgument(columnMetadata != null, "Column %s.%s does not exist", tableName, columnName);

            userToSystemFieldIndex.add(columnMetadata.getOrdinalPosition());
        }

        return new MappedRecordSet(systemTable, userToSystemFieldIndex.build());
    }
View Full Code Here

                public RecordSet apply(RecordSet recordSet)
                {
                    if (!overlappingFieldSets.isEmpty()) {
                        recordSet = new FieldSetFilteringRecordSet(recordSet, overlappingFieldSets);
                    }
                    return new MappedRecordSet(recordSet, remappedProbeKeyChannels);
                }
            };

            // Declare the input and output schemas for the index and acquire the actual Index
            List<ColumnHandle> lookupSchema = Lists.transform(lookupSymbolSchema, forMap(node.getAssignments()));
View Full Code Here

            checkArgument(columnMetadata != null, "Column %s.%s does not exist", tableName, columnName);

            userToSystemFieldIndex.add(columnMetadata.getOrdinalPosition());
        }

        return new MappedRecordSet(systemTable, userToSystemFieldIndex.build());
    }
View Full Code Here

        Function<RecordSet, RecordSet> keyFormatter = new Function<RecordSet, RecordSet>()
        {
            @Override
            public RecordSet apply(RecordSet key)
            {
                return new MappedRecordSet(new AppendingRecordSet(key, rawFixedValues, rawFixedTypes), keyRemap);
            }
        };

        // Compute how to map from the output of the indexed data to the expected output schema
        final List<Integer> outputRemap = computeRemap(table.getOutputColumns(), handleToNames(outputSchema));
        Function<RecordSet, RecordSet> outputFormatter = new Function<RecordSet, RecordSet>()
        {
            @Override
            public RecordSet apply(RecordSet output)
            {
                return new MappedRecordSet(output, outputRemap);
            }
        };

        return new TpchIndex(keyFormatter, outputFormatter, table);
    }
View Full Code Here

TOP

Related Classes of com.facebook.presto.split.MappedRecordSet$MappedRecordCursor

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.