|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Uses of Tuple in org.apache.pig |
---|
Methods in org.apache.pig that return Tuple | |
---|---|
Tuple |
LoadCaster.bytesToTuple(byte[] b,
ResourceSchema.ResourceFieldSchema fieldSchema)
Cast data from bytearray to tuple value. |
Tuple |
StreamToPig.deserialize(byte[] bytes)
Deprecated. Given a byte array from a streaming executable, produce a tuple. |
Tuple |
PigStreamingBase.deserialize(byte[] bytes)
Deprecated. |
abstract Tuple |
PigStreamingBase.deserialize(byte[] bytes,
int offset,
int length)
Given a byte array from a streaming executable, produce a tuple. |
Tuple |
LoadFuncWrapper.getNext()
|
abstract Tuple |
LoadFunc.getNext()
Retrieves the next tuple to be processed. |
Methods in org.apache.pig that return types with arguments of type Tuple | |
---|---|
Iterator<Tuple> |
PigServer.openIterator(String id)
Executes a Pig Latin script up to and including indicated alias. |
Methods in org.apache.pig with parameters of type Tuple | |
---|---|
void |
IteratingAccumulatorEvalFunc.accumulate(Tuple input)
|
void |
AlgebraicEvalFunc.accumulate(Tuple input)
This is the free accumulate implementation based on the static classes provided by the Algebraic static classes. |
abstract void |
AccumulatorEvalFunc.accumulate(Tuple b)
|
void |
Accumulator.accumulate(Tuple b)
Pass tuples to the UDF. |
abstract int |
ComparisonFunc.compare(Tuple t1,
Tuple t2)
Deprecated. This callback method must be implemented by all subclasses. |
OUT |
PrimitiveEvalFunc.exec(Tuple tuple)
|
abstract T |
EvalFunc.exec(Tuple input)
This callback method must be implemented by all subclasses. |
T |
AccumulatorEvalFunc.exec(Tuple input)
|
void |
StoreFuncWrapper.putNext(Tuple tuple)
|
void |
StoreFuncInterface.putNext(Tuple t)
Write a tuple to the data store. |
abstract void |
StoreFunc.putNext(Tuple t)
Write a tuple to the data store. |
void |
IndexableLoadFunc.seekNear(Tuple keys)
This method is called by the Pig runtime to indicate to the LoadFunc to position its underlying input stream near the keys supplied as the argument. |
byte[] |
PigToStream.serialize(Tuple t)
Deprecated. Given a tuple, produce an array of bytes to be passed to the streaming executable. |
byte[] |
PigStreamingBase.serialize(Tuple t)
Deprecated. |
abstract WritableByteArray |
PigStreamingBase.serializeToBytes(Tuple t)
Given a tuple, produce an array of bytes to be passed to the streaming executable. |
byte[] |
StoreCaster.toBytes(Tuple t)
|
protected void |
TypedOutputEvalFunc.verifyInput(Tuple input,
int minimumSize)
|
protected static void |
TypedOutputEvalFunc.verifyUdfInput(String klass,
Tuple input,
int minimumSize)
Increment Hadoop counters for bad inputs which are either null or too small. |
Method parameters in org.apache.pig with type arguments of type Tuple | |
---|---|
abstract T |
IteratingAccumulatorEvalFunc.exec(Iterator<Tuple> iter)
|
Uses of Tuple in org.apache.pig.backend.executionengine |
---|
Methods in org.apache.pig.backend.executionengine that return types with arguments of type Tuple | |
---|---|
Iterator<Tuple> |
ExecJob.getResults()
if query has executed successfully we want to retrieve the results via iterating over them. |
Uses of Tuple in org.apache.pig.backend.hadoop.accumulo |
---|
Methods in org.apache.pig.backend.hadoop.accumulo that return Tuple | |
---|---|
Tuple |
AccumuloBinaryConverter.bytesToTuple(byte[] b,
ResourceSchema.ResourceFieldSchema fieldSchema)
NOT IMPLEMENTED |
Tuple |
AbstractAccumuloStorage.getNext()
|
protected Tuple |
AccumuloStorage.getTuple(org.apache.accumulo.core.data.Key key,
org.apache.accumulo.core.data.Value value)
|
protected abstract Tuple |
AbstractAccumuloStorage.getTuple(org.apache.accumulo.core.data.Key key,
org.apache.accumulo.core.data.Value value)
|
Methods in org.apache.pig.backend.hadoop.accumulo with parameters of type Tuple | |
---|---|
protected Collection<org.apache.accumulo.core.data.Mutation> |
AccumuloStorage.getMutations(Tuple tuple)
|
protected abstract Collection<org.apache.accumulo.core.data.Mutation> |
AbstractAccumuloStorage.getMutations(Tuple tuple)
|
void |
AbstractAccumuloStorage.putNext(Tuple tuple)
|
byte[] |
AccumuloBinaryConverter.toBytes(Tuple t)
NOT IMPLEMENTED |
protected byte[] |
AbstractAccumuloStorage.tupleToBytes(Tuple tuple,
int i,
ResourceSchema.ResourceFieldSchema[] fieldSchemas)
|
protected org.apache.hadoop.io.Text |
AbstractAccumuloStorage.tupleToText(Tuple tuple,
int i,
ResourceSchema.ResourceFieldSchema[] fieldSchemas)
|
Uses of Tuple in org.apache.pig.backend.hadoop.executionengine |
---|
Methods in org.apache.pig.backend.hadoop.executionengine that return types with arguments of type Tuple | |
---|---|
Iterator<Tuple> |
HJob.getResults()
|
Uses of Tuple in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer |
---|
Methods in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer that return Tuple | |
---|---|
Tuple |
PigRecordReader.getCurrentValue()
|
Tuple |
MergeJoinIndexer.getNext()
|
Methods in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer that return types with arguments of type Tuple | |
---|---|
org.apache.hadoop.mapreduce.RecordReader<org.apache.hadoop.io.Text,Tuple> |
PigInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit split,
org.apache.hadoop.mapreduce.TaskAttemptContext context)
|
org.apache.hadoop.mapreduce.RecordWriter<org.apache.hadoop.io.WritableComparable,Tuple> |
PigTextOutputFormat.getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext job)
|
org.apache.hadoop.mapreduce.RecordWriter<org.apache.hadoop.io.WritableComparable,Tuple> |
PigOutputFormat.getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext taskattemptcontext)
|
Methods in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer with parameters of type Tuple | |
---|---|
void |
PigMapReduceCounter.PigMapCounter.collect(org.apache.hadoop.mapreduce.Mapper.Context context,
Tuple tuple)
While tuples are collected, they are counted one by one by a global counter per task. |
void |
PigMapOnly.Map.collect(org.apache.hadoop.mapreduce.Mapper.Context oc,
Tuple tuple)
|
void |
PigGenericMapReduce.Map.collect(org.apache.hadoop.mapreduce.Mapper.Context oc,
Tuple tuple)
|
void |
PigGenericMapReduce.MapWithComparator.collect(org.apache.hadoop.mapreduce.Mapper.Context oc,
Tuple tuple)
|
void |
PigGenericMapReduce.MapWithPartitionIndex.collect(org.apache.hadoop.mapreduce.Mapper.Context oc,
Tuple tuple)
|
abstract void |
PigGenericMapBase.collect(org.apache.hadoop.mapreduce.Mapper.Context oc,
Tuple tuple)
|
protected void |
PigGenericMapBase.map(org.apache.hadoop.io.Text key,
Tuple inpTuple,
org.apache.hadoop.mapreduce.Mapper.Context context)
The map function that attaches the inpTuple appropriately and executes the map plan if its not empty. |
void |
PigTextOutputFormat.PigLineRecordWriter.write(org.apache.hadoop.io.WritableComparable key,
Tuple value)
|
void |
PigOutputFormat.PigRecordWriter.write(org.apache.hadoop.io.WritableComparable key,
Tuple value)
We only care about the values, so we are going to skip the keys when we write. |
Uses of Tuple in org.apache.pig.backend.hadoop.executionengine.physicalLayer |
---|
Fields in org.apache.pig.backend.hadoop.executionengine.physicalLayer declared as Tuple | |
---|---|
protected Tuple |
PhysicalOperator.input
|
Methods in org.apache.pig.backend.hadoop.executionengine.physicalLayer with parameters of type Tuple | |
---|---|
void |
PhysicalOperator.attachInput(Tuple t)
Shorts the input path of this operator by providing the input tuple directly |
Uses of Tuple in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators |
---|
Methods in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators that return Tuple | |
---|---|
Tuple |
UnaryComparisonOperator.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POUserFunc.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POUserComparisonFunc.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POProject.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
PONegative.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POMapLookUp.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POCast.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POBinCond.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
ConstantExpression.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
BinaryExpressionOperator.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
BinaryComparisonOperator.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Methods in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators with parameters of type Tuple | |
---|---|
void |
POProject.attachInput(Tuple t)
Overridden since the attachment of the new input should cause the old processing to end. |
void |
POBinCond.attachInput(Tuple t)
|
void |
POUserComparisonFunc.attachInput(Tuple t1,
Tuple t2)
|
Uses of Tuple in org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans |
---|
Methods in org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans with parameters of type Tuple | |
---|---|
void |
PhysicalPlan.attachInput(Tuple t)
|
Uses of Tuple in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators |
---|
Fields in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators declared as Tuple | |
---|---|
protected Tuple[] |
POCross.data
|
protected Tuple |
POForEach.inpTuple
|
protected Tuple |
POLocalRearrange.mFakeTuple
|
protected Tuple |
POCross.tupleOfLastBag
|
Methods in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators that return Tuple | |
---|---|
protected Tuple |
POLocalRearrange.constructLROutput(List<Result> resLst,
List<Result> secondaryResLst,
Tuple value)
|
protected Tuple |
POPreCombinerLocalRearrange.constructLROutput(List<Result> resLst,
Tuple value)
|
protected Tuple |
POCollectedGroup.constructOutput(List<Result> resLst,
Tuple value)
|
protected Tuple |
POForEach.createTuple(Object[] data)
|
Tuple |
POMergeJoin.TuplesToSchemaTupleList.get(int i)
|
Tuple |
Packager.getKeyAsTuple()
|
Tuple |
Packager.getValueTuple(PigNullableWritable keyWritable,
NullableTuple ntup,
int index)
|
Tuple |
MultiQueryPackager.getValueTuple(PigNullableWritable keyWritable,
NullableTuple ntup,
int index)
|
Tuple |
LitePackager.getValueTuple(PigNullableWritable keyWritable,
NullableTuple ntup,
int index)
Makes use of the superclass method, but this requires an additional parameter key passed by ReadOnceBag. |
Tuple |
CombinerPackager.getValueTuple(PigNullableWritable keyWritable,
NullableTuple ntup,
int index)
|
Tuple |
Packager.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POUnion.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POStream.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POStore.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POSplit.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POSort.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POSkewedJoin.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
PORank.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POPreCombinerLocalRearrange.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POPartialAgg.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POPackage.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
PONative.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POMergeJoin.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POMergeCogroup.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POLocalRearrange.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POLoad.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POLimit.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POGlobalRearrange.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POForEach.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POFilter.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POFRJoin.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
PODistinct.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
PODemux.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POCross.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POCounter.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
POCollectedGroup.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
Tuple |
LitePackager.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
|
protected Tuple |
Packager.illustratorMarkup2(Object in,
Object out)
|
protected Tuple |
Packager.starMarkup(Tuple key,
Tuple val,
Tuple out)
|
Methods in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators that return types with arguments of type Tuple | |
---|---|
List<Tuple> |
POMergeJoin.TuplesToSchemaTupleList.getList()
|
Iterator<Tuple> |
AccumulativeTupleBuffer.getTuples(int index)
Get iterator of tuples in the buffer |
Methods in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators with parameters of type Tuple | |
---|---|
boolean |
POMergeJoin.TuplesToSchemaTupleList.add(Tuple t)
|
void |
POPreCombinerLocalRearrange.attachInput(Tuple t)
Overridden since the attachment of the new input should cause the old processing to end. |
void |
POLocalRearrange.attachInput(Tuple t)
Overridden since the attachment of the new input should cause the old processing to end. |
void |
POCollectedGroup.attachInput(Tuple t)
Overridden since the attachment of the new input should cause the old processing to end. |
protected void |
POForEach.attachInputToPlans(Tuple t)
|
int |
POSort.SortComparator.compare(Tuple o1,
Tuple o2)
|
int |
POSort.UDFSortComparator.compare(Tuple t1,
Tuple t2)
|
protected Tuple |
POLocalRearrange.constructLROutput(List<Result> resLst,
List<Result> secondaryResLst,
Tuple value)
|
protected Tuple |
POPreCombinerLocalRearrange.constructLROutput(List<Result> resLst,
Tuple value)
|
protected Tuple |
POCollectedGroup.constructOutput(List<Result> resLst,
Tuple value)
|
protected DataBag |
POPartitionRearrange.constructPROutput(List<Result> resLst,
Tuple value)
|
static SchemaTuple<?> |
POMergeJoin.TuplesToSchemaTupleList.convert(Tuple t,
SchemaTupleFactory tf)
|
Result |
POStream.getNextHelper(Tuple t)
|
protected Tuple |
Packager.starMarkup(Tuple key,
Tuple val,
Tuple out)
|
Constructors in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators with parameters of type Tuple | |
---|---|
POFRJoin(OperatorKey k,
int rp,
List<PhysicalOperator> inp,
List<List<PhysicalPlan>> ppLists,
List<List<Byte>> keyTypes,
FileSpec[] replFiles,
int fragment,
boolean isLeftOuter,
Tuple nullTuple)
|
|
POFRJoin(OperatorKey k,
int rp,
List<PhysicalOperator> inp,
List<List<PhysicalPlan>> ppLists,
List<List<Byte>> keyTypes,
FileSpec[] replFiles,
int fragment,
boolean isLeftOuter,
Tuple nullTuple,
Schema[] inputSchemas,
Schema[] keySchemas)
|
Uses of Tuple in org.apache.pig.backend.hadoop.executionengine.physicalLayer.util |
---|
Methods in org.apache.pig.backend.hadoop.executionengine.physicalLayer.util with parameters of type Tuple | |
---|---|
Object |
MonitoredUDFExecutor.monitorExec(Tuple input)
|
Uses of Tuple in org.apache.pig.backend.hadoop.hbase |
---|
Methods in org.apache.pig.backend.hadoop.hbase that return Tuple | |
---|---|
Tuple |
HBaseBinaryConverter.bytesToTuple(byte[] b,
ResourceSchema.ResourceFieldSchema fieldSchema)
NOT IMPLEMENTED |
Tuple |
HBaseStorage.getNext()
|
Methods in org.apache.pig.backend.hadoop.hbase with parameters of type Tuple | |
---|---|
void |
HBaseStorage.putNext(Tuple t)
|
byte[] |
HBaseBinaryConverter.toBytes(Tuple t)
NOT IMPLEMENTED |
Uses of Tuple in org.apache.pig.builtin |
---|
Methods in org.apache.pig.builtin that return Tuple | |
---|---|
Tuple |
Utf8StorageConverter.bytesToTuple(byte[] b,
ResourceSchema.ResourceFieldSchema fieldSchema)
|
Tuple |
TextLoader.bytesToTuple(byte[] b,
ResourceSchema.ResourceFieldSchema schema)
TextLoader does not support conversion to Tuple |
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 |
Tuple |
PigStreaming.deserialize(byte[] bytes,
int offset,
int length)
|
Tuple |
TOTUPLE.exec(Tuple input)
|
Tuple |
TOP.Initial.exec(Tuple tuple)
|
Tuple |
TOP.Intermed.exec(Tuple input)
|
Tuple |
StringMin.Initial.exec(Tuple input)
|
Tuple |
StringMin.Intermediate.exec(Tuple input)
|
Tuple |
StringMax.Initial.exec(Tuple input)
|
Tuple |
StringMax.Intermediate.exec(Tuple input)
|
Tuple |
STRSPLIT.exec(Tuple input)
Wrapper around Java's String.split |
Tuple |
REGEX_EXTRACT_ALL.exec(Tuple input)
|
Tuple |
PluckTuple.exec(Tuple input)
|
Tuple |
LongAvg.Initial.exec(Tuple input)
|
Tuple |
LongAvg.Intermediate.exec(Tuple input)
|
Tuple |
IntAvg.Initial.exec(Tuple input)
|
Tuple |
IntAvg.Intermediate.exec(Tuple input)
|
Tuple |
FloatAvg.Initial.exec(Tuple input)
|
Tuple |
FloatAvg.Intermediate.exec(Tuple input)
|
Tuple |
DoubleAvg.Initial.exec(Tuple input)
|
Tuple |
DoubleAvg.Intermediate.exec(Tuple input)
|
Tuple |
Distinct.Initial.exec(Tuple input)
|
Tuple |
Distinct.Intermediate.exec(Tuple input)
|
Tuple |
DateTimeMin.Initial.exec(Tuple input)
|
Tuple |
DateTimeMin.Intermediate.exec(Tuple input)
|
Tuple |
DateTimeMax.Initial.exec(Tuple input)
|
Tuple |
DateTimeMax.Intermediate.exec(Tuple input)
|
Tuple |
COV.Initial.exec(Tuple input)
|
Tuple |
COV.Intermed.exec(Tuple input)
|
Tuple |
COUNT_STAR.Initial.exec(Tuple input)
|
Tuple |
COUNT_STAR.Intermediate.exec(Tuple input)
|
Tuple |
COUNT.Initial.exec(Tuple input)
|
Tuple |
COUNT.Intermediate.exec(Tuple input)
|
Tuple |
COR.Initial.exec(Tuple input)
|
Tuple |
COR.Intermed.exec(Tuple input)
|
Tuple |
BuildBloom.Initial.exec(Tuple input)
|
Tuple |
BuildBloom.Intermediate.exec(Tuple input)
|
Tuple |
BigIntegerAvg.Initial.exec(Tuple input)
|
Tuple |
BigIntegerAvg.Intermediate.exec(Tuple input)
|
Tuple |
BigDecimalAvg.Initial.exec(Tuple input)
|
Tuple |
BigDecimalAvg.Intermediate.exec(Tuple input)
|
Tuple |
BagToTuple.exec(Tuple inputTuple)
|
Tuple |
AlgebraicLongMathBase.Intermediate.exec(Tuple input)
|
Tuple |
AlgebraicIntMathBase.Intermediate.exec(Tuple input)
|
Tuple |
AlgebraicFloatMathBase.Intermediate.exec(Tuple input)
|
Tuple |
AlgebraicDoubleMathBase.Intermediate.exec(Tuple input)
|
Tuple |
AlgebraicByteArrayMathBase.Intermediate.exec(Tuple input)
|
Tuple |
AlgebraicByteArrayMathBase.Initial.exec(Tuple input)
|
Tuple |
AlgebraicBigIntegerMathBase.Intermediate.exec(Tuple input)
|
Tuple |
AlgebraicBigDecimalMathBase.Intermediate.exec(Tuple input)
|
Tuple |
AVG.Initial.exec(Tuple input)
|
Tuple |
AVG.Intermediate.exec(Tuple input)
|
Tuple |
TextLoader.getNext()
|
Tuple |
PigStorage.getNext()
|
Tuple |
JsonLoader.getNext()
|
Tuple |
BinStorage.getNext()
|
Tuple |
AvroStorage.getNext()
|
Methods in org.apache.pig.builtin with parameters of type Tuple | |
---|---|
void |
StringMin.accumulate(Tuple b)
|
void |
StringMax.accumulate(Tuple b)
|
void |
LongAvg.accumulate(Tuple b)
|
void |
IntAvg.accumulate(Tuple b)
|
void |
FloatAvg.accumulate(Tuple b)
|
void |
DoubleAvg.accumulate(Tuple b)
|
void |
DateTimeMin.accumulate(Tuple b)
|
void |
DateTimeMax.accumulate(Tuple b)
|
void |
COUNT_STAR.accumulate(Tuple b)
|
void |
COUNT.accumulate(Tuple b)
|
void |
BigIntegerAvg.accumulate(Tuple b)
|
void |
BigDecimalAvg.accumulate(Tuple b)
|
void |
AlgebraicLongMathBase.accumulate(Tuple b)
|
void |
AlgebraicIntMathBase.accumulate(Tuple b)
|
void |
AlgebraicFloatMathBase.accumulate(Tuple b)
|
void |
AlgebraicDoubleMathBase.accumulate(Tuple b)
|
void |
AlgebraicByteArrayMathBase.accumulate(Tuple b)
|
void |
AlgebraicBigIntegerMathBase.accumulate(Tuple b)
|
void |
AlgebraicBigDecimalMathBase.accumulate(Tuple b)
|
void |
AVG.accumulate(Tuple b)
|
protected DataByteArray |
BuildBloomBase.bloomOr(Tuple input)
|
static void |
CubeDimensions.convertNullToUnknown(Tuple tuple)
|
protected static long |
LongAvg.count(Tuple input)
|
protected static long |
IntAvg.count(Tuple input)
|
protected static long |
FloatAvg.count(Tuple input)
|
protected static long |
DoubleAvg.count(Tuple input)
|
protected static BigInteger |
BigIntegerAvg.count(Tuple input)
|
protected static BigDecimal |
BigDecimalAvg.count(Tuple input)
|
protected static long |
AVG.count(Tuple input)
|
protected static Long |
AlgebraicLongMathBase.doTupleWork(Tuple input,
AlgebraicMathBase.KnownOpProvider opProvider)
|
protected static Integer |
AlgebraicIntMathBase.doTupleWork(Tuple input,
AlgebraicMathBase.KnownOpProvider opProvider)
|
protected static Float |
AlgebraicFloatMathBase.doTupleWork(Tuple input,
AlgebraicMathBase.KnownOpProvider opProvider)
|
protected static Double |
AlgebraicDoubleMathBase.doTupleWork(Tuple input,
AlgebraicMathBase.KnownOpProvider opProvider)
|
protected static BigInteger |
AlgebraicBigIntegerMathBase.doTupleWork(Tuple input,
AlgebraicMathBase.KnownOpProvider opProvider)
|
protected static BigDecimal |
AlgebraicBigDecimalMathBase.doTupleWork(Tuple input,
AlgebraicMathBase.KnownOpProvider opProvider)
|
protected static Double |
AlgebraicByteArrayMathBase.doTupleWork(Tuple input,
AlgebraicMathBase.KnownOpProvider opProvider,
byte expectedType)
|
Object |
InvokerFunction.eval(Tuple input)
|
Long |
YearsBetween.exec(Tuple input)
|
Long |
WeeksBetween.exec(Tuple input)
|
DataBag |
VALUESET.exec(Tuple input)
|
DataBag |
VALUELIST.exec(Tuple input)
|
String |
UPPER.exec(Tuple input)
Upper-cases an input string. |
String |
UCFIRST.exec(Tuple input)
|
Long |
TupleSize.exec(Tuple input)
|
Long |
ToUnixTime.exec(Tuple input)
|
String |
ToString.exec(Tuple input)
|
Long |
ToMilliSeconds.exec(Tuple input)
|
org.joda.time.DateTime |
ToDateISO.exec(Tuple input)
|
org.joda.time.DateTime |
ToDate3ARGS.exec(Tuple input)
|
org.joda.time.DateTime |
ToDate2ARGS.exec(Tuple input)
|
org.joda.time.DateTime |
ToDate.exec(Tuple input)
|
String |
TRIM.exec(Tuple input)
|
Tuple |
TOTUPLE.exec(Tuple input)
|
DataBag |
TOP.exec(Tuple tuple)
|
Tuple |
TOP.Initial.exec(Tuple tuple)
|
Tuple |
TOP.Intermed.exec(Tuple input)
|
DataBag |
TOP.Final.exec(Tuple tuple)
|
Map |
TOMAP.exec(Tuple input)
|
DataBag |
TOKENIZE.exec(Tuple input)
|
DataBag |
TOBAG.exec(Tuple input)
|
org.joda.time.DateTime |
SubtractDuration.exec(Tuple input)
|
Long |
StringSize.exec(Tuple input)
|
String |
StringMin.exec(Tuple input)
|
Tuple |
StringMin.Initial.exec(Tuple input)
|
Tuple |
StringMin.Intermediate.exec(Tuple input)
|
String |
StringMin.Final.exec(Tuple input)
|
String |
StringMax.exec(Tuple input)
|
Tuple |
StringMax.Initial.exec(Tuple input)
|
Tuple |
StringMax.Intermediate.exec(Tuple input)
|
String |
StringMax.Final.exec(Tuple input)
|
String |
StringConcat.exec(Tuple input)
|
Long |
SecondsBetween.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. |
String |
SUBSTRING.exec(Tuple input)
Method invoked on every tuple during foreach evaluation |
Tuple |
STRSPLIT.exec(Tuple input)
Wrapper around Java's String.split |
Boolean |
STARTSWITH.exec(Tuple tuple)
|
Long |
SIZE.exec(Tuple input)
|
DataBag |
RollupDimensions.exec(Tuple tuple)
|
String |
RTRIM.exec(Tuple input)
|
Double |
ROUND_TO.exec(Tuple input)
java level API |
Long |
ROUND.exec(Tuple input)
java level API |
String |
REPLACE.exec(Tuple input)
Method invoked on every tuple during foreach evaluation |
Tuple |
REGEX_EXTRACT_ALL.exec(Tuple input)
|
String |
REGEX_EXTRACT.exec(Tuple input)
|
Double |
RANDOM.exec(Tuple input)
|
Tuple |
PluckTuple.exec(Tuple input)
|
Long |
MonthsBetween.exec(Tuple input)
|
Long |
MinutesBetween.exec(Tuple input)
|
Long |
MilliSecondsBetween.exec(Tuple input)
|
Long |
MapSize.exec(Tuple input)
|
Double |
LongAvg.exec(Tuple input)
|
Tuple |
LongAvg.Initial.exec(Tuple input)
|
Tuple |
LongAvg.Intermediate.exec(Tuple input)
|
Double |
LongAvg.Final.exec(Tuple input)
|
Long |
LongAbs.exec(Tuple input)
java level API |
String |
LTRIM.exec(Tuple input)
|
String |
LOWER.exec(Tuple input)
Method invoked on every tuple during foreach evaluation |
String |
LCFIRST.exec(Tuple input)
|
Integer |
LAST_INDEX_OF.exec(Tuple input)
Finds the last location of a substring in a given string. |
DataBag |
KEYSET.exec(Tuple input)
|
Boolean |
IsEmpty.exec(Tuple input)
|
Object |
InvokerGenerator.exec(Tuple input)
|
Double |
IntAvg.exec(Tuple input)
|
Tuple |
IntAvg.Initial.exec(Tuple input)
|
Tuple |
IntAvg.Intermediate.exec(Tuple input)
|
Double |
IntAvg.Final.exec(Tuple input)
|
Integer |
IntAbs.exec(Tuple input)
java level API |
Map |
INVERSEMAP.exec(Tuple input)
|
Integer |
INDEXOF.exec(Tuple input)
Method invoked on every tuple during foreach evaluation |
Long |
HoursBetween.exec(Tuple input)
|
Integer |
GetYear.exec(Tuple input)
|
Integer |
GetWeekYear.exec(Tuple input)
|
Integer |
GetWeek.exec(Tuple input)
|
Integer |
GetSecond.exec(Tuple input)
|
Integer |
GetMonth.exec(Tuple input)
|
Integer |
GetMinute.exec(Tuple input)
|
Integer |
GetMilliSecond.exec(Tuple input)
|
Integer |
GetHour.exec(Tuple input)
|
Integer |
GetDay.exec(Tuple input)
|
T |
GenericInvoker.exec(Tuple input)
|
Float |
FloatRoundTo.exec(Tuple input)
java level API |
Integer |
FloatRound.exec(Tuple input)
java level API |
Double |
FloatAvg.exec(Tuple input)
|
Tuple |
FloatAvg.Initial.exec(Tuple input)
|
Tuple |
FloatAvg.Intermediate.exec(Tuple input)
|
Double |
FloatAvg.Final.exec(Tuple input)
|
Float |
FloatAbs.exec(Tuple input)
java level API |
Boolean |
EqualsIgnoreCase.exec(Tuple input)
|
Boolean |
ENDSWITH.exec(Tuple tuple)
|
Double |
DoubleRoundTo.exec(Tuple input)
java level API |
Long |
DoubleRound.exec(Tuple input)
java level API |
Double |
DoubleBase.exec(Tuple input)
java level API |
Double |
DoubleAvg.exec(Tuple input)
|
Tuple |
DoubleAvg.Initial.exec(Tuple input)
|
Tuple |
DoubleAvg.Intermediate.exec(Tuple input)
|
Double |
DoubleAvg.Final.exec(Tuple input)
|
DataBag |
Distinct.exec(Tuple input)
|
Tuple |
Distinct.Initial.exec(Tuple input)
|
Tuple |
Distinct.Intermediate.exec(Tuple input)
|
DataBag |
Distinct.Final.exec(Tuple input)
|
Long |
DaysBetween.exec(Tuple input)
|
org.joda.time.DateTime |
DateTimeMin.exec(Tuple input)
|
Tuple |
DateTimeMin.Initial.exec(Tuple input)
|
Tuple |
DateTimeMin.Intermediate.exec(Tuple input)
|
org.joda.time.DateTime |
DateTimeMin.Final.exec(Tuple input)
|
org.joda.time.DateTime |
DateTimeMax.exec(Tuple input)
|
Tuple |
DateTimeMax.Initial.exec(Tuple input)
|
Tuple |
DateTimeMax.Intermediate.exec(Tuple input)
|
org.joda.time.DateTime |
DateTimeMax.Final.exec(Tuple input)
|
DataBag |
DIFF.exec(Tuple input)
Compares a tuple with two fields. |
org.joda.time.DateTime |
CurrentTime.exec(Tuple input)
|
DataBag |
CubeDimensions.exec(Tuple tuple)
|
Long |
ConstantSize.exec(Tuple input)
|
DataBag |
COV.exec(Tuple input)
Function to compute covariance between data sets. |
Tuple |
COV.Initial.exec(Tuple input)
|
Tuple |
COV.Intermed.exec(Tuple input)
|
DataBag |
COV.Final.exec(Tuple input)
|
Long |
COUNT_STAR.exec(Tuple input)
|
Tuple |
COUNT_STAR.Initial.exec(Tuple input)
|
Tuple |
COUNT_STAR.Intermediate.exec(Tuple input)
|
Long |
COUNT_STAR.Final.exec(Tuple input)
|
Long |
COUNT.exec(Tuple input)
|
Tuple |
COUNT.Initial.exec(Tuple input)
|
Tuple |
COUNT.Intermediate.exec(Tuple input)
|
Long |
COUNT.Final.exec(Tuple input)
|
DataBag |
COR.exec(Tuple input)
Function to compute correlation between data sets. |
Tuple |
COR.Initial.exec(Tuple input)
|
Tuple |
COR.Intermed.exec(Tuple input)
|
DataBag |
COR.Final.exec(Tuple input)
|
DataByteArray |
CONCAT.exec(Tuple input)
|
DataByteArray |
BuildBloom.exec(Tuple input)
|
Tuple |
BuildBloom.Initial.exec(Tuple input)
|
Tuple |
BuildBloom.Intermediate.exec(Tuple input)
|
DataByteArray |
BuildBloom.Final.exec(Tuple input)
|
Boolean |
Bloom.exec(Tuple input)
|
BigDecimal |
BigIntegerAvg.exec(Tuple input)
|
Tuple |
BigIntegerAvg.Initial.exec(Tuple input)
|
Tuple |
BigIntegerAvg.Intermediate.exec(Tuple input)
|
BigDecimal |
BigIntegerAvg.Final.exec(Tuple input)
|
BigInteger |
BigIntegerAbs.exec(Tuple input)
|
BigDecimal |
BigDecimalAvg.exec(Tuple input)
|
Tuple |
BigDecimalAvg.Initial.exec(Tuple input)
|
Tuple |
BigDecimalAvg.Intermediate.exec(Tuple input)
|
BigDecimal |
BigDecimalAvg.Final.exec(Tuple input)
|
BigDecimal |
BigDecimalAbs.exec(Tuple input)
|
Tuple |
BagToTuple.exec(Tuple inputTuple)
|
String |
BagToString.exec(Tuple inputTuple)
|
Long |
BagSize.exec(Tuple input)
|
Boolean |
Assert.exec(Tuple tuple)
|
Long |
AlgebraicLongMathBase.exec(Tuple input)
|
Tuple |
AlgebraicLongMathBase.Intermediate.exec(Tuple input)
|
Long |
AlgebraicLongMathBase.Final.exec(Tuple input)
|
Integer |
AlgebraicIntMathBase.exec(Tuple input)
|
Tuple |
AlgebraicIntMathBase.Intermediate.exec(Tuple input)
|
Integer |
AlgebraicIntMathBase.Final.exec(Tuple input)
|
Float |
AlgebraicFloatMathBase.exec(Tuple input)
|
Tuple |
AlgebraicFloatMathBase.Intermediate.exec(Tuple input)
|
Float |
AlgebraicFloatMathBase.Final.exec(Tuple input)
|
Double |
AlgebraicDoubleMathBase.exec(Tuple input)
|
Tuple |
AlgebraicDoubleMathBase.Intermediate.exec(Tuple input)
|
Double |
AlgebraicDoubleMathBase.Final.exec(Tuple input)
|
Double |
AlgebraicByteArrayMathBase.exec(Tuple input)
|
Tuple |
AlgebraicByteArrayMathBase.Intermediate.exec(Tuple input)
|
Tuple |
AlgebraicByteArrayMathBase.Initial.exec(Tuple input)
|
Double |
AlgebraicByteArrayMathBase.Final.exec(Tuple input)
|
BigInteger |
AlgebraicBigIntegerMathBase.exec(Tuple input)
|
Tuple |
AlgebraicBigIntegerMathBase.Intermediate.exec(Tuple input)
|
BigInteger |
AlgebraicBigIntegerMathBase.Final.exec(Tuple input)
|
BigDecimal |
AlgebraicBigDecimalMathBase.exec(Tuple input)
|
Tuple |
AlgebraicBigDecimalMathBase.Intermediate.exec(Tuple input)
|
BigDecimal |
AlgebraicBigDecimalMathBase.Final.exec(Tuple input)
|
org.joda.time.DateTime |
AddDuration.exec(Tuple input)
|
Double |
AVG.exec(Tuple input)
|
Tuple |
AVG.Initial.exec(Tuple input)
|
Tuple |
AVG.Intermediate.exec(Tuple input)
|
Double |
AVG.Final.exec(Tuple input)
|
Integer |
ARITY.exec(Tuple input)
Deprecated. |
Double |
ABS.exec(Tuple input)
java level API |
protected DataBag |
Distinct.getDistinct(Tuple input)
|
T |
Invoker.invoke(Tuple input)
|
protected static String |
StringMax.max(Tuple input)
|
protected static org.joda.time.DateTime |
DateTimeMax.max(Tuple input)
|
protected static String |
StringMin.min(Tuple input)
|
protected static org.joda.time.DateTime |
DateTimeMin.min(Tuple input)
|
void |
PigStorage.putNext(Tuple f)
|
void |
JsonStorage.putNext(Tuple t)
|
void |
BinStorage.putNext(Tuple t)
|
void |
AvroStorage.putNext(Tuple t)
|
WritableByteArray |
PigStreaming.serializeToBytes(Tuple t)
|
protected static Long |
LongAvg.sum(Tuple input)
|
protected static Long |
IntAvg.sum(Tuple input)
|
protected static Double |
FloatAvg.sum(Tuple input)
|
protected static Double |
DoubleAvg.sum(Tuple input)
|
protected static Long |
COUNT_STAR.sum(Tuple input)
|
protected static Long |
COUNT.sum(Tuple input)
|
protected static BigInteger |
BigIntegerAvg.sum(Tuple input)
|
protected static BigDecimal |
BigDecimalAvg.sum(Tuple input)
|
protected static Double |
AVG.sum(Tuple input)
|
byte[] |
Utf8StorageConverter.toBytes(Tuple t)
|
byte[] |
TextLoader.toBytes(Tuple t)
|
byte[] |
BinStorage.toBytes(Tuple t)
|
Method parameters in org.apache.pig.builtin with type arguments of type Tuple | |
---|---|
protected static void |
TOP.updateTop(PriorityQueue<Tuple> store,
int limit,
DataBag inputBag)
|
Uses of Tuple in org.apache.pig.builtin.mock |
---|
Methods in org.apache.pig.builtin.mock that return Tuple | |
---|---|
Tuple |
Storage.getNext()
|
static Tuple |
Storage.tuple(Object... objects)
|
Methods in org.apache.pig.builtin.mock that return types with arguments of type Tuple | |
---|---|
List<Tuple> |
Storage.Data.get(String location)
|
Methods in org.apache.pig.builtin.mock with parameters of type Tuple | |
---|---|
static DataBag |
Storage.bag(Tuple... tuples)
|
void |
Storage.putNext(Tuple t)
|
void |
Storage.Data.set(String location,
Schema schema,
Tuple... data)
to set the data in a location with a known schema |
void |
Storage.Data.set(String location,
String schema,
Tuple... data)
to set the data in a location with a known schema |
void |
Storage.Data.set(String location,
Tuple... data)
to set the data in a location |
Method parameters in org.apache.pig.builtin.mock with type arguments of type Tuple | |
---|---|
void |
Storage.Data.set(String location,
Collection<Tuple> data)
to set the data in a location |
void |
Storage.Data.set(String location,
Schema schema,
Collection<Tuple> data)
to set the data in a location with a known schema |
void |
Storage.Data.set(String location,
String schema,
Collection<Tuple> data)
to set the data in a location with a known schema |
Uses of Tuple in org.apache.pig.data |
---|
Classes in org.apache.pig.data with type parameters of type Tuple | |
---|---|
interface |
TupleMaker<A extends Tuple>
|
Subinterfaces of Tuple in org.apache.pig.data | |
---|---|
interface |
TypeAwareTuple
|
Classes in org.apache.pig.data that implement Tuple | |
---|---|
class |
AbstractTuple
This class provides a convenient base for Tuple implementations. |
class |
AmendableTuple
|
class |
AppendableSchemaTuple<T extends AppendableSchemaTuple<T>>
|
class |
BinSedesTuple
This tuple has a faster (de)serialization mechanism. |
static class |
DefaultAbstractBag.BagDelimiterTuple
|
static class |
DefaultAbstractBag.EndBag
|
static class |
DefaultAbstractBag.StartBag
|
class |
DefaultTuple
A default implementation of Tuple. |
class |
SchemaTuple<T extends SchemaTuple<T>>
A SchemaTuple is a type aware tuple that is much faster and more memory efficient. |
class |
TargetedTuple
A tuple composed with the operators to which it needs be attached |
class |
TimestampedTuple
|
Fields in org.apache.pig.data declared as Tuple | |
---|---|
static Tuple |
DefaultAbstractBag.endBag
|
static Tuple |
DefaultAbstractBag.startBag
|
Fields in org.apache.pig.data with type parameters of type Tuple | |
---|---|
protected Collection<Tuple> |
DefaultAbstractBag.mContents
|
Methods in org.apache.pig.data that return Tuple | |
---|---|
protected Tuple |
SchemaTuple.box(Tuple t)
|
static Tuple |
DataReaderWriter.bytesToTuple(DataInput in)
|
protected abstract Tuple |
SchemaTuple.generatedCodeGetTuple(int fieldNum)
|
Tuple |
AppendableSchemaTuple.getAppendedFields()
|
Tuple |
TypeAwareTuple.getTuple(int idx)
|
Tuple |
SchemaTuple.getTuple(int fieldNum)
|
abstract Tuple |
TupleFactory.newTuple()
Create an empty tuple. |
Tuple |
BinSedesTupleFactory.newTuple()
|
abstract Tuple |
TupleFactory.newTuple(int size)
Create a tuple with size fields. |
Tuple |
BinSedesTupleFactory.newTuple(int size)
|
abstract Tuple |
TupleFactory.newTuple(List c)
Create a tuple from the provided list of objects. |
Tuple |
BinSedesTupleFactory.newTuple(List c)
|
abstract Tuple |
TupleFactory.newTuple(Object datum)
Create a tuple with a single element. |
Tuple |
BinSedesTupleFactory.newTuple(Object datum)
|
abstract Tuple |
TupleFactory.newTupleNoCopy(List list)
Create a tuple from a provided list of objects, keeping the provided list. |
Tuple |
BinSedesTupleFactory.newTupleNoCopy(List list)
|
Tuple |
ReadOnceBag.ReadOnceBagIterator.next()
|
Tuple |
BinInterSedes.readTuple(DataInput in)
|
Tuple |
BinInterSedes.readTuple(DataInput in,
byte type)
|
protected Tuple |
SchemaTuple.returnUnlessNull(boolean isNull,
Tuple val)
|
Tuple |
TargetedTuple.toTuple()
|
static Tuple |
DataType.toTuple(Object o)
If this object is a tuple, return it as a tuple. |
protected Tuple |
SchemaTuple.unbox(Object v,
Tuple t)
|
protected Tuple |
SchemaTuple.unboxTuple(Object val)
|
Methods in org.apache.pig.data that return types with arguments of type Tuple | |
---|---|
Iterator<Tuple> |
SortedDataBag.iterator()
|
Iterator<Tuple> |
SingleTupleBag.iterator()
|
Iterator<Tuple> |
ReadOnceBag.iterator()
|
Iterator<Tuple> |
NonSpillableDataBag.iterator()
|
Iterator<Tuple> |
InternalSortedBag.iterator()
|
Iterator<Tuple> |
InternalDistinctBag.iterator()
|
Iterator<Tuple> |
InternalCachedBag.iterator()
|
Iterator<Tuple> |
DistinctDataBag.iterator()
|
Iterator<Tuple> |
DefaultDataBag.iterator()
|
Iterator<Tuple> |
DataBag.iterator()
Get an iterator to the bag. |
Iterator<Tuple> |
AccumulativeBag.iterator()
|
abstract Class<? extends Tuple> |
TupleFactory.tupleClass()
Return the actual class representing a tuple that the implementing factory will be returning. |
Class<? extends Tuple> |
BinSedesTupleFactory.tupleClass()
|
Methods in org.apache.pig.data with parameters of type Tuple | |
---|---|
void |
SingleTupleBag.add(Tuple t)
|
void |
ReadOnceBag.add(Tuple t)
|
void |
NonSpillableDataBag.add(Tuple t)
|
void |
InternalSortedBag.add(Tuple t)
|
void |
InternalDistinctBag.add(Tuple t)
|
void |
InternalCachedBag.add(Tuple t)
|
void |
DistinctDataBag.add(Tuple t)
|
void |
DefaultAbstractBag.add(Tuple t)
Add a tuple to the bag. |
void |
DataBag.add(Tuple t)
Add a tuple to the bag. |
void |
AccumulativeBag.add(Tuple t)
|
void |
InterSedes.addColsToTuple(DataInput in,
Tuple t)
The type of next object has been determined to be of type Tuple, add the columns that belong to the tuple to given tuple argument t |
void |
BinInterSedes.addColsToTuple(DataInput in,
Tuple t)
|
protected Tuple |
SchemaTuple.box(Tuple t)
|
protected int |
SchemaTuple.compareNull(boolean usNull,
Tuple t,
int pos)
|
protected int |
SchemaTuple.compareSize(Tuple t)
|
int |
SchemaTuple.compareTo(Tuple t)
|
protected int |
SchemaTuple.compareTo(Tuple t,
boolean checkType)
|
protected abstract void |
SchemaTuple.generatedCodeSetTuple(int fieldNum,
Tuple val)
|
protected int |
SchemaTuple.hashCodePiece(int hash,
Tuple v,
boolean isNull)
|
void |
Tuple.reference(Tuple t)
Deprecated. |
void |
TargetedTuple.reference(Tuple t)
|
void |
SchemaTuple.reference(Tuple t)
|
void |
AbstractTuple.reference(Tuple t)
|
protected Tuple |
SchemaTuple.returnUnlessNull(boolean isNull,
Tuple val)
|
SchemaTuple<T> |
SchemaTuple.set(Tuple t)
|
protected SchemaTuple<T> |
SchemaTuple.set(Tuple t,
boolean checkType)
|
void |
SchemaTuple.setAndCatch(Tuple t)
|
protected void |
AppendableSchemaTuple.setAppendedFields(Tuple t)
|
void |
TypeAwareTuple.setTuple(int idx,
Tuple val)
|
void |
SchemaTuple.setTuple(int fieldNum,
Tuple val)
|
static void |
DataType.spillTupleContents(Tuple t,
String label)
Purely for debugging |
protected Tuple |
SchemaTuple.unbox(Object v,
Tuple t)
|
Method parameters in org.apache.pig.data with type arguments of type Tuple | |
---|---|
void |
DefaultAbstractBag.addAll(Collection<Tuple> c)
|
void |
DefaultAbstractBag.addAll(Iterable<Tuple> iterable)
Add contents of an iterable (a collection or a DataBag) |
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.newSortedBag(Comparator<Tuple> comp)
Get a sorted data bag. |
abstract DataBag |
BagFactory.newSortedBag(Comparator<Tuple> comp)
Get a sorted data bag. |
long |
SortedSpillBag.proactive_spill(Comparator<Tuple> comp)
Sort contents of mContents and write them to disk |
long |
InternalSortedBag.proactive_spill(Comparator<Tuple> comp)
|
Constructors in org.apache.pig.data with parameters of type Tuple | |
---|---|
SingleTupleBag(Tuple t)
|
|
TargetedTuple(Tuple t,
List<OperatorKey> targetOps)
|
Constructor parameters in org.apache.pig.data with type arguments of type Tuple | |
---|---|
DefaultDataBag(List<Tuple> listOfTuples)
This constructor creates a bag out of an existing list of tuples by taking ownership of the list and NOT copying the contents of the list. |
|
InternalSortedBag(Comparator<Tuple> comp)
|
|
InternalSortedBag(int bagCount,
Comparator<Tuple> comp)
|
|
InternalSortedBag(int bagCount,
float percent,
Comparator<Tuple> comp)
|
|
NonSpillableDataBag(List<Tuple> listOfTuples)
This constructor creates a bag out of an existing list of tuples by taking ownership of the list and NOT copying the contents of the list. |
|
SortedDataBag(Comparator<Tuple> comp)
|
Uses of Tuple in org.apache.pig.data.utils |
---|
Methods in org.apache.pig.data.utils that return Tuple | |
---|---|
static Tuple |
SedesHelper.readGenericTuple(DataInput in,
byte type)
|
Methods in org.apache.pig.data.utils with parameters of type Tuple | |
---|---|
static void |
SedesHelper.writeGenericTuple(DataOutput out,
Tuple t)
|
Uses of Tuple in org.apache.pig.impl.builtin |
---|
Methods in org.apache.pig.impl.builtin that return Tuple | |
---|---|
Tuple |
GetMemNumRows.exec(Tuple in)
|
Tuple |
RandomSampleLoader.getNext()
Allocate a buffer for numSamples elements, populate it with the first numSamples tuples, and continue scanning rest of the input. |
Tuple |
PoissonSampleLoader.getNext()
|
Tuple |
DefaultIndexableLoader.getNext()
|
Methods in org.apache.pig.impl.builtin with parameters of type Tuple | |
---|---|
Object |
StreamingUDF.exec(Tuple input)
|
Object |
ReadScalars.exec(Tuple input)
Java level API |
Map<String,Object> |
PartitionSkewedKeys.exec(Tuple in)
first field in the input tuple is the number of reducers second field is the *sorted* bag of samples this should be called only once |
Object |
IdentityColumn.exec(Tuple input)
|
Tuple |
GetMemNumRows.exec(Tuple in)
|
DataBag |
GFReplicate.exec(Tuple input)
|
DataBag |
GFCross.exec(Tuple input)
|
Integer |
GFAny.exec(Tuple input)
|
Map<String,Object> |
FindQuantiles.exec(Tuple in)
first field in the input tuple is the number of quantiles to generate second field is the *sorted* bag of samples |
void |
DefaultIndexableLoader.seekNear(Tuple keys)
|
Uses of Tuple in org.apache.pig.impl.io |
---|
Methods in org.apache.pig.impl.io that return Tuple | |
---|---|
Tuple |
TFileRecordReader.getCurrentValue()
|
Tuple |
InterRecordReader.getCurrentValue()
|
Tuple |
BinStorageRecordReader.getCurrentValue()
|
Tuple |
TFileStorage.getNext()
|
Tuple |
SequenceFileInterStorage.getNext()
|
Tuple |
ReadToEndLoader.getNext()
|
Tuple |
InterStorage.getNext()
|
Methods in org.apache.pig.impl.io that return types with arguments of type Tuple | |
---|---|
org.apache.hadoop.mapreduce.RecordReader<org.apache.hadoop.io.Text,Tuple> |
TFileStorage.TFileInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit split,
org.apache.hadoop.mapreduce.TaskAttemptContext context)
|
org.apache.hadoop.mapreduce.RecordReader<org.apache.hadoop.io.Text,Tuple> |
InterStorage.InterInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit split,
org.apache.hadoop.mapreduce.TaskAttemptContext context)
|
org.apache.hadoop.mapreduce.RecordReader<org.apache.hadoop.io.Text,Tuple> |
BinStorageInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit split,
org.apache.hadoop.mapreduce.TaskAttemptContext context)
|
org.apache.hadoop.mapreduce.RecordWriter<org.apache.hadoop.io.WritableComparable,Tuple> |
TFileStorage.TFileOutputFormat.getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext job)
|
org.apache.hadoop.mapreduce.RecordWriter<org.apache.hadoop.io.WritableComparable,Tuple> |
InterStorage.InterOutputFormat.getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext job)
|
org.apache.hadoop.mapreduce.RecordWriter<org.apache.hadoop.io.WritableComparable,Tuple> |
BinStorageOutputFormat.getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext job)
|
Methods in org.apache.pig.impl.io with parameters of type Tuple | |
---|---|
void |
TFileStorage.putNext(Tuple t)
|
void |
SequenceFileInterStorage.putNext(Tuple t)
|
void |
InterStorage.putNext(Tuple t)
|
void |
TFileRecordWriter.write(org.apache.hadoop.io.WritableComparable wc,
Tuple t)
|
void |
InterRecordWriter.write(org.apache.hadoop.io.WritableComparable wc,
Tuple t)
|
void |
BinStorageRecordWriter.write(org.apache.hadoop.io.WritableComparable wc,
Tuple t)
|
Constructors in org.apache.pig.impl.io with parameters of type Tuple | |
---|---|
NullableTuple(Tuple t)
|
Uses of Tuple in org.apache.pig.impl.streaming |
---|
Methods in org.apache.pig.impl.streaming that return Tuple | |
---|---|
Tuple |
PigStreamingUDF.deserialize(byte[] bytes,
int offset,
int length)
|
Tuple |
OutputHandler.getNext()
Get the next output Tuple of the managed process. |
Methods in org.apache.pig.impl.streaming with parameters of type Tuple | |
---|---|
void |
InputHandler.putNext(Tuple t)
Send the given input Tuple to the managed executable. |
WritableByteArray |
PigStreamingUDF.serializeToBytes(Tuple t)
|
Uses of Tuple in org.apache.pig.impl.util |
---|
Methods in org.apache.pig.impl.util that return Tuple | |
---|---|
static Tuple |
StorageUtil.bytesToTuple(byte[] buf,
int offset,
int length,
byte fieldDel)
Transform bytes from a byte array up to the specified length to a Tuple |
Tuple |
LineageTracer.getRepresentative(Tuple t)
|
static Tuple |
StorageUtil.textToTuple(org.apache.hadoop.io.Text val,
byte fieldDel)
Transform a line of Text to a Tuple |
Methods in org.apache.pig.impl.util that return types with arguments of type Tuple | |
---|---|
IdentityHashMap<Tuple,Integer> |
LineageTracer.getCounts()
|
Collection<Tuple> |
LineageTracer.getMembers(Tuple t)
|
IdentityHashMap<Tuple,Collection<Tuple>> |
LineageTracer.getMembershipMap()
|
IdentityHashMap<Tuple,Collection<Tuple>> |
LineageTracer.getMembershipMap()
|
IdentityHashMap<Tuple,Integer> |
LineageTracer.getWeightedCounts(IdentityHashSet<Tuple> specialTuples,
int multiplier)
|
Methods in org.apache.pig.impl.util with parameters of type Tuple | |
---|---|
static String |
TupleFormat.format(Tuple tuple)
Default implementation of format of tuple (each filed is delimited by tab) |
Collection<Tuple> |
LineageTracer.getMembers(Tuple t)
|
Tuple |
LineageTracer.getRepresentative(Tuple t)
|
void |
LineageTracer.insert(Tuple t)
|
void |
LineageTracer.union(Tuple t1,
Tuple t2)
|
Method parameters in org.apache.pig.impl.util with type arguments of type Tuple | |
---|---|
IdentityHashMap<Tuple,Integer> |
LineageTracer.getWeightedCounts(IdentityHashSet<Tuple> specialTuples,
int multiplier)
|
Uses of Tuple in org.apache.pig.impl.util.avro |
---|
Classes in org.apache.pig.impl.util.avro that implement Tuple | |
---|---|
class |
AvroTupleWrapper<T extends IndexedRecord>
Object that wraps an Avro object in a tuple. |
Methods in org.apache.pig.impl.util.avro that return types with arguments of type Tuple | |
---|---|
Iterator<Tuple> |
AvroBagWrapper.iterator()
|
Methods in org.apache.pig.impl.util.avro with parameters of type Tuple | |
---|---|
void |
AvroBagWrapper.add(Tuple t)
|
static org.apache.avro.generic.GenericData.Record |
AvroStorageDataConversionUtilities.packIntoAvro(Tuple t,
org.apache.avro.Schema s)
Packs a Pig Tuple into an Avro record. |
void |
AvroTupleWrapper.reference(Tuple arg0)
|
Uses of Tuple in org.apache.pig.pen |
---|
Methods in org.apache.pig.pen that return Tuple | |
---|---|
Tuple |
Illustrable.illustratorMarkup(Object in,
Object out,
int eqClassIndex)
input tuple mark up to be illustrate-able |
Methods in org.apache.pig.pen that return types with arguments of type Tuple | |
---|---|
Collection<IdentityHashSet<Tuple>> |
ExampleGenerator.getEqClasses()
|
LinkedList<IdentityHashSet<Tuple>> |
Illustrator.getEquivalenceClasses()
|
IdentityHashSet<Tuple> |
Illustrator.getInputs()
|
Map<LogicalRelationalOperator,Collection<IdentityHashSet<Tuple>>> |
ExampleGenerator.getLoToEqClassMap()
|
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)
|
Methods in org.apache.pig.pen with parameters of type Tuple | |
---|---|
void |
Illustrator.addData(Tuple t)
|
Method parameters in org.apache.pig.pen with type arguments of type Tuple | |
---|---|
void |
Illustrator.addInputs(IdentityHashSet<Tuple> inputs)
|
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 |
Illustrator.setEquivalenceClasses(LinkedList<IdentityHashSet<Tuple>> eqClasses,
PhysicalOperator po)
|
Constructor parameters in org.apache.pig.pen with type arguments of type Tuple | |
---|---|
Illustrator(LineageTracer lineage,
LinkedList<IdentityHashSet<Tuple>> equivalenceClasses,
IllustratorAttacher attacher,
PigContext hadoopPigContext)
|
|
Illustrator(LineageTracer lineage,
LinkedList<IdentityHashSet<Tuple>> equivalenceClasses,
int maxRecords,
IllustratorAttacher attacher,
LogicalSchema schema,
PigContext hadoopPigContext)
|
Uses of Tuple in org.apache.pig.pen.util |
---|
Classes in org.apache.pig.pen.util that implement Tuple | |
---|---|
class |
ExampleTuple
|
Methods in org.apache.pig.pen.util that return Tuple | |
---|---|
Tuple |
LineageTracer.getRepresentative(Tuple t)
|
Tuple |
ExampleTuple.toTuple()
|
Methods in org.apache.pig.pen.util that return types with arguments of type Tuple | |
---|---|
IdentityHashMap<Tuple,Double> |
LineageTracer.getCounts()
|
Collection<Tuple> |
LineageTracer.getMembers(Tuple t)
|
IdentityHashMap<Tuple,Collection<Tuple>> |
LineageTracer.getMembershipMap()
|
IdentityHashMap<Tuple,Collection<Tuple>> |
LineageTracer.getMembershipMap()
|
IdentityHashMap<Tuple,Double> |
LineageTracer.getWeightedCounts(float syntheticMultipler,
float omittableMultiplier)
|
Methods in org.apache.pig.pen.util with parameters of type Tuple | |
---|---|
Collection<Tuple> |
LineageTracer.getMembers(Tuple t)
|
Tuple |
LineageTracer.getRepresentative(Tuple t)
|
void |
LineageTracer.insert(Tuple t)
|
void |
ExampleTuple.reference(Tuple t)
|
void |
LineageTracer.union(Tuple t1,
Tuple t2)
|
Method parameters in org.apache.pig.pen.util with type arguments of type Tuple | |
---|---|
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)
|
Constructors in org.apache.pig.pen.util with parameters of type Tuple | |
---|---|
ExampleTuple(Tuple t)
|
Uses of Tuple in org.apache.pig.piggybank.evaluation |
---|
Methods in org.apache.pig.piggybank.evaluation that return Tuple | |
---|---|
Tuple |
MaxTupleBy1stField.exec(Tuple input)
|
Tuple |
MaxTupleBy1stField.Initial.exec(Tuple input)
|
Tuple |
MaxTupleBy1stField.Intermediate.exec(Tuple input)
|
Tuple |
MaxTupleBy1stField.Final.exec(Tuple input)
|
Tuple |
ExtremalTupleByNthField.exec(Tuple input)
The EvalFunc interface |
Tuple |
ExtremalTupleByNthField.HelperClass.exec(Tuple input)
|
protected static Tuple |
ExtremalTupleByNthField.extreme(int pind,
int psign,
Tuple input,
PigProgressable reporter)
|
Tuple |
ExtremalTupleByNthField.getValue()
|
protected static Tuple |
MaxTupleBy1stField.max(Tuple input,
PigProgressable reporter)
|
Methods in org.apache.pig.piggybank.evaluation with parameters of type Tuple | |
---|---|
void |
ExtremalTupleByNthField.accumulate(Tuple b)
|
DataBag |
Stitch.exec(Tuple input)
|
DataBag |
Over.exec(Tuple input)
|
Tuple |
MaxTupleBy1stField.exec(Tuple input)
|
Tuple |
MaxTupleBy1stField.Initial.exec(Tuple input)
|
Tuple |
MaxTupleBy1stField.Intermediate.exec(Tuple input)
|
Tuple |
MaxTupleBy1stField.Final.exec(Tuple input)
|
Boolean |
IsNumeric.exec(Tuple input)
|
Boolean |
IsLong.exec(Tuple input)
|
Boolean |
IsInt.exec(Tuple input)
|
Boolean |
IsFloat.exec(Tuple input)
|
Boolean |
IsDouble.exec(Tuple input)
|
Tuple |
ExtremalTupleByNthField.exec(Tuple input)
The EvalFunc interface |
Tuple |
ExtremalTupleByNthField.HelperClass.exec(Tuple input)
|
protected static Tuple |
ExtremalTupleByNthField.extreme(int pind,
int psign,
Tuple input,
PigProgressable reporter)
|
protected static Tuple |
MaxTupleBy1stField.max(Tuple input,
PigProgressable reporter)
|
Uses of Tuple in org.apache.pig.piggybank.evaluation.datetime |
---|
Methods in org.apache.pig.piggybank.evaluation.datetime with parameters of type Tuple | |
---|---|
Integer |
DiffDate.exec(Tuple input)
|
Uses of Tuple in org.apache.pig.piggybank.evaluation.datetime.convert |
---|
Methods in org.apache.pig.piggybank.evaluation.datetime.convert with parameters of type Tuple | |
---|---|
String |
UnixToISO.exec(Tuple input)
|
Long |
ISOToUnix.exec(Tuple input)
|
String |
CustomFormatToISO.exec(Tuple input)
|
Uses of Tuple in org.apache.pig.piggybank.evaluation.datetime.diff |
---|
Methods in org.apache.pig.piggybank.evaluation.datetime.diff with parameters of type Tuple | |
---|---|
Long |
ISOYearsBetween.exec(Tuple input)
|
Long |
ISOSecondsBetween.exec(Tuple input)
|
Long |
ISOMonthsBetween.exec(Tuple input)
|
Long |
ISOMinutesBetween.exec(Tuple input)
|
Long |
ISOHoursBetween.exec(Tuple input)
|
Long |
ISODaysBetween.exec(Tuple input)
|
Uses of Tuple in org.apache.pig.piggybank.evaluation.datetime.truncate |
---|
Methods in org.apache.pig.piggybank.evaluation.datetime.truncate with parameters of type Tuple | |
---|---|
String |
ISOToYear.exec(Tuple input)
|
String |
ISOToWeek.exec(Tuple input)
|
String |
ISOToSecond.exec(Tuple input)
|
String |
ISOToMonth.exec(Tuple input)
|
String |
ISOToMinute.exec(Tuple input)
|
String |
ISOToHour.exec(Tuple input)
|
String |
ISOToDay.exec(Tuple input)
|
static org.joda.time.DateTime |
ISOHelper.parseDateTime(Tuple input)
|
Uses of Tuple in org.apache.pig.piggybank.evaluation.decode |
---|
Methods in org.apache.pig.piggybank.evaluation.decode with parameters of type Tuple | |
---|---|
String |
Decode.exec(Tuple tuple)
|
String |
BinCond.exec(Tuple tuple)
|
String |
Bin.exec(Tuple tuple)
|
Uses of Tuple in org.apache.pig.piggybank.evaluation.math |
---|
Methods in org.apache.pig.piggybank.evaluation.math with parameters of type Tuple | |
---|---|
Double |
nextAfter.exec(Tuple input)
java level API |
Integer |
getExponent.exec(Tuple input)
java level API |
Double |
copySign.exec(Tuple input)
java level API |
Double |
ULP.exec(Tuple input)
java level API |
Double |
SIGNUM.exec(Tuple input)
java level API |
Double |
SCALB.exec(Tuple input)
java level API |
Long |
ROUND.exec(Tuple input)
Deprecated. java level API |
Double |
RANDOM.exec(Tuple input)
|
Double |
NEXTUP.exec(Tuple input)
java level API |
Double |
MIN.exec(Tuple input)
java level API |
Double |
MAX.exec(Tuple input)
java level API |
Long |
LongMin.exec(Tuple input)
java level API |
Long |
LongMax.exec(Tuple input)
java level API |
Long |
LongAbs.exec(Tuple input)
Deprecated. java level API |
Integer |
IntMin.exec(Tuple input)
java level API |
Integer |
IntMax.exec(Tuple input)
java level API |
Integer |
IntAbs.exec(Tuple input)
Deprecated. java level API |
Float |
FloatUlp.exec(Tuple input)
java level API |
Float |
FloatSignum.exec(Tuple input)
java level API |
Integer |
FloatRound.exec(Tuple input)
Deprecated. java level API |
Float |
FloatNextup.exec(Tuple input)
java level API |
Float |
FloatNextAfter.exec(Tuple input)
java level API |
Float |
FloatMin.exec(Tuple input)
java level API |
Float |
FloatMax.exec(Tuple input)
java level API |
Integer |
FloatGetExponent.exec(Tuple input)
java level API |
Float |
FloatCopySign.exec(Tuple input)
java level API |
Float |
FloatAbs.exec(Tuple input)
Deprecated. java level API |
Double |
DoubleUlp.exec(Tuple input)
java level API |
Double |
DoubleSignum.exec(Tuple input)
java level API |
Long |
DoubleRound.exec(Tuple input)
Deprecated. java level API |
Double |
DoubleNextup.exec(Tuple input)
java level API |
Double |
DoubleNextAfter.exec(Tuple input)
java level API |
Double |
DoubleMin.exec(Tuple input)
java level API |
Double |
DoubleMax.exec(Tuple input)
java level API |
Integer |
DoubleGetExponent.exec(Tuple input)
java level API |
Double |
DoubleDoubleBase.exec(Tuple input)
java level API |
Double |
DoubleCopySign.exec(Tuple input)
java level API |
Double |
DoubleBase.exec(Tuple input)
Deprecated. java level API |
Double |
DoubleAbs.exec(Tuple input)
Deprecated. java level API |
Double |
ABS.exec(Tuple input)
Deprecated. java level API |
Uses of Tuple in org.apache.pig.piggybank.evaluation.stats |
---|
Methods in org.apache.pig.piggybank.evaluation.stats that return Tuple | |
---|---|
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 |
Tuple |
COV.Initial.exec(Tuple input)
|
Tuple |
COV.Intermed.exec(Tuple input)
|
Tuple |
COR.Initial.exec(Tuple input)
|
Tuple |
COR.Intermed.exec(Tuple input)
|
Methods in org.apache.pig.piggybank.evaluation.stats with parameters of type Tuple | |
---|---|
DataBag |
COV.exec(Tuple input)
Deprecated. Function to compute covariance between data sets. |
Tuple |
COV.Initial.exec(Tuple input)
|
Tuple |
COV.Intermed.exec(Tuple input)
|
DataBag |
COV.Final.exec(Tuple input)
|
DataBag |
COR.exec(Tuple input)
Deprecated. Function to compute correlation between data sets. |
Tuple |
COR.Initial.exec(Tuple input)
|
Tuple |
COR.Intermed.exec(Tuple input)
|
DataBag |
COR.Final.exec(Tuple input)
|
Uses of Tuple in org.apache.pig.piggybank.evaluation.string |
---|
Methods in org.apache.pig.piggybank.evaluation.string that return Tuple | |
---|---|
Tuple |
RegexExtractAll.exec(Tuple input)
Deprecated. |
Methods in org.apache.pig.piggybank.evaluation.string with parameters of type Tuple | |
---|---|
String |
UPPER.exec(Tuple input)
Deprecated. Upper-cases an input string. |
String |
Stuff.exec(Tuple input)
|
String |
Reverse.exec(Tuple input)
|
Integer |
RegexMatch.exec(Tuple input)
|
Tuple |
RegexExtractAll.exec(Tuple input)
Deprecated. |
String |
RegexExtract.exec(Tuple input)
Deprecated. |
Integer |
LookupInFiles.exec(Tuple input)
|
Integer |
LENGTH.exec(Tuple input)
|
Long |
HashFNV2.exec(Tuple input)
|
Long |
HashFNV1.exec(Tuple input)
|
Long |
HashFNV.exec(Tuple input)
|
void |
LookupInFiles.init(Tuple tuple)
|
Uses of Tuple in org.apache.pig.piggybank.evaluation.util |
---|
Methods in org.apache.pig.piggybank.evaluation.util that return Tuple | |
---|---|
Tuple |
Top.Initial.exec(Tuple tuple)
|
Tuple |
Top.Intermed.exec(Tuple input)
|
Tuple |
ToTuple.exec(Tuple input)
Deprecated. |
Methods in org.apache.pig.piggybank.evaluation.util with parameters of type Tuple | |
---|---|
DataBag |
Top.exec(Tuple tuple)
Deprecated. |
Tuple |
Top.Initial.exec(Tuple tuple)
|
Tuple |
Top.Intermed.exec(Tuple input)
|
DataBag |
Top.Final.exec(Tuple tuple)
|
Tuple |
ToTuple.exec(Tuple input)
Deprecated. |
DataBag |
ToBag.exec(Tuple input)
Deprecated. |
String |
SearchQuery.exec(Tuple tuple)
|
Method parameters in org.apache.pig.piggybank.evaluation.util with type arguments of type Tuple | |
---|---|
protected static void |
Top.updateTop(PriorityQueue<Tuple> store,
int limit,
DataBag inputBag)
Deprecated. |
Uses of Tuple in org.apache.pig.piggybank.evaluation.util.apachelogparser |
---|
Methods in org.apache.pig.piggybank.evaluation.util.apachelogparser with parameters of type Tuple | |
---|---|
String |
SearchTermExtractor.exec(Tuple input)
|
String |
SearchEngineExtractor.exec(Tuple input)
|
String |
HostExtractor.exec(Tuple input)
|
String |
DateExtractor.exec(Tuple input)
|
Uses of Tuple in org.apache.pig.piggybank.evaluation.xml |
---|
Methods in org.apache.pig.piggybank.evaluation.xml with parameters of type Tuple | |
---|---|
String |
XPath.exec(Tuple input)
input should contain: 1) xml 2) xpath 3) optional cache xml doc flag Usage: 1) XPath(xml, xpath) 2) XPath(xml, xpath, false) |
Uses of Tuple in org.apache.pig.piggybank.storage |
---|
Methods in org.apache.pig.piggybank.storage that return Tuple | |
---|---|
Tuple |
XMLLoader.createTuple(String str)
Creates a tuple from a matched string |
Tuple |
IndexedStorage.IndexManager.getIndexKeyTuple(Tuple indexTuple)
Extracts the index key from the index tuple |
Tuple |
XMLLoader.getNext()
|
Tuple |
SequenceFileLoader.getNext()
|
Tuple |
RegExLoader.getNext()
|
Tuple |
IndexedStorage.getNext()
|
Tuple |
HiveColumnarLoader.getNext()
|
Tuple |
HadoopJobHistoryLoader.getNext()
|
Tuple |
FixedWidthLoader.getNext()
|
Tuple |
CSVLoader.getNext()
|
Tuple |
CSVExcelStorage.getNext()
|
Tuple |
AllLoader.getNext()
|
Tuple |
IndexedStorage.IndexManager.ReadIndex()
Reads the next index from the index file (or null if EOF) and extracts the index fields. |
Tuple |
IndexedStorage.IndexManager.ScanIndex(Tuple keys)
Scans the index looking for a given key. |
Methods in org.apache.pig.piggybank.storage that return types with arguments of type Tuple | |
---|---|
org.apache.hadoop.mapreduce.RecordWriter<String,Tuple> |
MultiStorage.MultiStorageOutputFormat.getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context)
|
org.apache.hadoop.mapreduce.RecordWriter<org.apache.hadoop.io.WritableComparable,Tuple> |
IndexedStorage.IndexedStorageOutputFormat.getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context)
|
Methods in org.apache.pig.piggybank.storage with parameters of type Tuple | |
---|---|
Tuple |
IndexedStorage.IndexManager.getIndexKeyTuple(Tuple indexTuple)
Extracts the index key from the index tuple |
long |
IndexedStorage.IndexManager.getIndexKeyTupleCount(Tuple indexTuple)
Extracts the number of records that share the current key from the index tuple. |
long |
IndexedStorage.IndexManager.getOffset(Tuple indexTuple)
Extracts the offset into the data file from the index tuple. |
void |
MultiStorage.putNext(Tuple tuple)
|
void |
HiveColumnarStorage.putNext(Tuple t)
|
void |
FixedWidthStorer.putNext(Tuple t)
|
void |
DBStorage.putNext(Tuple tuple)
Write the tuple to Database directly here. |
void |
CSVExcelStorage.putNext(Tuple tupleToWrite)
|
Tuple |
IndexedStorage.IndexManager.ScanIndex(Tuple keys)
Scans the index looking for a given key. |
void |
IndexedStorage.seekNear(Tuple keys)
|
boolean |
IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader.seekNear(Tuple keys)
Scan the index for given key and seek to appropriate offset in the data |
void |
IndexedStorage.IndexedStorageOutputFormat.IndexedStorageRecordWriter.write(org.apache.hadoop.io.WritableComparable key,
Tuple value)
|
Uses of Tuple in org.apache.pig.piggybank.storage.avro |
---|
Methods in org.apache.pig.piggybank.storage.avro that return Tuple | |
---|---|
Tuple |
AvroStorage.getNext()
|
protected Tuple |
PigAvroRecordReader.wrapAsTuple(Object in)
Wrap non-tuple value as a tuple |
Methods in org.apache.pig.piggybank.storage.avro with parameters of type Tuple | |
---|---|
void |
AvroStorage.putNext(Tuple t)
|
Uses of Tuple in org.apache.pig.piggybank.storage.hiverc |
---|
Methods in org.apache.pig.piggybank.storage.hiverc that return Tuple | |
---|---|
static Tuple |
HiveRCSchemaUtil.parseLazyArrayToPigArray(org.apache.hadoop.hive.serde2.lazy.LazyArray arr)
Converts the LazyArray to a Tuple. |
Uses of Tuple in org.apache.pig.scripting.groovy |
---|
Methods in org.apache.pig.scripting.groovy with parameters of type Tuple | |
---|---|
void |
GroovyAccumulatorEvalFunc.accumulate(Tuple b)
|
T |
GroovyEvalFunc.exec(Tuple input)
|
Constructor parameters in org.apache.pig.scripting.groovy with type arguments of type Tuple | |
---|---|
GroovyUtils.DataBagGroovyIterator(Iterator<Tuple> iter)
|
Uses of Tuple in org.apache.pig.scripting.jruby |
---|
Methods in org.apache.pig.scripting.jruby that return Tuple | |
---|---|
Tuple |
JrubyAlgebraicEvalFunc.Initial.exec(Tuple input)
|
Tuple |
JrubyAlgebraicEvalFunc.Intermed.exec(Tuple input)
|
static Tuple |
PigJrubyLibrary.rubyToPig(org.jruby.RubyArray rbObject)
A type specific conversion routine. |
Methods in org.apache.pig.scripting.jruby that return types with arguments of type Tuple | |
---|---|
Iterator<Tuple> |
RubyDataBag.iterator()
|
Methods in org.apache.pig.scripting.jruby with parameters of type Tuple | |
---|---|
void |
JrubyAccumulatorEvalFunc.accumulate(Tuple b)
This uses the "exec" method required of AccumulatorPigUdf Ruby classes. |
Object |
JrubyEvalFunc.exec(Tuple tuple)
The exec method passes the tuple argument to the Ruby function, and converts the result back to Pig. |
Tuple |
JrubyAlgebraicEvalFunc.Initial.exec(Tuple input)
|
Tuple |
JrubyAlgebraicEvalFunc.Intermed.exec(Tuple input)
|
T |
JrubyAlgebraicEvalFunc.Final.exec(Tuple input)
|
abstract T |
JrubyAlgebraicEvalFunc.AlgebraicFunctionWrapper.exec(Tuple input)
|
static org.jruby.RubyArray |
PigJrubyLibrary.pigToRuby(org.jruby.Ruby ruby,
Tuple object)
A type specific conversion routine. |
Uses of Tuple in org.apache.pig.scripting.js |
---|
Methods in org.apache.pig.scripting.js with parameters of type Tuple | |
---|---|
Object |
JsFunction.exec(Tuple tuple)
|
Uses of Tuple in org.apache.pig.scripting.jython |
---|
Methods in org.apache.pig.scripting.jython with parameters of type Tuple | |
---|---|
Object |
JythonFunction.exec(Tuple tuple)
|
static org.python.core.PyTuple |
JythonUtils.pigTupleToPyTuple(Tuple tuple)
|
Uses of Tuple in org.apache.pig.tools.pigstats |
---|
Methods in org.apache.pig.tools.pigstats that return types with arguments of type Tuple | |
---|---|
Iterator<Tuple> |
OutputStats.iterator()
|
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |