Modifier and Type | Method and Description |
---|---|
DataBag |
LoadCaster.bytesToBag(byte[] b,
ResourceSchema.ResourceFieldSchema fieldSchema)
Cast data from bytearray to bag value.
|
Modifier and Type | Method and Description |
---|---|
Map<Operator,DataBag> |
PigServer.getExamples(String alias) |
Modifier and Type | Method and Description |
---|---|
byte[] |
StoreCaster.toBytes(DataBag bag) |
Modifier and Type | Method and Description |
---|---|
DataBag |
AccumuloBinaryConverter.bytesToBag(byte[] b,
ResourceSchema.ResourceFieldSchema fieldSchema)
NOT IMPLEMENTED
|
Modifier and Type | Method and Description |
---|---|
byte[] |
AccumuloBinaryConverter.toBytes(DataBag bag)
NOT IMPLEMENTED
|
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.mapreduce.Mapper.Context |
PigMapBase.getIllustratorContext(org.apache.hadoop.conf.Configuration conf,
DataBag input,
List<Pair<PigNullableWritable,org.apache.hadoop.io.Writable>> output,
org.apache.hadoop.mapreduce.InputSplit split)
Get mapper's illustrator context
|
abstract org.apache.hadoop.mapreduce.Mapper.Context |
PigGenericMapBase.getIllustratorContext(org.apache.hadoop.conf.Configuration conf,
DataBag input,
List<Pair<PigNullableWritable,org.apache.hadoop.io.Writable>> output,
org.apache.hadoop.mapreduce.InputSplit split) |
Constructor and Description |
---|
IllustratorContext(org.apache.hadoop.conf.Configuration conf,
DataBag input,
List<Pair<PigNullableWritable,org.apache.hadoop.io.Writable>> output,
org.apache.hadoop.mapreduce.InputSplit split) |
Modifier and Type | Method and Description |
---|---|
protected void |
WeightedRangePartitioner.convertToArray(DataBag quantilesListAsBag) |
Modifier and Type | Field and Description |
---|---|
protected DataBag[] |
Packager.bags |
protected DataBag[] |
POCross.inputBags |
protected DataBag |
POFRJoin.nullBag |
Modifier and Type | Method and Description |
---|---|
protected DataBag |
POPartitionRearrange.constructPROutput(List<Result> resLst,
Tuple value) |
DataBag |
Packager.getBag() |
Modifier and Type | Method and Description |
---|---|
void |
Packager.attachInput(Object key,
DataBag[] bags,
boolean[] readOnce) |
void |
LitePackager.attachInput(Object key,
DataBag[] bags,
boolean[] readOnce) |
void |
JoinPackager.attachInput(Object key,
DataBag[] bags,
boolean[] readOnce) |
void |
CombinerPackager.attachInput(Object key,
DataBag[] bags,
boolean[] readOnce) |
Modifier and Type | Method and Description |
---|---|
protected DataBag |
POPartitionRearrangeTez.constructPROutput(List<Result> resLst,
Tuple value) |
Modifier and Type | Method and Description |
---|---|
void |
BloomPackager.attachInput(Object key,
DataBag[] bags,
boolean[] readOnce) |
Modifier and Type | Method and Description |
---|---|
DataBag |
HBaseBinaryConverter.bytesToBag(byte[] b,
ResourceSchema.ResourceFieldSchema fieldSchema)
NOT IMPLEMENTED
|
Modifier and Type | Method and Description |
---|---|
byte[] |
HBaseBinaryConverter.toBytes(DataBag bag)
NOT IMPLEMENTED
|
Modifier and Type | Method and Description |
---|---|
DataBag |
Utf8StorageConverter.bytesToBag(byte[] b,
ResourceSchema.ResourceFieldSchema schema) |
DataBag |
TextLoader.bytesToBag(byte[] b,
ResourceSchema.ResourceFieldSchema schema)
TextLoader does not support conversion to Bag
|
DataBag |
VALUESET.exec(Tuple input) |
DataBag |
VALUELIST.exec(Tuple input) |
DataBag |
TOP.Final.exec(Tuple tuple) |
DataBag |
TOKENIZE.exec(Tuple input) |
DataBag |
TOBAG.exec(Tuple input) |
DataBag |
SUBTRACT.exec(Tuple input)
Compares the two bag fields from input Tuple and returns a new bag composed of elements of first bag not in the second bag.
|
DataBag |
STRSPLITTOBAG.exec(Tuple input)
Wrapper around Java's String.split
|
DataBag |
RollupDimensions.exec(Tuple tuple) |
DataBag |
REGEX_SEARCH.exec(Tuple input) |
DataBag |
KEYSET.exec(Tuple input) |
DataBag |
Distinct.exec(Tuple input) |
DataBag |
Distinct.Final.exec(Tuple input) |
DataBag |
DIFF.exec(Tuple input)
Compares a tuple with two fields.
|
DataBag |
CubeDimensions.exec(Tuple tuple) |
DataBag |
COV.exec(Tuple input)
Function to compute covariance between data sets.
|
DataBag |
COV.Final.exec(Tuple input) |
DataBag |
COR.exec(Tuple input)
Function to compute correlation between data sets.
|
DataBag |
COR.Final.exec(Tuple input) |
protected DataBag |
Distinct.getDistinct(Tuple input) |
DataBag |
TOP.getValue() |
Modifier and Type | Method and Description |
---|---|
protected static Tuple |
LongAvg.combine(DataBag values) |
protected static Tuple |
IntAvg.combine(DataBag values) |
protected static Tuple |
FloatAvg.combine(DataBag values) |
protected static Tuple |
DoubleAvg.combine(DataBag values) |
protected static Tuple |
COV.combine(DataBag values)
combine results of different data chunk
|
protected static Tuple |
COR.combine(DataBag values)
combine results of different data chunk
|
protected static Tuple |
BigIntegerAvg.combine(DataBag values) |
protected static Tuple |
BigDecimalAvg.combine(DataBag values) |
protected static Tuple |
AVG.combine(DataBag values) |
protected static Tuple |
COV.computeAll(DataBag first,
DataBag second)
compute sum(XY), sum(X), sum(Y) from given data sets
|
protected static Tuple |
COR.computeAll(DataBag first,
DataBag second)
compute sum(XY), sum(X), sum(Y), sum(XX), sum(YY) from given data sets
|
byte[] |
Utf8StorageConverter.toBytes(DataBag bag) |
byte[] |
TextLoader.toBytes(DataBag bag) |
byte[] |
BinStorage.toBytes(DataBag bag) |
protected static void |
TOP.updateTop(PriorityQueue<Tuple> store,
int limit,
DataBag inputBag) |
Modifier and Type | Method and Description |
---|---|
static DataBag |
Storage.bag(Tuple... tuples) |
Modifier and Type | Class and Description |
---|---|
class |
AccumulativeBag |
class |
DefaultAbstractBag
Default implementation of DataBag.
|
class |
DefaultDataBag
An unordered collection of Tuples (possibly) with multiples.
|
class |
DistinctDataBag
An unordered collection of Tuples with no multiples.
|
class |
InternalCachedBag |
class |
InternalDistinctBag
An unordered collection of Tuples with no multiples.
|
class |
InternalSortedBag
An ordered collection of Tuples (possibly) with multiples.
|
class |
LimitedSortedDataBag
An ordered collection of Tuples (possibly) with multiples.
|
class |
NonSpillableDataBag
An unordered collection of Tuples (possibly) with multiples.
|
class |
ReadOnceBag
This bag does not store the tuples in memory, but has access to an iterator
typically provided by Hadoop.
|
class |
SelfSpillBag
Class to hold code common to self spilling bags such as InternalCachedBag
|
class |
SingleTupleBag
A simple performant implementation of the DataBag
interface which only holds a single tuple.
|
class |
SortedDataBag
An ordered collection of Tuples (possibly) with multiples.
|
class |
SortedSpillBag
Common functionality for proactively spilling bags that need to keep the data
sorted.
|
Modifier and Type | Method and Description |
---|---|
protected DataBag |
SchemaTuple.box(DataBag v) |
static DataBag |
DataReaderWriter.bytesToBag(DataInput in) |
protected abstract DataBag |
SchemaTuple.generatedCodeGetDataBag(int fieldNum) |
DataBag |
TypeAwareTuple.getDataBag(int idx) |
DataBag |
SchemaTuple.getDataBag(int fieldNum) |
DataBag |
DefaultBagFactory.newDefaultBag()
Get a default (unordered, not distinct) data bag.
|
abstract DataBag |
BagFactory.newDefaultBag()
Get a default (unordered, not distinct) data bag.
|
DataBag |
DefaultBagFactory.newDefaultBag(List<Tuple> listOfTuples)
Get a default (unordered, not distinct) data bag from
an existing list of tuples.
|
abstract DataBag |
BagFactory.newDefaultBag(List<Tuple> listOfTuples)
Get a default (unordered, not distinct) data bag with
an existing list of tuples inserted into the bag.
|
DataBag |
DefaultBagFactory.newDistinctBag()
Get a distinct data bag.
|
abstract DataBag |
BagFactory.newDistinctBag()
Get a distinct data bag.
|
DataBag |
DefaultBagFactory.newLimitedSortedBag(Comparator<Tuple> comp,
long limit)
Get a limited sorted data bag.
|
abstract DataBag |
BagFactory.newLimitedSortedBag(Comparator<Tuple> comp,
long limit)
Get a limited sorted data bag.
|
DataBag |
DefaultBagFactory.newSortedBag(Comparator<Tuple> comp)
Get a sorted data bag.
|
abstract DataBag |
BagFactory.newSortedBag(Comparator<Tuple> comp)
Get a sorted data bag.
|
protected static DataBag |
SchemaTuple.read(DataInput in,
DataBag v) |
protected DataBag |
SchemaTuple.returnUnlessNull(boolean isNull,
DataBag val) |
static DataBag |
DataType.toBag(Object o)
If this object is a bag, return it as a bag.
|
protected DataBag |
SchemaTuple.unbox(DataBag v) |
protected DataBag |
SchemaTuple.unbox(Object v,
DataBag t) |
protected DataBag |
SchemaTuple.unboxDataBag(Object val) |
Modifier and Type | Method and Description |
---|---|
void |
SingleTupleBag.addAll(DataBag b) |
void |
ReadOnceBag.addAll(DataBag b) |
void |
NonSpillableDataBag.addAll(DataBag b) |
void |
LimitedSortedDataBag.addAll(DataBag b)
Add contents of a bag to the bag.
|
void |
DefaultAbstractBag.addAll(DataBag b) |
void |
DataBag.addAll(DataBag b)
Add contents of a bag to the bag.
|
void |
AccumulativeBag.addAll(DataBag b) |
protected DataBag |
SchemaTuple.box(DataBag v) |
protected int |
SchemaTuple.compare(boolean usNull,
DataBag usVal,
boolean themNull,
DataBag themVal) |
protected int |
SchemaTuple.compare(DataBag val,
DataBag themVal) |
protected int |
SchemaTuple.compareWithElementAtPos(boolean isNull,
DataBag val,
SchemaTuple<?> t,
int pos) |
protected abstract void |
SchemaTuple.generatedCodeSetDataBag(int fieldNum,
DataBag val) |
protected int |
SchemaTuple.hashCodePiece(int hash,
DataBag v,
boolean isNull) |
protected static DataBag |
SchemaTuple.read(DataInput in,
DataBag v) |
protected void |
BagFactory.registerBag(DataBag b)
Deprecated.
As of Pig 0.11, bags register with the
SpillableMemoryManager themselves.
Register a bag with the
SpillableMemoryManager .
If the bags created by an implementation of BagFactory are managed by
the SpillableMemoryManager then this
method should be called each time a new bag is created. |
protected DataBag |
SchemaTuple.returnUnlessNull(boolean isNull,
DataBag val) |
void |
TypeAwareTuple.setDataBag(int idx,
DataBag val) |
void |
SchemaTuple.setDataBag(int fieldNum,
DataBag val) |
protected DataBag |
SchemaTuple.unbox(DataBag v) |
protected DataBag |
SchemaTuple.unbox(Object v,
DataBag t) |
protected static void |
SchemaTuple.write(DataOutput out,
DataBag v) |
Modifier and Type | Field and Description |
---|---|
protected DataBag |
FindQuantiles.samples |
Modifier and Type | Method and Description |
---|---|
DataBag |
GFReplicate.exec(Tuple input) |
DataBag |
GFCross.exec(Tuple input) |
Modifier and Type | Method and Description |
---|---|
void |
ReadScalars.setOutputBuffer(Map<String,DataBag> inputBuffer) |
Modifier and Type | Method and Description |
---|---|
DataBag |
PigFile.load(LoadFunc lfunc,
PigContext pigContext) |
Modifier and Type | Method and Description |
---|---|
void |
PigFile.store(DataBag data,
FuncSpec storeFuncSpec,
PigContext pigContext) |
Constructor and Description |
---|
NullableBag(DataBag b) |
Modifier and Type | Method and Description |
---|---|
static String |
BagFormat.format(DataBag bag) |
Modifier and Type | Class and Description |
---|---|
class |
AvroBagWrapper<T>
Class that implements the Pig bag interface, wrapping an Avro array.
|
Modifier and Type | Method and Description |
---|---|
void |
AvroBagWrapper.addAll(DataBag b) |
static org.apache.avro.generic.GenericData.Array<Object> |
AvroStorageDataConversionUtilities.packIntoAvro(DataBag db,
org.apache.avro.Schema s)
Packs a Pig DataBag into an Avro array.
|
Modifier and Type | Method and Description |
---|---|
DataBag |
Illustrator.getData() |
Modifier and Type | Method and Description |
---|---|
Map<Operator,DataBag> |
ExampleGenerator.getData() |
Map<Operator,DataBag> |
ExampleGenerator.getData(Map<LOLoad,DataBag> newBaseData) |
Map<PhysicalOperator,DataBag> |
IllustratorAttacher.getDataMap() |
Map<Operator,DataBag> |
ExampleGenerator.getExamples() |
Map<LOLoad,DataBag> |
AugmentBaseDataVisitor.getNewBaseData() |
Modifier and Type | Method and Description |
---|---|
Map<Operator,DataBag> |
ExampleGenerator.getData(Map<LOLoad,DataBag> newBaseData) |
static Map<LogicalRelationalOperator,Collection<IdentityHashSet<Tuple>>> |
EquivalenceClasses.getLoToEqClassMap(PhysicalPlan plan,
LogicalPlan lp,
Map<Operator,PhysicalOperator> logToPhyMap,
Map<Operator,DataBag> logToDataMap,
Map<LOForEach,Map<LogicalRelationalOperator,PhysicalOperator>> forEachInnerLogToPhyMap,
HashMap<PhysicalOperator,Collection<IdentityHashSet<Tuple>>> poToEqclassesMap) |
void |
LocalMapReduceSimulator.launchPig(PhysicalPlan php,
Map<LOLoad,DataBag> baseData,
LineageTracer lineage,
IllustratorAttacher attacher,
ExampleGenerator eg,
PigContext pc) |
Constructor and Description |
---|
AugmentBaseDataVisitor(OperatorPlan plan,
Map<Operator,PhysicalOperator> logToPhysMap,
Map<LOLoad,DataBag> baseData,
Map<Operator,DataBag> derivedData) |
AugmentBaseDataVisitor(OperatorPlan plan,
Map<Operator,PhysicalOperator> logToPhysMap,
Map<LOLoad,DataBag> baseData,
Map<Operator,DataBag> derivedData) |
LineageTrimmingVisitor(LogicalPlan plan,
Map<LOLoad,DataBag> baseData,
ExampleGenerator eg,
Map<Operator,PhysicalOperator> LogToPhyMap,
PhysicalPlan physPlan,
PigContext pc) |
Modifier and Type | Method and Description |
---|---|
static float |
MetricEvaluation.getCompleteness(Operator op,
Map<Operator,DataBag> exampleData,
Map<LogicalRelationalOperator,Collection<IdentityHashSet<Tuple>>> OperatorToEqClasses,
boolean overallCompleteness) |
static float |
MetricEvaluation.getConciseness(Operator op,
Map<Operator,DataBag> exampleData,
Map<LogicalRelationalOperator,Collection<IdentityHashSet<Tuple>>> OperatorToEqClasses,
boolean overallConciseness) |
static float |
MetricEvaluation.getRealness(Operator op,
Map<Operator,DataBag> exampleData,
boolean overallRealness) |
static void |
DisplayExamples.printSimple(Operator op,
LogicalPlan lp,
Map<Operator,DataBag> exampleData) |
static String |
DisplayExamples.printTabular(LogicalPlan lp,
Map<Operator,DataBag> exampleData,
Map<LOForEach,Map<LogicalRelationalOperator,DataBag>> forEachInnerLogToDataMap) |
static String |
DisplayExamples.printTabular(LogicalPlan lp,
Map<Operator,DataBag> exampleData,
Map<LOForEach,Map<LogicalRelationalOperator,DataBag>> forEachInnerLogToDataMap) |
Modifier and Type | Method and Description |
---|---|
DataBag |
Stitch.exec(Tuple input) |
DataBag |
Over.exec(Tuple input) |
Modifier and Type | Method and Description |
---|---|
protected static Tuple |
MaxTupleBy1stField.max(DataBag values,
PigProgressable reporter) |
Modifier and Type | Method and Description |
---|---|
DataBag |
COV.exec(Tuple input)
Deprecated.
Function to compute covariance between data sets.
|
DataBag |
COV.Final.exec(Tuple input) |
DataBag |
COR.exec(Tuple input)
Deprecated.
Function to compute correlation between data sets.
|
DataBag |
COR.Final.exec(Tuple input) |
Modifier and Type | Method and Description |
---|---|
protected static Tuple |
COV.combine(DataBag values)
Deprecated.
combine results of different data chunk
|
protected static Tuple |
COR.combine(DataBag values)
Deprecated.
combine results of different data chunk
|
protected static Tuple |
COV.computeAll(DataBag first,
DataBag second)
Deprecated.
compute sum(XY), sum(X), sum(Y) from given data sets
|
protected static Tuple |
COR.computeAll(DataBag first,
DataBag second)
Deprecated.
compute sum(XY), sum(X), sum(Y), sum(XX), sum(YY) from given data sets
|
Modifier and Type | Method and Description |
---|---|
DataBag |
Top.exec(Tuple tuple)
Deprecated.
|
DataBag |
Top.Final.exec(Tuple tuple) |
DataBag |
ToBag.exec(Tuple input)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
protected static void |
Top.updateTop(PriorityQueue<Tuple> store,
int limit,
DataBag inputBag)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
DataBag |
RubyDataBag.getBag() |
static DataBag |
PigJrubyLibrary.rubyToPig(RubyDataBag rbObject)
A type specific conversion routine.
|
Modifier and Type | Method and Description |
---|---|
static RubyDataBag |
PigJrubyLibrary.pigToRuby(org.jruby.Ruby ruby,
DataBag object)
A type specific conversion routine.
|
Constructor and Description |
---|
RubyDataBag(org.jruby.Ruby ruby,
org.jruby.RubyClass rc,
DataBag db)
This constructor encapsulates the bag that is passed to it.
|
Copyright © 2007-2017 The Apache Software Foundation