Uses of Class
org.apache.pig.backend.executionengine.ExecException

Packages that use ExecException
org.apache.pig Public interfaces and classes for Pig. 
org.apache.pig.backend.executionengine   
org.apache.pig.backend.executionengine.util   
org.apache.pig.backend.hadoop   
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.relationalOperators   
org.apache.pig.backend.hadoop.executionengine.util   
org.apache.pig.backend.hadoop.streaming   
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   
org.apache.pig.impl.streaming   
org.apache.pig.pen   
org.apache.pig.pen.util   
org.apache.pig.tools.grunt   
org.apache.pig.tools.pigstats   
 

Uses of ExecException in org.apache.pig
 

Methods in org.apache.pig that throw ExecException
 List<ExecJob> PigServer.executeBatch()
          Submits a batch of Pig commands for execution.
static void StandAloneParser.main(String[] args)
           
 

Constructors in org.apache.pig that throw ExecException
PigServer(ExecType execType)
           
PigServer(ExecType execType, Properties properties)
           
PigServer(PigContext context)
           
PigServer(PigContext context, boolean connect)
           
PigServer(String execTypeString)
           
 

Uses of ExecException in org.apache.pig.backend.executionengine
 

Methods in org.apache.pig.backend.executionengine that throw ExecException
 Collection<String> ExecutionEngine.activeScopes()
          List scopes that are active in the back-end
 void ExecutionEngine.close()
          Clean-up and releasing of resources.
 PhysicalPlan ExecutionEngine.compile(LogicalPlan plan, Properties properties)
          Compiles a logical plan into a physical plan, given a set of configuration properties that apply at the plan-level.
 List<ExecJob> ExecutionEngine.execute(PhysicalPlan plan, String jobName)
          Execute the physical plan in blocking mode.
 Properties ExecutionEngine.getConfiguration()
          Provides configuration information about the execution engine itself.
 void ExecJob.getLogs(OutputStream log)
          Collecting various forms of outputs
 Iterator<Tuple> ExecJob.getResults()
          if query has executed successfully we want to retrieve the results via iterating over them.
 Map<String,Object> ExecutionEngine.getStatistics()
          Provides statistics on the Execution Engine: number of nodes, node failure rates, average load, average job wait time...
 void ExecJob.getSTDError(OutputStream error)
           
 void ExecJob.getSTDOut(OutputStream out)
           
 boolean ExecJob.hasCompleted()
          true is the physical plan has executed successfully and results are ready to be retrieved
 void ExecutionEngine.init()
          Place holder for possible initialization activities.
 void ExecJob.kill()
          Kills current job.
 void ExecutionEngine.reclaimScope(String scope)
          A mechanism to communicate to the back-end that a set of logical plans go out of scope
 Collection<ExecJob> ExecutionEngine.runningJobs(Properties properties)
          Return currently running jobs (can be useful for admin purposes)
 List<ExecJob> ExecutionEngine.submit(PhysicalPlan plan, String jobName)
          Execute the physical plan in non-blocking mode
 void ExecPhysicalPlan.updateConfiguration(Properties configuration)
          Some properties of the job may be changed, say the priority...
 void ExecutionEngine.updateConfiguration(Properties newConfiguration)
          Provides a way to dynamically change configuration parameters at the Execution Engine level.
 

Uses of ExecException in org.apache.pig.backend.executionengine.util
 

Methods in org.apache.pig.backend.executionengine.util that throw ExecException
static FileSpec ExecTools.checkLeafIsStore(PhysicalPlan plan, PigContext pigContext)
           
 

Uses of ExecException in org.apache.pig.backend.hadoop
 

Methods in org.apache.pig.backend.hadoop that throw ExecException
static PigNullableWritable HDataType.getWritableComparableTypes(byte type)
           
static PigNullableWritable HDataType.getWritableComparableTypes(Object o, byte keyType)
           
 

Uses of ExecException in org.apache.pig.backend.hadoop.executionengine
 

Methods in org.apache.pig.backend.hadoop.executionengine that throw ExecException
 Collection<String> HExecutionEngine.activeScopes()
           
 void HExecutionEngine.close()
           
 PhysicalPlan HExecutionEngine.compile(LogicalPlan plan, Properties properties)
           
 List<ExecJob> HExecutionEngine.execute(PhysicalPlan plan, String jobName)
           
 Properties HExecutionEngine.getConfiguration()
           
 void HJob.getLogs(OutputStream log)
           
 Iterator<Tuple> HJob.getResults()
           
 Map<String,Object> HExecutionEngine.getStatistics()
           
 void HJob.getSTDError(OutputStream error)
           
 void HJob.getSTDOut(OutputStream out)
           
 boolean HJob.hasCompleted()
           
 void HExecutionEngine.init()
           
 void HExecutionEngine.init(Properties properties)
           
 void HJob.kill()
           
 void HExecutionEngine.reclaimScope(String scope)
           
 Collection<ExecJob> HExecutionEngine.runningJobs(Properties properties)
           
 List<ExecJob> HExecutionEngine.submit(PhysicalPlan plan, String jobName)
           
 void HExecutionEngine.updateConfiguration(Properties newConfiguration)
           
 

Uses of ExecException in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 

Methods in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer that throw ExecException
abstract  void PigMapBase.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)
           
 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)
           
abstract  PigStats Launcher.launchPig(PhysicalPlan php, String grpName, PigContext pc)
          Method to launch pig for hadoop either for a cluster's job tracker or for a local job runner.
 PigStats MapReduceLauncher.launchPig(PhysicalPlan php, String grpName, PigContext pc)
           
protected  void PigMapReduce.Reduce.runPipeline(PhysicalOperator leaf)
           
 

Uses of ExecException in org.apache.pig.backend.hadoop.executionengine.physicalLayer
 

Methods in org.apache.pig.backend.hadoop.executionengine.physicalLayer that throw ExecException
 Result PhysicalOperator.getNext(Boolean b)
           
 Result PhysicalOperator.getNext(DataBag db)
           
 Result PhysicalOperator.getNext(DataByteArray ba)
           
 Result PhysicalOperator.getNext(Double d)
           
 Result PhysicalOperator.getNext(Float f)
           
 Result PhysicalOperator.getNext(Integer i)
           
 Result PhysicalOperator.getNext(Long l)
           
 Result PhysicalOperator.getNext(Map m)
           
 Result PhysicalOperator.getNext(String s)
           
 Result PhysicalOperator.getNext(Tuple t)
           
 Result PhysicalOperator.processInput()
          A generic method for parsing input that either returns the attached input if it exists or fetches it from its predecessor.
 

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

Methods in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators that throw ExecException
protected  Result POProject.consumeInputBag(Result input)
           
 int POProject.getColumn()
           
 String POUserFunc.getFinal()
           
 String POUserFunc.getInitial()
           
 String POUserFunc.getIntermed()
           
 Result POProject.getNext()
          Fetches the input tuple and returns the requested column
 Result ComparisonOperator.getNext(Boolean b)
           
 Result ConstantExpression.getNext(Boolean b)
           
 Result EqualToExpr.getNext(Boolean bool)
           
 Result GTOrEqualToExpr.getNext(Boolean bool)
           
 Result GreaterThanExpr.getNext(Boolean bool)
           
 Result LTOrEqualToExpr.getNext(Boolean bool)
           
 Result LessThanExpr.getNext(Boolean bool)
           
 Result NotEqualToExpr.getNext(Boolean bool)
           
 Result POAnd.getNext(Boolean b)
           
 Result POBinCond.getNext(Boolean b)
           
 Result POIsNull.getNext(Boolean b)
           
 Result POMapLookUp.getNext(Boolean b)
           
 Result PONot.getNext(Boolean b)
           
 Result POOr.getNext(Boolean b)
           
 Result POProject.getNext(Boolean b)
           
 Result PORegexp.getNext(Boolean bool)
           
 Result POUserComparisonFunc.getNext(Boolean b)
           
 Result POUserFunc.getNext(Boolean b)
           
 Result ComparisonOperator.getNext(DataBag db)
           
 Result ConstantExpression.getNext(DataBag db)
           
 Result ExpressionOperator.getNext(DataBag db)
           
 Result POBinCond.getNext(DataBag db)
           
 Result POCast.getNext(DataBag bag)
           
 Result POMapLookUp.getNext(DataBag db)
           
 Result POProject.getNext(DataBag db)
           
 Result PORelationToExprProject.getNext(DataBag db)
           
 Result POUserComparisonFunc.getNext(DataBag db)
           
 Result POUserFunc.getNext(DataBag db)
           
 Result ComparisonOperator.getNext(DataByteArray ba)
           
 Result ConstantExpression.getNext(DataByteArray ba)
           
 Result POBinCond.getNext(DataByteArray ba)
           
 Result POMapLookUp.getNext(DataByteArray ba)
           
 Result POProject.getNext(DataByteArray ba)
           
 Result POUserComparisonFunc.getNext(DataByteArray ba)
           
 Result POUserFunc.getNext(DataByteArray ba)
           
 Result Add.getNext(Double d)
           
 Result ComparisonOperator.getNext(Double d)
           
 Result ConstantExpression.getNext(Double d)
           
 Result Divide.getNext(Double d)
           
 Result Multiply.getNext(Double d)
           
 Result POBinCond.getNext(Double d)
           
 Result POCast.getNext(Double d)
           
 Result POMapLookUp.getNext(Double d)
           
 Result PONegative.getNext(Double d)
           
 Result POProject.getNext(Double d)
           
 Result POUserComparisonFunc.getNext(Double d)
           
 Result POUserFunc.getNext(Double d)
           
 Result Subtract.getNext(Double d)
           
 Result Add.getNext(Float f)
           
 Result ComparisonOperator.getNext(Float f)
           
 Result ConstantExpression.getNext(Float f)
           
 Result Divide.getNext(Float f)
           
 Result Multiply.getNext(Float f)
           
 Result POBinCond.getNext(Float f)
           
 Result POCast.getNext(Float f)
           
 Result POMapLookUp.getNext(Float f)
           
 Result PONegative.getNext(Float f)
           
 Result POProject.getNext(Float f)
           
 Result POUserComparisonFunc.getNext(Float f)
           
 Result POUserFunc.getNext(Float f)
           
 Result Subtract.getNext(Float f)
           
 Result Add.getNext(Integer i)
           
 Result ComparisonOperator.getNext(Integer i)
           
 Result ConstantExpression.getNext(Integer i)
           
 Result Divide.getNext(Integer i)
           
 Result Mod.getNext(Integer i)
           
 Result Multiply.getNext(Integer i)
           
 Result POBinCond.getNext(Integer i)
           
 Result POCast.getNext(Integer i)
           
 Result POMapLookUp.getNext(Integer i)
           
 Result PONegative.getNext(Integer i)
           
 Result POProject.getNext(Integer i)
           
 Result POUserComparisonFunc.getNext(Integer i)
           
 Result POUserFunc.getNext(Integer i)
           
 Result Subtract.getNext(Integer i)
           
 Result Add.getNext(Long l)
           
 Result ComparisonOperator.getNext(Long l)
           
 Result ConstantExpression.getNext(Long l)
           
 Result Divide.getNext(Long l)
           
 Result Mod.getNext(Long i)
           
 Result Multiply.getNext(Long l)
           
 Result POBinCond.getNext(Long l)
           
 Result POCast.getNext(Long l)
           
 Result POMapLookUp.getNext(Long l)
           
 Result PONegative.getNext(Long l)
           
 Result POProject.getNext(Long l)
           
 Result POUserComparisonFunc.getNext(Long l)
           
 Result POUserFunc.getNext(Long l)
           
 Result Subtract.getNext(Long l)
           
 Result ComparisonOperator.getNext(Map m)
           
 Result ConstantExpression.getNext(Map m)
           
 Result POBinCond.getNext(Map m)
           
 Result POCast.getNext(Map m)
           
 Result POMapLookUp.getNext(Map m)
           
 Result POProject.getNext(Map m)
           
 Result POUserComparisonFunc.getNext(Map m)
           
 Result POUserFunc.getNext(Map m)
           
 Result ComparisonOperator.getNext(String s)
           
 Result ConstantExpression.getNext(String s)
           
 Result POBinCond.getNext(String s)
           
 Result POCast.getNext(String str)
           
 Result POMapLookUp.getNext(String s)
           
 Result POProject.getNext(String s)
           
 Result POUserComparisonFunc.getNext(String s)
           
 Result POUserFunc.getNext(String s)
           
 Result ComparisonOperator.getNext(Tuple t)
           
 Result ConstantExpression.getNext(Tuple t)
           
 Result POBinCond.getNext(Tuple t)
           
 Result POCast.getNext(Tuple t)
           
 Result POMapLookUp.getNext(Tuple t)
           
 Result POProject.getNext(Tuple t)
          Asked for Tuples.
 Result POUserComparisonFunc.getNext(Tuple in)
           
 Result POUserFunc.getNext(Tuple tIn)
           
 Result POMapLookUp.processInput()
           
 Result POUserFunc.processInput()
           
protected  Result POProject.processInputBag()
           
 void POUserFunc.setAlgebraicFunction(byte Function)
           
 

Uses of ExecException in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 

Methods in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators that throw ExecException
protected  Tuple POLocalRearrange.constructLROutput(List<Result> resLst, Tuple value)
           
protected  Tuple POLocalRearrangeForIllustrate.constructLROutput(List<Result> resLst, Tuple value)
           
protected  Tuple POPreCombinerLocalRearrange.constructLROutput(List<Result> resLst, Tuple value)
           
protected  Tuple POForEach.CreateTuple(Object[] data)
           
 Result POCombinerPackage.getNext(Tuple t)
           
 Result PODemux.getNext(Tuple t)
           
 Result PODistinct.getNext(Tuple t)
           
 Result POFRJoin.getNext(Tuple t)
           
 Result POFilter.getNext(Tuple t)
          Attaches the proccesed input tuple to the expression plan and checks if comparison operator returns a true.
 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 POGlobalRearrange.getNext(Tuple t)
           
 Result POJoinPackage.getNext(Tuple t)
          Calls getNext to get next ForEach result.
 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 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 POLocalRearrange.getNext(Tuple t)
          Calls getNext on the generate operator inside the nested physical plan.
 Result POMultiQueryPackage.getNext(Tuple t)
          Constructs the output tuple from the inputs.
 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 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 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 POPreCombinerLocalRearrange.getNext(Tuple t)
          Calls getNext on the generate operator inside the nested physical plan.
 Result POSort.getNext(Tuple t)
           
 Result POSplit.getNext(Tuple t)
           
 Result POStore.getNext(Tuple t)
           
 Result POStream.getNext(Tuple t)
           
 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.getNextHelper(Tuple t)
           
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.
protected  Result POForEach.processPlan()
           
 void POLocalRearrange.setIndex(int index)
          Sets the co-group index of this operator
 void POLocalRearrange.setMultiQueryIndex(int index)
          Sets the multi-query index of this operator
 

Constructors in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators that throw ExecException
POFRJoin(OperatorKey k)
           
POFRJoin(OperatorKey k, int rp)
           
POFRJoin(OperatorKey k, int rp, List<PhysicalOperator> inp)
           
POFRJoin(OperatorKey k, int rp, List<PhysicalOperator> inp, List<List<PhysicalPlan>> ppLists, List<Byte> keyTypes, FileSpec[] replFiles, int fragment)
           
POFRJoin(OperatorKey k, List<PhysicalOperator> inp)
           
 

Uses of ExecException in org.apache.pig.backend.hadoop.executionengine.util
 

Methods in org.apache.pig.backend.hadoop.executionengine.util that throw ExecException
static StoreFunc MapRedUtil.getStoreFunc(org.apache.hadoop.mapred.JobConf conf)
          This method is to be called from an OutputFormat.getRecordWriter(FileSystem ignored, JobConf job, String name, Progressable progress) method to obtain a reference to the StoreFunc object to be used by that OutputFormat to perform the write() operation
 

Uses of ExecException in org.apache.pig.backend.hadoop.streaming
 

Methods in org.apache.pig.backend.hadoop.streaming that throw ExecException
 void HadoopExecutableManager.configure(POStream stream)
           
 

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

Methods in org.apache.pig.backend.local.executionengine that throw ExecException
 Collection<String> LocalExecutionEngine.activeScopes()
           
 void LocalExecutionEngine.close()
           
 PhysicalPlan LocalExecutionEngine.compile(LogicalPlan plan, Properties properties)
           
 List<ExecJob> LocalExecutionEngine.execute(PhysicalPlan plan, String jobName)
           
 Properties LocalExecutionEngine.getConfiguration()
           
 void LocalJob.getLogs(OutputStream log)
           
 Iterator<Tuple> LocalJob.getResults()
           
 Map<String,Object> LocalExecutionEngine.getStatistics()
           
 void LocalJob.getSTDError(OutputStream error)
           
 void LocalJob.getSTDOut(OutputStream out)
           
 boolean LocalJob.hasCompleted()
           
 void LocalExecutionEngine.init()
           
 void LocalJob.kill()
           
 PigStats LocalPigLauncher.launchPig(PhysicalPlan php, String grpName, PigContext pc)
           
 void LocalExecutionEngine.reclaimScope(String scope)
           
 Collection<ExecJob> LocalExecutionEngine.runningJobs(Properties properties)
           
 List<ExecJob> LocalExecutionEngine.submit(PhysicalPlan plan, String jobName)
           
 void LocalExecutionEngine.updateConfiguration(Properties newConfiguration)
           
 

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

Methods in org.apache.pig.backend.local.executionengine.physicalLayer.counters that throw ExecException
 Result POCounter.getNext(Tuple t)
           
 

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

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

Uses of ExecException in org.apache.pig.builtin
 

Methods in org.apache.pig.builtin that throw ExecException
protected static Tuple AVG.combine(DataBag values)
           
protected static Tuple DoubleAvg.combine(DataBag values)
           
protected static Tuple FloatAvg.combine(DataBag values)
           
protected static Tuple IntAvg.combine(DataBag values)
           
protected static Tuple LongAvg.combine(DataBag values)
           
protected static long AVG.count(Tuple input)
           
protected static long DoubleAvg.count(Tuple input)
           
protected static long FloatAvg.count(Tuple input)
           
protected static long IntAvg.count(Tuple input)
           
protected static long LongAvg.count(Tuple input)
           
protected static Double DoubleMax.max(Tuple input)
           
protected static Float FloatMax.max(Tuple input)
           
protected static Integer IntMax.max(Tuple input)
           
protected static Long LongMax.max(Tuple input)
           
protected static Double MAX.max(Tuple input)
           
protected static String StringMax.max(Tuple input)
           
protected static Double MAX.maxDoubles(Tuple input)
           
protected static Double DoubleMin.min(Tuple input)
           
protected static Float FloatMin.min(Tuple input)
           
protected static Integer IntMin.min(Tuple input)
           
protected static Long LongMin.min(Tuple input)
           
protected static Double MIN.min(Tuple input)
           
protected static String StringMin.min(Tuple input)
           
protected static Double MIN.minDoubles(Tuple input)
           
protected static Double AVG.sum(Tuple input)
           
protected static Long COUNT.sum(Tuple input)
           
protected static Double DoubleAvg.sum(Tuple input)
           
protected static Double DoubleSum.sum(Tuple input)
           
protected static Double FloatAvg.sum(Tuple input)
           
protected static Double FloatSum.sum(Tuple input)
           
protected static Long IntAvg.sum(Tuple input)
           
protected static Long IntSum.sum(Tuple input)
           
protected static Long LongAvg.sum(Tuple input)
           
protected static Long LongSum.sum(Tuple input)
           
protected static Double SUM.sum(Tuple input)
           
protected static Double FloatSum.sumDoubles(Tuple input)
           
protected static Double SUM.sumDoubles(Tuple input)
           
protected static Long IntSum.sumLongs(Tuple input)
           
 

Uses of ExecException in org.apache.pig.data
 

Methods in org.apache.pig.data that throw ExecException
static Schema.FieldSchema DataType.determineFieldSchema(Object o)
          Determine the field schema of an object
 Object DefaultTuple.get(int fieldNum)
          Get the value in a given field.
 Object TargetedTuple.get(int fieldNum)
           
 Object Tuple.get(int fieldNum)
          Get the value in a given field.
 byte DefaultTuple.getType(int fieldNum)
          Find the type of a given field.
 byte TargetedTuple.getType(int fieldNum)
           
 byte Tuple.getType(int fieldNum)
          Find the type of a given field.
 boolean DefaultTuple.isNull(int fieldNum)
          Find out if a given field is null.
 boolean TargetedTuple.isNull(int fieldNum)
           
 boolean Tuple.isNull(int fieldNum)
          Find out if a given field is null.
static Object DataReaderWriter.readDatum(DataInput in)
           
static Object DataReaderWriter.readDatum(DataInput in, byte type)
           
 void DefaultTuple.set(int fieldNum, Object val)
          Set the value in a given field.
 void TargetedTuple.set(int fieldNum, Object val)
           
 void Tuple.set(int fieldNum, Object val)
          Set the value in a given field.
static DataBag DataType.toBag(Object o)
          If this object is a bag, return it as a bag.
 String DefaultTuple.toDelimitedString(String delim)
          Write a tuple of atomic values into a string.
 String TargetedTuple.toDelimitedString(String delim)
           
 String Tuple.toDelimitedString(String delim)
          Write a tuple of atomic values into a string.
static Double DataType.toDouble(Object o)
          If type of object is not known, use this method which in turns call toLong(object,type) after finding type.
static Double DataType.toDouble(Object o, byte type)
          Force a data object to a Double, if possible.
static Float DataType.toFloat(Object o)
          If type of object is not known, use this method which in turns call toFloat(object,type) after finding type.
static Float DataType.toFloat(Object o, byte type)
          Force a data object to a Float, if possible.
static Integer DataType.toInteger(Object o)
          If type of object is not known, use this method, which internally calls toInteger(object,type)
static Integer DataType.toInteger(Object o, byte type)
          Force a data object to an Integer, if possible.
static Long DataType.toLong(Object o)
          If type of object is not known, use this method which in turns call toLong(object,type) after finding type.
static Long DataType.toLong(Object o, byte type)
          Force a data object to a Long, if possible.
static Map<Object,Object> DataType.toMap(Object o)
          If this object is a map, return it as a map.
static String DataType.toString(Object o)
          If type of object is not known, use this method which in turns call toString(object,type) after finding type.
static String DataType.toString(Object o, byte type)
          Force a data object to a String, if possible.
static Tuple DataType.toTuple(Object o)
          If this object is a tuple, return it as a tuple.
 

Uses of ExecException in org.apache.pig.impl
 

Methods in org.apache.pig.impl that throw ExecException
 void PigContext.connect()
           
 ExecutableManager PigContext.createExecutableManager()
          Create a new ExecutableManager depending on the ExecType.
 

Uses of ExecException in org.apache.pig.impl.streaming
 

Methods in org.apache.pig.impl.streaming that throw ExecException
 void ExecutableManager.configure(POStream stream)
          Configure and initialize the ExecutableManager.
static InputHandler HandlerFactory.createInputHandler(StreamingCommand command)
          Create an InputHandler for the given input specification of the StreamingCommand.
static OutputHandler HandlerFactory.createOutputHandler(StreamingCommand command)
          Create an OutputHandler for the given output specification of the StreamingCommand.
 

Constructors in org.apache.pig.impl.streaming that throw ExecException
FileInputHandler(StreamingCommand.HandleSpec handleSpec)
           
FileOutputHandler(StreamingCommand.HandleSpec handleSpec)
           
 

Uses of ExecException in org.apache.pig.pen
 

Methods in org.apache.pig.pen that throw ExecException
static Collection<IdentityHashSet<Tuple>> EquivalenceClasses.GetEquivalenceClasses(LogicalOperator op, Map<LogicalOperator,DataBag> derivedData)
           
 

Uses of ExecException in org.apache.pig.pen.util
 

Methods in org.apache.pig.pen.util that throw ExecException
 Object ExampleTuple.get(int fieldNum)
           
 byte ExampleTuple.getType(int fieldNum)
           
 boolean ExampleTuple.isNull(int fieldNum)
           
 void ExampleTuple.set(int fieldNum, Object val)
           
 String ExampleTuple.toDelimitedString(String delim)
           
 

Uses of ExecException in org.apache.pig.tools.grunt
 

Constructors in org.apache.pig.tools.grunt that throw ExecException
Grunt(BufferedReader in, PigContext pigContext)
           
 

Uses of ExecException in org.apache.pig.tools.pigstats
 

Methods in org.apache.pig.tools.pigstats that throw ExecException
 Map<String,Map<String,String>> PigStats.accumulateStats()
           
 



Copyright © ${year} The Apache Software Foundation