Uses of Interface
org.apache.pig.data.Tuple

Packages that use Tuple
org.apache.pig Public interfaces and classes for Pig. 
org.apache.pig.backend.executionengine   
org.apache.pig.backend.hadoop.executionengine   
org.apache.pig.backend.hadoop.executionengine.mapReduceLayer   
org.apache.pig.backend.hadoop.executionengine.physicalLayer Implementation of physical operators that use hadoop as the execution engine and data storage. 
org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators   
org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans   
org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators   
org.apache.pig.backend.hadoop.hbase   
org.apache.pig.backend.local.executionengine   
org.apache.pig.backend.local.executionengine.physicalLayer.counters   
org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators   
org.apache.pig.builtin   
org.apache.pig.data Data types for Pig. 
org.apache.pig.impl.builtin   
org.apache.pig.impl.io   
org.apache.pig.impl.streaming   
org.apache.pig.impl.util   
org.apache.pig.pen   
org.apache.pig.pen.util   
 

Uses of Tuple in org.apache.pig
 

Methods in org.apache.pig that return Tuple
 Tuple LoadFunc.bytesToTuple(byte[] b)
          Cast data from bytes to tuple value.
 Tuple LoadFunc.getNext()
          Retrieves the next tuple to be processed.
 Tuple SamplableLoader.getSampledTuple()
          Get the next tuple from the stream starting from the current read position.
 

Methods in org.apache.pig that return types with arguments of type Tuple
 Iterator<Tuple> PigServer.openIterator(String id)
          Forces execution of query (and all queries from which it reads), in order to materialize result
 

Methods in org.apache.pig with parameters of type Tuple
 void Accumulator.accumulate(Tuple b)
          Pass tuples to the UDF.
abstract  int ComparisonFunc.compare(Tuple t1, Tuple t2)
          This callback method must be implemented by all subclasses.
abstract  T EvalFunc.exec(Tuple input)
          This callback method must be implemented by all subclasses.
 boolean Slice.next(Tuple value)
          Loads the next value from this Slice into value.
 void StoreFunc.putNext(Tuple f)
          Write a tuple the output stream to which this instance was previously bound.
 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.
 

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.
 

Methods in org.apache.pig.backend.executionengine with parameters of type Tuple
 boolean PigSlice.next(Tuple value)
           
 

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 types with arguments of type Tuple
 org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.Text,Tuple> PigInputFormat.getRecordReader(org.apache.hadoop.mapred.InputSplit split, org.apache.hadoop.mapred.JobConf job, org.apache.hadoop.mapred.Reporter reporter)
           
 org.apache.hadoop.mapred.RecordWriter<org.apache.hadoop.io.WritableComparable,Tuple> PigOutputFormat.getRecordWriter(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.mapred.JobConf job, String name, org.apache.hadoop.util.Progressable progress)
          In general, the mechanism for an OutputFormat in Pig to get hold of the storeFunc and the metadata information (for now schema and location provided for the store in the pig script) is through the following Utility static methods: MapRedUtil.getStoreFunc(JobConf) - this will get the StoreFunc reference to use in the RecordWriter.write() MapRedUtil.getStoreConfig(JobConf) - this will get the StoreConfig reference which has metadata like the location (the string supplied with store statement in the script) and the Schema of the data.
 org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.Text,Tuple> SliceWrapper.makeReader(org.apache.hadoop.mapred.JobConf job)
           
 

Methods in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer with parameters of type Tuple
 void PigMapReduce.Map.collect(org.apache.hadoop.mapred.OutputCollector<PigNullableWritable,org.apache.hadoop.io.Writable> oc, Tuple tuple)
           
 void PigMapReduce.MapWithComparator.collect(org.apache.hadoop.mapred.OutputCollector<PigNullableWritable,org.apache.hadoop.io.Writable> oc, Tuple tuple)
           
 void PigMapReduce.MapWithPartitionIndex.collect(org.apache.hadoop.mapred.OutputCollector<PigNullableWritable,org.apache.hadoop.io.Writable> oc, Tuple tuple)
           
 void PigMapOnly.Map.collect(org.apache.hadoop.mapred.OutputCollector<PigNullableWritable,org.apache.hadoop.io.Writable> oc, Tuple tuple)
           
abstract  void PigMapBase.collect(org.apache.hadoop.mapred.OutputCollector<PigNullableWritable,org.apache.hadoop.io.Writable> oc, Tuple tuple)
           
 void PigMapBase.map(org.apache.hadoop.io.Text key, Tuple inpTuple, org.apache.hadoop.mapred.OutputCollector<PigNullableWritable,org.apache.hadoop.io.Writable> oc, org.apache.hadoop.mapred.Reporter reporter)
          The map function that attaches the inpTuple appropriately and executes the map plan if its not empty.
 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 static Tuple PhysicalOperator.dummyTuple
           
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
 Result PhysicalOperator.getNext(Tuple t)
           
 

Uses of Tuple in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 

Methods in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators with parameters of type Tuple
protected  Result ExpressionOperator.accumChild(List<ExpressionOperator> child, Tuple t)
          Drive all the UDFs in accumulative mode
 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)
           
 Result POUserFunc.getNext(Tuple tIn)
           
 Result POUserComparisonFunc.getNext(Tuple in)
           
 Result POProject.getNext(Tuple t)
          Asked for Tuples.
 Result POMapLookUp.getNext(Tuple t)
           
 Result POCast.getNext(Tuple t)
           
 Result POBinCond.getNext(Tuple t)
           
 Result ConstantExpression.getNext(Tuple t)
           
 Result ComparisonOperator.getNext(Tuple t)
           
 

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 POPackage.keyAsTuple
           
protected  Tuple POLocalRearrange.mFakeTuple
           
 

Methods in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators that return Tuple
protected  Tuple POLocalRearrangeForIllustrate.constructLROutput(List<Result> resLst, List<Result> secondaryResLst, Tuple value)
           
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 POPackageLite.getKeyAsTuple()
           
protected  Tuple POPackage.getValueTuple(NullableTuple ntup, int index)
           
 Tuple POPackageLite.getValueTuple(NullableTuple ntup, int index, Object key)
          Makes use of the superclass method, but this requires an additional parameter key passed by ReadOnceBag.
 

Methods in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators that return types with arguments of type Tuple
 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
 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 POLocalRearrangeForIllustrate.constructLROutput(List<Result> resLst, List<Result> secondaryResLst, Tuple value)
           
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)
           
 Result POUnion.getNext(Tuple t)
          The code below, tries to follow our single threaded shared execution model with execution being passed around each non-drained input
 Result POStream.getNext(Tuple t)
           
 Result POStore.getNext(Tuple t)
           
 Result POSplit.getNext(Tuple t)
           
 Result POSortedDistinct.getNext(Tuple t)
           
 Result POSort.getNext(Tuple t)
           
 Result PORead.getNext(Tuple t)
           
 Result POPreCombinerLocalRearrange.getNext(Tuple t)
          Calls getNext on the generate operator inside the nested physical plan.
 Result POPartitionRearrange.getNext(Tuple t)
          Calls getNext on the generate operator inside the nested physical plan.
 Result POPackageLite.getNext(Tuple t)
          Similar to POPackage.getNext except that only one input is expected with index 0 and ReadOnceBag is used instead of DefaultDataBag.
 Result POPackage.getNext(Tuple t)
          From the inputs, constructs the output tuple for this co-group in the required format which is (key, {bag of tuples from input 1}, {bag of tuples from input 2}, ...)
 Result POOptimizedForEach.getNext(Tuple t)
          Calls getNext on the generate operator inside the nested physical plan and returns it maintaining an additional state to denote the begin and end of the nested plan processing.
 Result POMultiQueryPackage.getNext(Tuple t)
          Constructs the output tuple from the inputs.
 Result POMergeJoin.getNext(Tuple t)
           
 Result POLocalRearrange.getNext(Tuple t)
          Calls getNext on the generate operator inside the nested physical plan.
 Result POLoad.getNext(Tuple t)
          The main method used by this operator's successor to read tuples from the specified file using the specified load function.
 Result POLimit.getNext(Tuple t)
          Counts the number of tuples processed into static variable soFar, if the number of tuples processed reach the limit, return EOP; Otherwise, return the tuple
 Result POJoinPackage.getNext(Tuple t)
          Calls getNext to get next ForEach result.
 Result POGlobalRearrange.getNext(Tuple t)
           
 Result POForEach.getNext(Tuple t)
          Calls getNext on the generate operator inside the nested physical plan and returns it maintaining an additional state to denote the begin and end of the nested plan processing.
 Result POFilter.getNext(Tuple t)
          Attaches the proccesed input tuple to the expression plan and checks if comparison operator returns a true.
 Result POFRJoin.getNext(Tuple t)
           
 Result PODistinct.getNext(Tuple t)
           
 Result PODemux.getNext(Tuple t)
           
 Result POCombinerPackage.getNext(Tuple t)
           
 Result POCollectedGroup.getNext(Tuple t)
           
 Result POStream.getNextHelper(Tuple t)
           
 

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)
           
 

Uses of Tuple in org.apache.pig.backend.hadoop.hbase
 

Methods in org.apache.pig.backend.hadoop.hbase that return Tuple
 Tuple HBaseStorage.getNext()
           
 

Methods in org.apache.pig.backend.hadoop.hbase with parameters of type Tuple
 boolean HBaseSlice.next(Tuple value)
           
 

Uses of Tuple in org.apache.pig.backend.local.executionengine
 

Methods in org.apache.pig.backend.local.executionengine that return types with arguments of type Tuple
 Iterator<Tuple> LocalJob.getResults()
           
 

Uses of Tuple in org.apache.pig.backend.local.executionengine.physicalLayer.counters
 

Methods in org.apache.pig.backend.local.executionengine.physicalLayer.counters with parameters of type Tuple
 Result POCounter.getNext(Tuple t)
           
 

Uses of Tuple in org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators
 

Methods in org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators with parameters of type Tuple
 Result POStreamLocal.getNext(Tuple t)
          This is different from the Map-Reduce implementation of the POStream since there is no push model here.
 Result POSplitOutput.getNext(Tuple t)
           
 Result POSplit.getNext(Tuple t)
           
 Result POCross.getNext(Tuple t)
           
 Result POCogroup.getNext(Tuple t)
           
 

Uses of Tuple in org.apache.pig.builtin
 

Methods in org.apache.pig.builtin that return Tuple
 Tuple Utf8StorageConverter.bytesToTuple(byte[] b)
           
 Tuple TextLoader.bytesToTuple(byte[] b)
          TextLoader does not support conversion to Tuple
 Tuple BinStorage.bytesToTuple(byte[] b)
           
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 AVG.combine(DataBag values)
           
 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 SUM.Initial.exec(Tuple input)
           
 Tuple SUM.Intermediate.exec(Tuple input)
           
 Tuple MIN.Initial.exec(Tuple input)
           
 Tuple MIN.Intermediate.exec(Tuple input)
           
 Tuple MAX.Initial.exec(Tuple input)
           
 Tuple MAX.Intermediate.exec(Tuple input)
           
 Tuple LongSum.Initial.exec(Tuple input)
           
 Tuple LongSum.Intermediate.exec(Tuple input)
           
 Tuple LongMin.Initial.exec(Tuple input)
           
 Tuple LongMin.Intermediate.exec(Tuple input)
           
 Tuple LongMax.Initial.exec(Tuple input)
           
 Tuple LongMax.Intermediate.exec(Tuple input)
           
 Tuple LongAvg.Initial.exec(Tuple input)
           
 Tuple LongAvg.Intermediate.exec(Tuple input)
           
 Tuple IntSum.Initial.exec(Tuple input)
           
 Tuple IntSum.Intermediate.exec(Tuple input)
           
 Tuple IntMin.Initial.exec(Tuple input)
           
 Tuple IntMin.Intermediate.exec(Tuple input)
           
 Tuple IntMax.Initial.exec(Tuple input)
           
 Tuple IntMax.Intermediate.exec(Tuple input)
           
 Tuple IntAvg.Initial.exec(Tuple input)
           
 Tuple IntAvg.Intermediate.exec(Tuple input)
           
 Tuple FloatSum.Initial.exec(Tuple input)
           
 Tuple FloatSum.Intermediate.exec(Tuple input)
           
 Tuple FloatMin.Initial.exec(Tuple input)
           
 Tuple FloatMin.Intermediate.exec(Tuple input)
           
 Tuple FloatMax.Initial.exec(Tuple input)
           
 Tuple FloatMax.Intermediate.exec(Tuple input)
           
 Tuple FloatAvg.Initial.exec(Tuple input)
           
 Tuple FloatAvg.Intermediate.exec(Tuple input)
           
 Tuple DoubleSum.Initial.exec(Tuple input)
           
 Tuple DoubleSum.Intermediate.exec(Tuple input)
           
 Tuple DoubleMin.Initial.exec(Tuple input)
           
 Tuple DoubleMin.Intermediate.exec(Tuple input)
           
 Tuple DoubleMax.Initial.exec(Tuple input)
           
 Tuple DoubleMax.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 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 AVG.Initial.exec(Tuple input)
           
 Tuple AVG.Intermediate.exec(Tuple input)
           
 Tuple TextLoader.getNext()
           
 Tuple PigStorage.getNext()
           
 Tuple BinaryStorage.getNext()
           
 Tuple BinStorage.getNext()
           
 Tuple PigStorage.getSampledTuple()
           
 Tuple BinStorage.getSampledTuple()
           
 

Methods in org.apache.pig.builtin with parameters of type Tuple
 void StringMin.accumulate(Tuple b)
           
 void StringMax.accumulate(Tuple b)
           
 void SUM.accumulate(Tuple b)
           
 void MIN.accumulate(Tuple b)
           
 void MAX.accumulate(Tuple b)
           
 void LongSum.accumulate(Tuple b)
           
 void LongMin.accumulate(Tuple b)
           
 void LongMax.accumulate(Tuple b)
           
 void LongAvg.accumulate(Tuple b)
           
 void IntSum.accumulate(Tuple b)
           
 void IntMin.accumulate(Tuple b)
           
 void IntMax.accumulate(Tuple b)
           
 void IntAvg.accumulate(Tuple b)
           
 void FloatSum.accumulate(Tuple b)
           
 void FloatMin.accumulate(Tuple b)
           
 void FloatMax.accumulate(Tuple b)
           
 void FloatAvg.accumulate(Tuple b)
           
 void DoubleSum.accumulate(Tuple b)
           
 void DoubleMin.accumulate(Tuple b)
           
 void DoubleMax.accumulate(Tuple b)
           
 void DoubleAvg.accumulate(Tuple b)
           
 void COUNT_STAR.accumulate(Tuple b)
           
 void COUNT.accumulate(Tuple b)
           
 void AVG.accumulate(Tuple b)
           
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 long AVG.count(Tuple input)
           
 Long TupleSize.exec(Tuple input)
           
 DataBag TOKENIZE.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)
           
 Double SUM.exec(Tuple input)
           
 Tuple SUM.Initial.exec(Tuple input)
           
 Tuple SUM.Intermediate.exec(Tuple input)
           
 Double SUM.Final.exec(Tuple input)
           
 Long SIZE.exec(Tuple input)
           
 Double RANDOM.exec(Tuple input)
           
 Long MapSize.exec(Tuple input)
           
 Double MIN.exec(Tuple input)
           
 Tuple MIN.Initial.exec(Tuple input)
           
 Tuple MIN.Intermediate.exec(Tuple input)
           
 Double MIN.Final.exec(Tuple input)
           
 Double MAX.exec(Tuple input)
           
 Tuple MAX.Initial.exec(Tuple input)
           
 Tuple MAX.Intermediate.exec(Tuple input)
           
 Double MAX.Final.exec(Tuple input)
           
 Long LongSum.exec(Tuple input)
           
 Tuple LongSum.Initial.exec(Tuple input)
           
 Tuple LongSum.Intermediate.exec(Tuple input)
           
 Long LongSum.Final.exec(Tuple input)
           
 Long LongMin.exec(Tuple input)
           
 Tuple LongMin.Initial.exec(Tuple input)
           
 Tuple LongMin.Intermediate.exec(Tuple input)
           
 Long LongMin.Final.exec(Tuple input)
           
 Long LongMax.exec(Tuple input)
           
 Tuple LongMax.Initial.exec(Tuple input)
           
 Tuple LongMax.Intermediate.exec(Tuple input)
           
 Long LongMax.Final.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)
           
 Boolean IsEmpty.exec(Tuple input)
           
 Long IntSum.exec(Tuple input)
           
 Tuple IntSum.Initial.exec(Tuple input)
           
 Tuple IntSum.Intermediate.exec(Tuple input)
           
 Long IntSum.Final.exec(Tuple input)
           
 Integer IntMin.exec(Tuple input)
           
 Tuple IntMin.Initial.exec(Tuple input)
           
 Tuple IntMin.Intermediate.exec(Tuple input)
           
 Integer IntMin.Final.exec(Tuple input)
           
 Integer IntMax.exec(Tuple input)
           
 Tuple IntMax.Initial.exec(Tuple input)
           
 Tuple IntMax.Intermediate.exec(Tuple input)
           
 Integer IntMax.Final.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)
           
 Double FloatSum.exec(Tuple input)
           
 Tuple FloatSum.Initial.exec(Tuple input)
           
 Tuple FloatSum.Intermediate.exec(Tuple input)
           
 Double FloatSum.Final.exec(Tuple input)
           
 Float FloatMin.exec(Tuple input)
           
 Tuple FloatMin.Initial.exec(Tuple input)
           
 Tuple FloatMin.Intermediate.exec(Tuple input)
           
 Float FloatMin.Final.exec(Tuple input)
           
 Float FloatMax.exec(Tuple input)
           
 Tuple FloatMax.Initial.exec(Tuple input)
           
 Tuple FloatMax.Intermediate.exec(Tuple input)
           
 Float FloatMax.Final.exec(Tuple input)
           
 Double FloatAvg.exec(Tuple input)
           
 Tuple FloatAvg.Initial.exec(Tuple input)
           
 Tuple FloatAvg.Intermediate.exec(Tuple input)
           
 Double FloatAvg.Final.exec(Tuple input)
           
 Double DoubleSum.exec(Tuple input)
           
 Tuple DoubleSum.Initial.exec(Tuple input)
           
 Tuple DoubleSum.Intermediate.exec(Tuple input)
           
 Double DoubleSum.Final.exec(Tuple input)
           
 Double DoubleMin.exec(Tuple input)
           
 Tuple DoubleMin.Initial.exec(Tuple input)
           
 Tuple DoubleMin.Intermediate.exec(Tuple input)
           
 Double DoubleMin.Final.exec(Tuple input)
           
 Double DoubleMax.exec(Tuple input)
           
 Tuple DoubleMax.Initial.exec(Tuple input)
           
 Tuple DoubleMax.Intermediate.exec(Tuple input)
           
 Double DoubleMax.Final.exec(Tuple input)
           
 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)
           
 DataBag DIFF.exec(Tuple input)
          Compares a tuple with two fields.
 Long ConstantSize.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)
           
 DataByteArray CONCAT.exec(Tuple input)
           
 Long BagSize.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)
           
protected  DataBag Distinct.getDistinct(Tuple input)
           
protected static String StringMax.max(Tuple input)
           
protected static Double MAX.max(Tuple input)
           
protected static Long LongMax.max(Tuple input)
           
protected static Integer IntMax.max(Tuple input)
           
protected static Float FloatMax.max(Tuple input)
           
protected static Double DoubleMax.max(Tuple input)
           
protected static Double MAX.maxDoubles(Tuple input)
           
protected static String StringMin.min(Tuple input)
           
protected static Double MIN.min(Tuple input)
           
protected static Long LongMin.min(Tuple input)
           
protected static Integer IntMin.min(Tuple input)
           
protected static Float FloatMin.min(Tuple input)
           
protected static Double DoubleMin.min(Tuple input)
           
protected static Double MIN.minDoubles(Tuple input)
           
 void PigStorage.putNext(Tuple f)
           
 void PigDump.putNext(Tuple f)
           
 void BinaryStorage.putNext(Tuple f)
           
 void BinStorage.putNext(Tuple t)
           
protected static Double SUM.sum(Tuple input)
           
protected static Long LongSum.sum(Tuple input)
           
protected static Long LongAvg.sum(Tuple input)
           
protected static Long IntSum.sum(Tuple input)
           
protected static Long IntAvg.sum(Tuple input)
           
protected static Double FloatSum.sum(Tuple input)
           
protected static Double FloatAvg.sum(Tuple input)
           
protected static Double DoubleSum.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 Double AVG.sum(Tuple input)
           
protected static Double SUM.sumDoubles(Tuple input)
           
protected static Double FloatSum.sumDoubles(Tuple input)
           
protected static Long IntSum.sumLongs(Tuple input)
           
 byte[] Utf8StorageConverter.toBytes(Tuple t)
           
 byte[] TextLoader.toBytes(Tuple t)
           
 byte[] BinStorage.toBytes(Tuple t)
           
 

Uses of Tuple in org.apache.pig.data
 

Classes in org.apache.pig.data that implement Tuple
 class AmendableTuple
           
static class DefaultAbstractBag.BagDelimiterTuple
           
static class DefaultAbstractBag.EndBag
           
static class DefaultAbstractBag.StartBag
           
 class DefaultTuple
          A default implementation of Tuple.
 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
static Tuple DataReaderWriter.bytesToTuple(DataInput in)
           
abstract  Tuple TupleFactory.newTuple()
          Create an empty tuple.
 Tuple DefaultTupleFactory.newTuple()
           
abstract  Tuple TupleFactory.newTuple(int size)
          Create a tuple with size fields.
 Tuple DefaultTupleFactory.newTuple(int size)
           
abstract  Tuple TupleFactory.newTuple(List c)
          Create a tuple from the provided list of objects.
 Tuple DefaultTupleFactory.newTuple(List c)
           
abstract  Tuple TupleFactory.newTuple(Object datum)
          Create a tuple with a single element.
 Tuple DefaultTupleFactory.newTuple(Object datum)
           
abstract  Tuple TupleFactory.newTupleNoCopy(List list)
          Create a tuple from a provided list of objects, keeping the provided list.
 Tuple DefaultTupleFactory.newTupleNoCopy(List list)
           
 Tuple TargetedTuple.toTuple()
           
static Tuple DataType.toTuple(Object o)
          If this object is a tuple, return it as a tuple.
 

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()
           
 

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 Tuple.reference(Tuple t)
          Make this tuple reference the contents of another.
 void TargetedTuple.reference(Tuple t)
           
 void DefaultTuple.reference(Tuple t)
          Make this tuple reference the contents of another.
static void DataType.spillTupleContents(Tuple t, String label)
          Purely for debugging
 

Method parameters in org.apache.pig.data with type arguments of type Tuple
 void InternalSortedBag.addAll(Collection<Tuple> c)
           
 void InternalDistinctBag.addAll(Collection<Tuple> c)
           
 void InternalCachedBag.addAll(Collection<Tuple> c)
           
 void DefaultAbstractBag.addAll(Collection<Tuple> c)
          Add contents of a container to the 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 from an existing list of tuples.
 DataBag DefaultBagFactory.newSortedBag(Comparator<Tuple> comp)
          Get a sorted data bag.
abstract  DataBag BagFactory.newSortedBag(Comparator<Tuple> comp)
          Get a sorted data bag.
 

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, double 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.impl.builtin
 

Methods in org.apache.pig.impl.builtin that return Tuple
 Tuple SampleLoader.bytesToTuple(byte[] b)
           
 Tuple MergeJoinIndexer.bytesToTuple(byte[] b)
           
 Tuple DefaultIndexableLoader.bytesToTuple(byte[] b)
           
 Tuple TupleSize.exec(Tuple in)
          Get memory size and disk size of input tuple
 Tuple SampleLoader.getNext()
           
 Tuple MergeJoinIndexer.getNext()
           
 Tuple DefaultIndexableLoader.getNext()
           
 

Methods in org.apache.pig.impl.builtin with parameters of type Tuple
 Tuple TupleSize.exec(Tuple in)
          Get memory size and disk size of input tuple
 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
 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
 

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 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.
 

Uses of Tuple in org.apache.pig.impl.util
 

Methods in org.apache.pig.impl.util that return Tuple
 Tuple LineageTracer.getRepresentative(Tuple t)
           
 

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.pen
 

Methods in org.apache.pig.pen that return types with arguments of type Tuple
static Collection<IdentityHashSet<Tuple>> EquivalenceClasses.getEquivalenceClasses(LogicalOperator op, Map<LogicalOperator,DataBag> derivedData)
           
 

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(LogicalOperator op, Map<LogicalOperator,DataBag> exampleData, Map<LogicalOperator,Collection<IdentityHashSet<Tuple>>> OperatorToEqClasses, boolean overallCompleteness)
           
static float MetricEvaluation.getConciseness(LogicalOperator op, Map<LogicalOperator,DataBag> exampleData, Map<LogicalOperator,Collection<IdentityHashSet<Tuple>>> OperatorToEqClasses, boolean overallConciseness)
           
 

Constructors in org.apache.pig.pen.util with parameters of type Tuple
ExampleTuple(Tuple t)
           
 



Copyright © ${year} The Apache Software Foundation