You are viewing a plain text version of this content. The canonical link for it is here.
Posted to user@flume.apache.org by Keith Wiggins <ke...@genband.com> on 2015/11/02 20:54:02 UTC

Need help with Hive Sink

Greetings,

  We are encountering the following exception when attempting to use the hive sink.

2015-11-02 13:57:47,177 (SinkRunner-PollingRunner-DefaultSinkProcessor) [ERROR - org.apache.flume.SinkRunner$PollingRunner.run(SinkRunner.java:160)] Unable to deliver event. Exception follows.
org.apache.flume.EventDeliveryException: java.lang.ArrayIndexOutOfBoundsException: 157
        at org.apache.flume.sink.hive.HiveSink.process(HiveSink.java:268)
        at org.apache.flume.sink.DefaultSinkProcessor.process(DefaultSinkProcessor.java:68)
        at org.apache.flume.SinkRunner$PollingRunner.run(SinkRunner.java:147)
        at java.lang.Thread.run(Thread.java:745)
Caused by: java.lang.ArrayIndexOutOfBoundsException: 157
        at org.apache.hive.hcatalog.streaming.DelimitedInputWriter.reorderFields(DelimitedInputWriter.java:180)
        at org.apache.hive.hcatalog.streaming.DelimitedInputWriter.write(DelimitedInputWriter.java:213)
        at org.apache.hive.hcatalog.streaming.HiveEndPoint$TransactionBatchImpl.write(HiveEndPoint.java:632)
        at org.apache.flume.sink.hive.HiveDelimitedTextSerializer.write(HiveDelimitedTextSerializer.java:51)
        at org.apache.flume.sink.hive.HiveWriter$1.call(HiveWriter.java:153)
        at org.apache.flume.sink.hive.HiveWriter$1.call(HiveWriter.java:147)
        at org.apache.flume.sink.hive.HiveWriter$9.call(HiveWriter.java:366)
        at java.util.concurrent.FutureTask.run(FutureTask.java:262)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1145)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:615)
        ... 1 more

Here is the background as to what we are sending.  I have created a log file of 100 records that contains 187 fields ( A mock billing record ).  We have examined all the records to ensure that they all have the same number of fields.

Example record;
2015-10-01 11:43:33,1443714213,000:00:12,10.11.1.3,39894,10.11.3.3,,,131,131,IV,01,N,0,,,,16,AD,322738,315960,484991414,,14437103751613112,49,Canada_3,0,France_3,0,16,131,0,,ac
k-rx,16,12,,h323,end1,1,,442,,,0,,12.156,EDT,msx_Canada,,3,,Canada,France,routename,destcustid,callzone,3,,16,600,6,0,10,G711,10,94,600,6,0,10,G711,10,92,,sip,10.0.0.1,10.0.0.2
,,,diversioninfo,,,,,source,,,,,,,,49206,49206,74.106.168.197,27516,10.128.249.58,53610,,,,,,,01/10/2015 10:39:35,01/10/2015 10:39:47,,1,1111,3333,2222,4444,None,1869138903,189
6645364,,Unauthorized,Unauthorized,,,,,,,,,,,,,,,,,,,,,,,,,,,,,,,,,,,,,,48,,,,,,,,,,,,,,,,,,,,,,,,,,,,,,

These records are being delivered to an Avro sink (I removed the IPs)

agent.sources = CDRS
agent.channels = memoryChannel_1
agent.sinks = k2 k3
agent.sinkgroups = load-balance

agent.sinkgroups.load-balance.sinks = k2 k3
agent.sinkgroups.load-balance.processor.type = load_balance
agent.sinkgroups.load-balance.processor.selector = round_robin

agent.sources.CDRS.type = spooldir
agent.sources.CDRS.channels = memoryChannel_1
agent.sources.CDRS.spoolDir = /var/log/cdrs/
agent.sources.CDRS.fileHeader = true
agent.sources.CDRS.interceptors = itime
agent.sources.CDRS.interceptors.itime.type = timestamp

agent.sinks.k2.type = avro
agent.sinks.k2.channel = memoryChannel_1
agent.sinks.k2.hostname =
agent.sinks.k2.port = 4775

agent.sinks.k3.type = avro
agent.sinks.k3.channel = memoryChannel_1
agent.sinks.k3.hostname =
agent.sinks.k3.port = 4775

# Each channel's type is defined.
agent.channels.memoryChannel_1.type = memory

# Other config values specific to each type of channel(sink or source)
# can be defined as well
# In this case, it specifies the capacity of the memory channel
agent.channels.memoryChannel_1.capacity = 100

The flume agent on the hadoop server has the configuration; (Note that we have played with a small channel to match the data coming in).  We did have things working when we were using the hdfs sink.

agent.sources = LSMetrics
agent.channels = memoryChannel
agent.sinks = k1

# For each one of the sources, the type is defined
agent.sources.LSMetrics.type = avro
agent.sources.LSMetrics.batchSize = 1
agent.sources.LSMetrics.channels = memoryChannel
agent.sources.LSMetrics.bind =
agent.sources.LSMetrics.port = 4775
agent.sources.LSMetrics.interceptors = dateI
agent.sources.LSMetrics.interceptors.dateI.type = regex_extractor
agent.sources.LSMetrics.interceptors.dateI.regex = ^(\\d+)-.*
agent.sources.LSMetrics.interceptors.dateI.serializers = y
agent.sources.LSMetrics.interceptors.dateI.serializers.y.name = ddate

agent.sinks.k1.type = hive
agent.sinks.k1.channel = memoryChannel
agent.sinks.k1.hive.metastore = thrift://:9083
agent.sinks.k1.hive.database = default
agent.sinks.k1.hive.table = acs_cdr_orc_v7
agent.sinks.k1.hive.partition = %{ddate}
agent.sinks.k1.callTimeout = 100000
agent.sinks.k1.serializer = DELIMITED
agent.sinks.k1.serializer.delimeter = ,
agent.sinks.k1.serializer.fieldnames = starttime,datetimeint,callduration,origip,sourceq931port,termip,unspecified1,userid,calle164,calldtmf,calltypeinfo,unspecified2,disccode,erroridleg1,errordescleg1,unspecified3,unspecified4,ani,mediatype,bytesforwardedfromsrc,bytesforwardedfromdst,seqnum,transcoder_id,callid,holdtime,origgw,origport,termgw,termport,isdncode,lastcallnumber,erroridleg2,errordescleg2,lastevent,newani,duration,incomingcallid,protocol,cdrtype,huntattempts,origtg,pdd,h323raserror,h323h225error,sipfinalresponsecode,termtg,durationmsec,tz,mswname,numberaftertransit,termnumbertype,orignumbertype,origrealm,termrealm,callroute,calldstcustid,callzonedata,calldstnumtype,callsrcnumtype,origisdncausecode,srcpacketsreceived,srcpacketslost,srcpacketsdiscarded,srcpdv,srccodec,srclatency,srcrfactor,dstpacketsreceived,dstpacketslost,dstpacketsdiscarded,dstpdv,dstcodec,dstlatency,dstrfactor,srcsiprespcode,peerprotocol,srcprivateip,dstprivateip,srcigrpname,dstigrpname,diversioninfo,customcontacttag,e911call,unspecified5,unspecified6,callreleasesource,huntattemptsincludinglcf,callgappingerror,errorcodeinreasonheader,oclobjecttype,oclobjectiddtnregidrealmname,oclobjectiddtnrealmuport,oclpolicyname,srcprivateport,destprivateport,srcrealmmediaip,srcrealmmediaport,dstrealmmediaip,dstrealmmediaport,origtgc,termtgc,srcpcv,destpcv,srcpani,destpani,callconnecttimemsec,endtimemsec,routingnumber,mlines,fromuriuserpart,newfromuriuserpart,paiduriuserpart,newpaiduriuserpart,privacy,requesturiuserpart,newrequesturiuserpart,localrefertransferstatus,sipfinalresponsereason,srcsiprespreason,chargenumber,chargenumbernoa,chargenumbernpi,segmentstarttimems,segmentdurationfractional,srcxrlossrate,srcxrdiscardrate,srcxrburstdensity,srcxrgapdensity,srcxrburstduration,srcxrgapduration,srcxrroundtripdelay,srcxrendsystemdelay,srcxrgmin,srcxrjitterbufferadaptive,srcxrjitterbufferrate,srcxrrfactor,srcxrmos_cq,srcxrjitterbuffernominaldelay,srcxrjitterbuffermaximumdelay,srcxrjitterbufferabsolutemaximumdelay,dstxrlossrate,dstxrdiscardrate,dstxrburstdensity,dstxrgapdensity,dstxrburstduration,dstxrgapduration,dstxrroundtripdelay,dstxrendsystemdelay,dstxrgmin,dstxrjitterbufferadaptive,dstxrjitterbufferrate,dstxrrfactor,dstxrmos_cq,dstxrjitterbuffernominaldelay,dstxrjitterbuffermaximumdelay,dstxrjitterbufferabsolutemaximumdelay,unspecified7,unspecified8,srcciphersuite,destciphersuite,srcpacketoutsidereplaywindow,srcpacketauthfailure,srcpacketcipherfailure,destpacketoutsidereplaywindow,destpacketauthfailure,destpacketcipherfailure,fmmcallleginfo1,fmmcallleginfo2,fmmcallleginfo3,fmmcallleginfo4,fmmcallleginfo5,fmmcallinfo1,fmmcallinfo2,fmmcallinfo3,fmmcallinfo4,fmmcallinfo5,embeddeddspinsertion,outgoingtouri,incomingrequesturi,incomingrsaipaddress,sbciserverversion,outgoingrequesturi,outgoingfromuri,privacyingressrequested,privacymethodegress,privacyegressrequested,srcpolicedpackets,ddate

#agent.sinks.k1.hdfs.path = hdfs://:8020/flume
#agent.sinks.k1.hdfs.writeFormat = Text
#agent.sinks.k1.hdfs.fileType = DataStream
#agent.sinks.k1.hdfs.batchSize = 100
#agent.sinks.k1.hdfs.rollInterval = 3600
#agent.sinks.k1.hdfs.rollCount = 1000000
#agent.sinks.k1.hdfs.rollSize = 0
#agent.sinks.k1.hdfs.idleTimeout = 5

# Each channel's type is defined.
agent.channels.memoryChannel.type = memory
agent.channels.memoryChannel.transactionCapacity = 20000

# Other config values specific to each type of channel(sink or source)
# can be defined as well
# In this case, it specifies the capacity of the memory channel
agent.channels.memoryChannel.capacity = 200000

The flume execution output shows the following;

2015-11-02 13:57:27,280 (SinkRunner-PollingRunner-DefaultSinkProcessor) [INFO - org.apache.hadoop.hive.metastore.HiveMetaStoreClient.open(HiveMetaStoreClient.java:473)] Connected to metastore.
2015-11-02 13:57:27,458 (SinkRunner-PollingRunner-DefaultSinkProcessor) [DEBUG - org.apache.hive.hcatalog.streaming.DelimitedInputWriter.<init>(DelimitedInputWriter.java:121)] Field reordering needed = true, for endpoint {metaStoreUri='thrift://172.28.172.5:9083', database='default', table='acs_cdr_orc_v7', partitionVals=[2015] }
2015-11-02 13:57:27,459 (SinkRunner-PollingRunner-DefaultSinkProcessor) [DEBUG - org.apache.flume.sink.hive.HiveWriter.nextTxnBatch(HiveWriter.java:326)] Fetching new Txn Batch for {metaStoreUri='thrift://172.28.172.5:9083', database='default', table='acs_cdr_orc_v7', partitionVals=[2015] }
2015-11-02 13:57:27,675 (hive-k1-call-runner-0) [DEBUG - org.apache.hive.hcatalog.streaming.AbstractRecordWriter.newBatch(AbstractRecordWriter.java:120)] Creating Record updater
2015-11-02 13:57:27,678 (hive-k1-call-runner-0) [DEBUG - org.apache.hadoop.hive.metastore.MetaStoreUtils.getDDLFromFieldSchema(MetaStoreUtils.java:843)] DDL: struct acs_cdr_orc_v7 { string starttime, i32 datetimeint, string callduration, string origip, i32 sourceq931port, string termip, string unspecified1, string userid, string calle164, string calldtmf, string calltypeinfo, string unspecified2, string disccode, i32 erroridleg1, string errordescleg1, string unspecified3, string unspecified4, string ani, string mediatype, string bytesforwardedfromsrc, string bytesforwardedfromdst, i32 seqnum, string transcoder_id, string callid, i32 holdtime, string origgw, i32 origport, string termgw, i32 termport, i32 isdncode, string lastcallnumber, i32 erroridleg2, string errordescleg2, string lastevent, string newani, i32 duration, string incomingcallid, i32 protocol, i32 cdrtype, i32 huntattempts, string origtg, i32 pdd, i32 h323raserror, i32 h323h225error, i32 sipfinalresponsecode, string termtg, i32 durationmsec, string tz, string mswname, string numberaftertransit, i32 termnumbertype, i32 orignumbertype, string origrealm, string termrealm, string callroute, string calldstcustid, string callzonedata, string calldstnumtype, string callsrcnumtype, string origisdncausecode, i32 srcpacketsreceived, i32 srcpacketslost, i32 srcpacketsdiscarded, i32 srcpdv, string srccodec, i32 srclatency, i32 srcrfactor, i32 dstpacketsreceived, i32 dstpacketslost, i32 dstpacketsdiscarded, i32 dstpdv, string dstcodec, i32 dstlatency, i32 dstrfactor, i32 srcsiprespcode, string peerprotocol, string srcprivateip, string dstprivateip, string srcigrpname, string dstigrpname, string diversioninfo, string customcontacttag, string e911call, string unspecified5, string unspecified6, string callreleasesource, i32 huntattemptsincludinglcf, i32 callgappingerror, i32 errorcodeinreasonheader, string oclobjecttype, string oclobjectiddtnregidrealmname, string oclobjectiddtnrealmuport, string oclpolicyname, string srcprivateport, string destprivateport, string srcrealmmediaip, string srcrealmmediaport, string dstrealmmediaip, string dstrealmmediaport, string origtgc, string termtgc, string srcpcv, string destpcv, string srcpani, string destpani, string callconnecttimemsec, string endtimemsec, string routingnumber, i32 mlines, string fromuriuserpart, string newfromuriuserpart, string paiduriuserpart, string newpaiduriuserpart, string privacy, string requesturiuserpart, string newrequesturiuserpart, string localrefertransferstatus, string sipfinalresponsereason, string srcsiprespreason, string chargenumber, i32 chargenumbernoa, i32 chargenumbernpi, string segmentstarttimems, string segmentdurationfractional, i32 srcxrlossrate, i32 srcxrdiscardrate, i32 srcxrburstdensity, i32 srcxrgapdensity, i32 srcxrburstduration, i32 srcxrgapduration, i32 srcxrroundtripdelay, i32 srcxrendsystemdelay, i32 srcxrgmin, i32 srcxrjitterbufferadaptive, i32 srcxrjitterbufferrate, i32 srcxrrfactor, i32 srcxrmos_cq, i32 srcxrjitterbuffernominaldelay, i32 srcxrjitterbuffermaximumdelay, i32 srcxrjitterbufferabsolutemaximumdelay, i32 dstxrlossrate, i32 dstxrdiscardrate, i32 dstxrburstdensity, i32 dstxrgapdensity, i32 dstxrburstduration, i32 dstxrgapduration, i32 dstxrroundtripdelay, i32 dstxrendsystemdelay, i32 dstxrgmin, i32 dstxrjitterbufferadaptive, i32 dstxrjitterbufferrate, i32 dstxrrfactor, i32 dstxrmos_cq, i32 dstxrjitterbuffernominaldelay, i32 dstxrjitterbuffermaximumdelay, i32 dstxrjitterbufferabsolutemaximumdelay, string unspecified7, string unspecified8, string srcciphersuite, string destciphersuite, i32 srcpacketoutsidereplaywindow, i32 srcpacketauthfailure, i32 srcpacketcipherfailure, i32 destpacketoutsidereplaywindow, i32 destpacketauthfailure, i32 destpacketcipherfailure, string fmmcallleginfo1, string fmmcallleginfo2, string fmmcallleginfo3, string fmmcallleginfo4, string fmmcallleginfo5, string fmmcallinfo1, string fmmcallinfo2, string fmmcallinfo3, string fmmcallinfo4, string fmmcallinfo5, string embeddeddspinsertion, string outgoingtouri, string incomingrequesturi, string incomingrsaipaddress, string sbciserverversion, string outgoingrequesturi, string outgoingfromuri, string privacyingressrequested, string privacymethodegress, string privacyegressrequested, string srcpolicedpackets}
2015-11-02 13:57:28,062 (SinkRunner-PollingRunner-DefaultSinkProcessor) [INFO - org.apache.flume.sink.hive.HiveWriter.nextTxnBatch(HiveWriter.java:335)] Acquired Txn Batch TxnIds=[2101...2200] on endPoint = {metaStoreUri='thrift://172.28.172.5:9083', database='default', table='acs_cdr_orc_v7', partitionVals=[2015] }. Switching to first txn

It appears as though the records are being read in; (We get 100 of the following events)
2015-11-02 13:57:28,086 (SinkRunner-PollingRunner-DefaultSinkProcessor) [DEBUG - org.apache.flume.sink.hive.HiveSink.drainOneBatch(HiveSink.java:299)] k1 : Writing event to {metaStoreUri='thrift://:9083', database='default', table='acs_cdr_orc_v7', partitionVals=[2015] }
2015-11-02 13:57:28,087 (SinkRunner-PollingRunner-DefaultSinkProcessor) [DEBUG - org.apache.flume.sink.hive.HiveSink.drainOneBatch(HiveSink.java:299)] k1 : Writing event to {metaStoreUri='thrift://:9083', database='default', table='acs_cdr_orc_v7', partitionVals=[2015] }
2015-11-02 13:57:28,087 (SinkRunner-PollingRunner-DefaultSinkProcessor) [DEBUG - org.apache.flume.sink.hive.HiveSink.drainOneBatch(HiveSink.java:299)] k1 : Writing event to {metaStoreUri='thrift://:9083', database='default', table='acs_cdr_orc_v7', partitionVals=[2015] }
.
.

We have verified that the database table that we have created matches the fields identified.
create table acs_cdr_orc_v7 (starttime string, DateTimeInt int,callduration string,origIp string,sourceQ931Port int,termIp string,unspecified1 string,userId string,callE164 string,callDTMF string,callTypeInfo string,unspecified2 string,discCode string,errorIDLeg1 int,errorDescLeg1 string,unspecified3 string,unspecified4 string,ani string,mediaType string,bytesForwardedFromSrc string,bytesForwardedFromDst string,seqNum int,transcoder_id string,callId string,holdTime int,origGw string,origPort int,termGw string,termPort int,isdnCode int,lastCallNumber string,errorIDLeg2 int,errorDescLeg2 string,lastEvent string,newANI string,duration int,incomingCallId string,protocol int,cdrType int,huntAttempts int,origTG string,pdd int,h323RASError int,h323H225Error int,sipFinalResponseCode int,termTG string,durationMsec int,tz string,mswname string,numberAfterTransit string,termNumberType int,origNumberType int,origRealm string,termRealm string,callRoute string,callDstCustId string,callZoneData string,callDstNumType string,callSrcNumType string,origISDNCauseCode string,srcPacketsReceived int,srcPacketsLost int,srcPacketsDiscarded int,srcPDV int,srcCodec string,srcLatency int,srcRFactor int,dstPacketsReceived int,dstPacketsLost int,dstPacketsDiscarded int,dstPDV int,dstCodec string,dstLatency int,dstRFactor int,srcSipRespCode int,peerProtocol string,srcPrivateIp string,dstPrivateIp string,srcIgrpName string,dstIgrpName string,diversioninfo string,customcontacttag  string, e911call string,unspecified5 string,unspecified6 string,callReleaseSource string,huntAttemptsIncludingLCF int,callGappingError int,errorCodeInReasonHeader int,oclObjectType string,oclObjectIdDtnRegidRealmname string,oclObjectIdDtnrealmUport string,oclPolicyName string,srcPrivatePort string,destPrivatePort string,srcRealmMediaIP string,srcRealmMediaPort string,dstRealmMediaIP string,dstRealmMediaPort string,origTGC string,termTGC string,srcPCV string,destPCV string,srcPANI string,destPANI string,callConnectTimeMSec string,endTimeMSec string,routingNumber string,mLines int,fromUriUserPart string,newFromUriUserPart string,paidUriUserPart string,newPaidUriUserPart string,privacy string,requestUriUserPart string,newRequestUriUserPart string,localReferTransferStatus string,sipFinalResponseReason string,srcSipRespReason string,ChargeNumber  string,ChargeNumberNOA int,ChargeNumberNPI  int,segmentstarttimems string,segmentdurationfractional  string,srcXrLossRate int,srcXrDiscardRate int,srcXrBurstDensity int,srcXrGapDensity int,srcXrBurstDuration int,srcXrGapDuration  int,srcXrRoundTripDelay int,srcXrEndSystemDelay  int,srcXrGmin int,srcXrJitterBufferAdaptive int,srcXrJitterBufferRate int,srcXrRfactor int,srcXrMOS_CQ int,srcXrJitterBufferNominalDelay int,srcXrJitterBufferMaximumDelay int,srcXrJitterBufferAbsoluteMaximumDelay int,dstXrLossRate int,dstXrDiscardRate int,dstXrBurstDensity int,dstXrGapDensity int,dstXrBurstDuration int,dstXrGapDuration int,dstXrRoundTripDelay int,dstXrEndSystemDelay int,dstXrGmin int,dstXrJitterBufferAdaptive int,dstXrJitterBufferRate int,dstXrRfactor int,dstXrMOS_CQ int,dstXrJitterBufferNominalDelay int,dstXrJitterBufferMaximumDelay int,dstXrJitterBufferAbsoluteMaximumDelay int,unspecified7 string,unspecified8 string,srcCipherSuite string,destCipherSuite string,srcPacketOutsideReplayWindow int,srcPacketAuthFailure int,srcPacketCipherFailure int,destPacketOutsideReplayWindow int,destPacketAuthFailure int,destPacketCipherFailure int,fmmCallLegInfo1 string,fmmCallLegInfo2 string,fmmCallLegInfo3 string,fmmCallLegInfo4 string,fmmCallLegInfo5 string,fmmCallInfo1 string,fmmCallInfo2 string,fmmCallInfo3 string,fmmCallInfo4 string,fmmCallInfo5 string,embeddedDspInsertion string,outgoingToURI string,incomingRequestURI string,incomingRSAIPAddress string,SBCiServerVersion string,outgoingRequestURI string,outgoingFromURI string,privacyIngressRequested string,privacyMethodEgress string,privacyEgressRequested string,srcPolicedPackets string) partitioned by (ddate string) clustered by (starttime) into 5 buckets stored as orc tblproperties("transactional"="true");
Once we received the exception, it appears to try again as the above logs would be repeated over and over again.
The only thing that I can think of is the ddate as it shows up as another column in the database but when we tried to add the ddate to the fieldnames we got the error;
Caused by: org.apache.flume.sink.hive.HiveWriter$ConnectException: Failed connecting to EndPoint {metaStoreUri='thrift://172.28.172.5:9083', database='default', table='acs_cdr_orc_v7', partitionVals=[2015] }
        at org.apache.flume.sink.hive.HiveWriter.<init>(HiveWriter.java:98)
        at org.apache.flume.sink.hive.HiveSink.getOrCreateWriter(HiveSink.java:343)
        at org.apache.flume.sink.hive.HiveSink.drainOneBatch(HiveSink.java:296)
        at org.apache.flume.sink.hive.HiveSink.process(HiveSink.java:254)
        ... 3 more
Caused by: org.apache.hive.hcatalog.streaming.InvalidColumn: Column 'ddate' not found in table for input field 1871

Database contents;
hive> describe acs_cdr_orc_v7;
OK
starttime               string
datetimeint             int
callduration            string
origip                  string
sourceq931port          int
termip                  string
unspecified1            string
userid                  string
calle164                string
calldtmf                string
calltypeinfo            string
unspecified2            string
disccode                string
erroridleg1             int
errordescleg1           string
unspecified3            string
unspecified4            string
ani                     string
mediatype               string
bytesforwardedfromsrc   string
bytesforwardedfromdst   string
seqnum                  int
transcoder_id           string
callid                  string
holdtime                int
origgw                  string
origport                int
termgw                  string
termport                int
isdncode                int
lastcallnumber          string
erroridleg2             int
errordescleg2           string
lastevent               string
newani                  string
duration                int
incomingcallid          string
protocol                int
cdrtype                 int
huntattempts            int
origtg                  string
pdd                     int
h323raserror            int
h323h225error           int
sipfinalresponsecode    int
termtg                  string
durationmsec            int
tz                      string
mswname                 string
numberaftertransit      string
termnumbertype          int
orignumbertype          int
origrealm               string
termrealm               string
callroute               string
calldstcustid           string
callzonedata            string
calldstnumtype          string
callsrcnumtype          string
origisdncausecode       string
srcpacketsreceived      int
srcpacketslost          int
srcpacketsdiscarded     int
srcpdv                  int
srccodec                string
srclatency              int
srcrfactor              int
dstpacketsreceived      int
dstpacketslost          int
dstpacketsdiscarded     int
dstpdv                  int
dstcodec                string
dstlatency              int
dstrfactor              int
srcsiprespcode          int
peerprotocol            string
srcprivateip            string
dstprivateip            string
srcigrpname             string
dstigrpname             string
diversioninfo           string
customcontacttag        string
e911call                string
unspecified5            string
unspecified6            string
callreleasesource       string
huntattemptsincludinglcf        int
callgappingerror        int
errorcodeinreasonheader int
oclobjecttype           string
oclobjectiddtnregidrealmname    string
oclobjectiddtnrealmuport        string
oclpolicyname           string
srcprivateport          string
destprivateport         string
srcrealmmediaip         string
srcrealmmediaport       string
dstrealmmediaip         string
dstrealmmediaport       string
origtgc                 string
termtgc                 string
srcpcv                  string
destpcv                 string
srcpani                 string
destpani                string
callconnecttimemsec     string
endtimemsec             string
routingnumber           string
mlines                  int
fromuriuserpart         string
newfromuriuserpart      string
paiduriuserpart         string
newpaiduriuserpart      string
privacy                 string
requesturiuserpart      string
newrequesturiuserpart   string
localrefertransferstatus        string
sipfinalresponsereason  string
srcsiprespreason        string
chargenumber            string
chargenumbernoa         int
chargenumbernpi         int
segmentstarttimems      string
segmentdurationfractional       string
srcxrlossrate           int
srcxrdiscardrate        int
srcxrburstdensity       int
srcxrgapdensity         int
srcxrburstduration      int
srcxrgapduration        int
srcxrroundtripdelay     int
srcxrendsystemdelay     int
srcxrgmin               int
srcxrjitterbufferadaptive       int
srcxrjitterbufferrate   int
srcxrrfactor            int
srcxrmos_cq             int
srcxrjitterbuffernominaldelay   int
srcxrjitterbuffermaximumdelay   int
srcxrjitterbufferabsolutemaximumdelay   int
dstxrlossrate           int
dstxrdiscardrate        int
dstxrburstdensity       int
dstxrgapdensity         int
dstxrburstduration      int
dstxrgapduration        int
dstxrroundtripdelay     int
dstxrendsystemdelay     int
dstxrgmin               int
dstxrjitterbufferadaptive       int
dstxrjitterbufferrate   int
dstxrrfactor            int
dstxrmos_cq             int
dstxrjitterbuffernominaldelay   int
dstxrjitterbuffermaximumdelay   int
dstxrjitterbufferabsolutemaximumdelay   int
unspecified7            string
unspecified8            string
srcciphersuite          string
destciphersuite         string
srcpacketoutsidereplaywindow    int
srcpacketauthfailure    int
srcpacketcipherfailure  int
destpacketoutsidereplaywindow   int
destpacketauthfailure   int
destpacketcipherfailure int
fmmcallleginfo1         string
fmmcallleginfo2         string
fmmcallleginfo3         string
fmmcallleginfo4         string
fmmcallleginfo5         string
fmmcallinfo1            string
fmmcallinfo2            string
fmmcallinfo3            string
fmmcallinfo4            string
fmmcallinfo5            string
embeddeddspinsertion    string
outgoingtouri           string
incomingrequesturi      string
incomingrsaipaddress    string
sbciserverversion       string
outgoingrequesturi      string
outgoingfromuri         string
privacyingressrequested string
privacymethodegress     string
privacyegressrequested  string
srcpolicedpackets       string
ddate                   string

# Partition Information
# col_name              data_type               comment

ddate                   string
Time taken: 0.534 seconds, Fetched: 193 row(s)

Thanks for any support that can be offered.
Keith Wiggins
Software Designer

500 Palladium Drive, Suite 2100
Ottawa ON Canada K2V 1C2
www.genband.com<http://www.genband.com/>
office:+1.343.883.2656

keith.wiggins@genband.com
[Description: http://www.genband.com/extras/email/email_signature_line_below.jpg]<http://www.genband.com/>
Connect with us:[Description: http://www.genband.com/extras/email/facebookBTN.gif]<http://www.facebook.com/genband>[Description: http://www.genband.com/extras/email/twitterBTN.gif]<https://twitter.com/#!/genband>[Description: http://www.genband.com/extras/email/linkedBTN.gif]<http://www.linkedin.com/company/genband>[Description: http://www.genband.com/extras/email/youtubeBTN.gif]<http://www.youtube.com/GenbandClips>[Description: http://www.genband.com/extras/email/blogBTN.gif]<http://www.genband.com/driving-innovation>