Uses of Class
org.apache.accumulo.core.data.thrift.IterInfo

Packages that use IterInfo
org.apache.accumulo.core.client.impl   
org.apache.accumulo.core.data.thrift   
org.apache.accumulo.core.iterators   
org.apache.accumulo.core.tabletserver.thrift   
 

Uses of IterInfo in org.apache.accumulo.core.client.impl
 

Fields in org.apache.accumulo.core.client.impl with type parameters of type IterInfo
protected  List<IterInfo> ScannerOptions.serverSideIteratorList
           
 List<IterInfo> CompressedIterators.IterConfig.ssiList
           
 

Method parameters in org.apache.accumulo.core.client.impl with type arguments of type IterInfo
static boolean ThriftScanner.getBatchFromServer(Instance instance, Credentials credentials, Range range, KeyExtent extent, String server, SortedMap<Key,Value> results, SortedSet<Column> fetchedColumns, List<IterInfo> serverSideIteratorList, Map<String,Map<String,String>> serverSideIteratorOptions, int size, Authorizations authorizations, boolean retry, AccumuloConfiguration conf)
           
 

Constructor parameters in org.apache.accumulo.core.client.impl with type arguments of type IterInfo
ThriftScanner.ScanState(Instance instance, Credentials credentials, org.apache.hadoop.io.Text tableId, Authorizations authorizations, Range range, SortedSet<Column> fetchedColumns, int size, List<IterInfo> serverSideIteratorList, Map<String,Map<String,String>> serverSideIteratorOptions, boolean isolated)
           
ThriftScanner.ScanState(Instance instance, Credentials credentials, org.apache.hadoop.io.Text tableId, Authorizations authorizations, Range range, SortedSet<Column> fetchedColumns, int size, List<IterInfo> serverSideIteratorList, Map<String,Map<String,String>> serverSideIteratorOptions, boolean isolated, long readaheadThreshold)
           
 

Uses of IterInfo in org.apache.accumulo.core.data.thrift
 

Methods in org.apache.accumulo.core.data.thrift that return IterInfo
 IterInfo IterInfo.deepCopy()
           
 IterInfo IterInfo.setClassName(String className)
           
 IterInfo IterInfo.setIterName(String iterName)
           
 IterInfo IterInfo.setPriority(int priority)
           
 

Methods in org.apache.accumulo.core.data.thrift with parameters of type IterInfo
 int IterInfo.compareTo(IterInfo other)
           
 boolean IterInfo.equals(IterInfo that)
           
 

Constructors in org.apache.accumulo.core.data.thrift with parameters of type IterInfo
IterInfo(IterInfo other)
          Performs a deep copy on other.
 

Uses of IterInfo in org.apache.accumulo.core.iterators
 

Methods in org.apache.accumulo.core.iterators with parameters of type IterInfo
 int IteratorUtil.IterInfoComparator.compare(IterInfo o1, IterInfo o2)
           
 

Method parameters in org.apache.accumulo.core.iterators with type arguments of type IterInfo
static
<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
SortedKeyValueIterator<K,V>
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent, AccumuloConfiguration conf, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, IteratorEnvironment env)
           
static
<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
SortedKeyValueIterator<K,V>
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent, AccumuloConfiguration conf, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, IteratorEnvironment env, boolean useAccumuloClassLoader)
           
static
<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
SortedKeyValueIterator<K,V>
IteratorUtil.loadIterators(SortedKeyValueIterator<K,V> source, Collection<IterInfo> iters, Map<String,Map<String,String>> iterOpts, IteratorEnvironment env, boolean useAccumuloClassLoader, String context)
           
protected static void IteratorUtil.parseIterConf(IteratorUtil.IteratorScope scope, List<IterInfo> iters, Map<String,Map<String,String>> allOptions, AccumuloConfiguration conf)
           
 

Uses of IterInfo in org.apache.accumulo.core.tabletserver.thrift
 

Fields in org.apache.accumulo.core.tabletserver.thrift with type parameters of type IterInfo
 List<IterInfo> TabletClientService.startScan_args.ssiList
           
 List<IterInfo> TabletClientService.startMultiScan_args.ssiList
           
 List<IterInfo> ActiveScan.ssiList
           
 List<IterInfo> ActiveCompaction.ssiList
           
 

Methods in org.apache.accumulo.core.tabletserver.thrift that return types with arguments of type IterInfo
 List<IterInfo> TabletClientService.startScan_args.getSsiList()
           
 List<IterInfo> TabletClientService.startMultiScan_args.getSsiList()
           
 List<IterInfo> ActiveScan.getSsiList()
           
 List<IterInfo> ActiveCompaction.getSsiList()
           
 Iterator<IterInfo> TabletClientService.startScan_args.getSsiListIterator()
           
 Iterator<IterInfo> TabletClientService.startMultiScan_args.getSsiListIterator()
           
 Iterator<IterInfo> ActiveScan.getSsiListIterator()
           
 Iterator<IterInfo> ActiveCompaction.getSsiListIterator()
           
 

Methods in org.apache.accumulo.core.tabletserver.thrift with parameters of type IterInfo
 void TabletClientService.startScan_args.addToSsiList(IterInfo elem)
           
 void TabletClientService.startMultiScan_args.addToSsiList(IterInfo elem)
           
 void ActiveScan.addToSsiList(IterInfo elem)
           
 void ActiveCompaction.addToSsiList(IterInfo elem)
           
 

Method parameters in org.apache.accumulo.core.tabletserver.thrift with type arguments of type IterInfo
 void TabletClientService.Client.send_startMultiScan(TInfo tinfo, TCredentials credentials, Map<TKeyExtent,List<TRange>> batch, List<TColumn> columns, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, List<ByteBuffer> authorizations, boolean waitForWrites)
           
 void TabletClientService.Client.send_startScan(TInfo tinfo, TCredentials credentials, TKeyExtent extent, TRange range, List<TColumn> columns, int batchSize, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, List<ByteBuffer> authorizations, boolean waitForWrites, boolean isolated, long readaheadThreshold)
           
 TabletClientService.startScan_args TabletClientService.startScan_args.setSsiList(List<IterInfo> ssiList)
           
 TabletClientService.startMultiScan_args TabletClientService.startMultiScan_args.setSsiList(List<IterInfo> ssiList)
           
 ActiveScan ActiveScan.setSsiList(List<IterInfo> ssiList)
           
 ActiveCompaction ActiveCompaction.setSsiList(List<IterInfo> ssiList)
           
 InitialMultiScan TabletClientService.Iface.startMultiScan(TInfo tinfo, TCredentials credentials, Map<TKeyExtent,List<TRange>> batch, List<TColumn> columns, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, List<ByteBuffer> authorizations, boolean waitForWrites)
           
 InitialMultiScan TabletClientService.Client.startMultiScan(TInfo tinfo, TCredentials credentials, Map<TKeyExtent,List<TRange>> batch, List<TColumn> columns, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, List<ByteBuffer> authorizations, boolean waitForWrites)
           
 void TabletClientService.AsyncIface.startMultiScan(TInfo tinfo, TCredentials credentials, Map<TKeyExtent,List<TRange>> batch, List<TColumn> columns, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, List<ByteBuffer> authorizations, boolean waitForWrites, org.apache.thrift.async.AsyncMethodCallback resultHandler)
           
 void TabletClientService.AsyncClient.startMultiScan(TInfo tinfo, TCredentials credentials, Map<TKeyExtent,List<TRange>> batch, List<TColumn> columns, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, List<ByteBuffer> authorizations, boolean waitForWrites, org.apache.thrift.async.AsyncMethodCallback resultHandler)
           
 InitialScan TabletClientService.Iface.startScan(TInfo tinfo, TCredentials credentials, TKeyExtent extent, TRange range, List<TColumn> columns, int batchSize, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, List<ByteBuffer> authorizations, boolean waitForWrites, boolean isolated, long readaheadThreshold)
           
 InitialScan TabletClientService.Client.startScan(TInfo tinfo, TCredentials credentials, TKeyExtent extent, TRange range, List<TColumn> columns, int batchSize, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, List<ByteBuffer> authorizations, boolean waitForWrites, boolean isolated, long readaheadThreshold)
           
 void TabletClientService.AsyncIface.startScan(TInfo tinfo, TCredentials credentials, TKeyExtent extent, TRange range, List<TColumn> columns, int batchSize, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, List<ByteBuffer> authorizations, boolean waitForWrites, boolean isolated, long readaheadThreshold, org.apache.thrift.async.AsyncMethodCallback resultHandler)
           
 void TabletClientService.AsyncClient.startScan(TInfo tinfo, TCredentials credentials, TKeyExtent extent, TRange range, List<TColumn> columns, int batchSize, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, List<ByteBuffer> authorizations, boolean waitForWrites, boolean isolated, long readaheadThreshold, org.apache.thrift.async.AsyncMethodCallback resultHandler)
           
 

Constructor parameters in org.apache.accumulo.core.tabletserver.thrift with type arguments of type IterInfo
ActiveCompaction(TKeyExtent extent, long age, List<String> inputFiles, String outputFile, CompactionType type, CompactionReason reason, String localityGroup, long entriesRead, long entriesWritten, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio)
           
ActiveScan(String client, String user, String tableId, long age, long idleTime, ScanType type, ScanState state, TKeyExtent extent, List<TColumn> columns, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, List<ByteBuffer> authorizations)
           
TabletClientService.AsyncClient.startMultiScan_call(TInfo tinfo, TCredentials credentials, Map<TKeyExtent,List<TRange>> batch, List<TColumn> columns, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, List<ByteBuffer> authorizations, boolean waitForWrites, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport)
           
TabletClientService.AsyncClient.startScan_call(TInfo tinfo, TCredentials credentials, TKeyExtent extent, TRange range, List<TColumn> columns, int batchSize, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, List<ByteBuffer> authorizations, boolean waitForWrites, boolean isolated, long readaheadThreshold, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport)
           
TabletClientService.startMultiScan_args(TInfo tinfo, TCredentials credentials, Map<TKeyExtent,List<TRange>> batch, List<TColumn> columns, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, List<ByteBuffer> authorizations, boolean waitForWrites)
           
TabletClientService.startScan_args(TInfo tinfo, TCredentials credentials, TKeyExtent extent, TRange range, List<TColumn> columns, int batchSize, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, List<ByteBuffer> authorizations, boolean waitForWrites, boolean isolated, long readaheadThreshold)
           
 



Copyright © 2015 Apache Accumulo Project. All rights reserved.